DELETE addresses-{addressId}
{{baseUrl}}/V1/addresses/:addressId
QUERY PARAMS

addressId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/addresses/:addressId");

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

(client/delete "{{baseUrl}}/V1/addresses/:addressId")
require "http/client"

url = "{{baseUrl}}/V1/addresses/:addressId"

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

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

func main() {

	url := "{{baseUrl}}/V1/addresses/:addressId"

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

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

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

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

}
DELETE /baseUrl/V1/addresses/:addressId HTTP/1.1
Host: example.com

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

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

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

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

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/addresses/:addressId'};

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

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/V1/addresses/:addressId")
  .delete(null)
  .build()

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

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

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

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

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

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

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/addresses/:addressId'};

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

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

const req = unirest('DELETE', '{{baseUrl}}/V1/addresses/:addressId');

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}}/V1/addresses/:addressId'};

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

const url = '{{baseUrl}}/V1/addresses/:addressId';
const options = {method: 'DELETE'};

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

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

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

let uri = Uri.of_string "{{baseUrl}}/V1/addresses/:addressId" in

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

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

curl_close($curl);

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

echo $response->getBody();
setUrl('{{baseUrl}}/V1/addresses/:addressId');
$request->setMethod(HTTP_METH_DELETE);

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

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

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

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

conn.request("DELETE", "/baseUrl/V1/addresses/:addressId")

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

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

url = "{{baseUrl}}/V1/addresses/:addressId"

response = requests.delete(url)

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

url <- "{{baseUrl}}/V1/addresses/:addressId"

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

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

url = URI("{{baseUrl}}/V1/addresses/:addressId")

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

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

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

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

response = conn.delete('/baseUrl/V1/addresses/:addressId') do |req|
end

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

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

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

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

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

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

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

dataTask.resume()
PUT amazon-billing-address-{amazonOrderReferenceId}
{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId
QUERY PARAMS

amazonOrderReferenceId
BODY json

{
  "addressConsentToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"addressConsentToken\": \"\"\n}");

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

(client/put "{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId" {:content-type :json
                                                                                             :form-params {:addressConsentToken ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId"

	payload := strings.NewReader("{\n  \"addressConsentToken\": \"\"\n}")

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

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

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

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

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

}
PUT /baseUrl/V1/amazon-billing-address/:amazonOrderReferenceId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 31

{
  "addressConsentToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"addressConsentToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId")
  .header("content-type", "application/json")
  .body("{\n  \"addressConsentToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  addressConsentToken: ''
});

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

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

xhr.open('PUT', '{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId',
  headers: {'content-type': 'application/json'},
  data: {addressConsentToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"addressConsentToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "addressConsentToken": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"addressConsentToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/amazon-billing-address/:amazonOrderReferenceId',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId',
  headers: {'content-type': 'application/json'},
  body: {addressConsentToken: ''},
  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}}/V1/amazon-billing-address/:amazonOrderReferenceId');

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

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

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}}/V1/amazon-billing-address/:amazonOrderReferenceId',
  headers: {'content-type': 'application/json'},
  data: {addressConsentToken: ''}
};

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

const url = '{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"addressConsentToken":""}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"addressConsentToken": @"" };

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

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

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId', [
  'body' => '{
  "addressConsentToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId');
$request->setMethod(HTTP_METH_PUT);

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

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'addressConsentToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId');
$request->setRequestMethod('PUT');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "addressConsentToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "addressConsentToken": ""
}'
import http.client

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

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

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

conn.request("PUT", "/baseUrl/V1/amazon-billing-address/:amazonOrderReferenceId", payload, headers)

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

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

url = "{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId"

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

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

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

url <- "{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId"

payload <- "{\n  \"addressConsentToken\": \"\"\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId")

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

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"addressConsentToken\": \"\"\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/V1/amazon-billing-address/:amazonOrderReferenceId') do |req|
  req.body = "{\n  \"addressConsentToken\": \"\"\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}}/V1/amazon-billing-address/:amazonOrderReferenceId";

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

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

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

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

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId \
  --header 'content-type: application/json' \
  --data '{
  "addressConsentToken": ""
}'
echo '{
  "addressConsentToken": ""
}' |  \
  http PUT {{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "addressConsentToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId
import Foundation

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/amazon-billing-address/:amazonOrderReferenceId")! 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()
DELETE amazon-order-ref
{{baseUrl}}/V1/amazon/order-ref
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/amazon/order-ref");

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

(client/delete "{{baseUrl}}/V1/amazon/order-ref")
require "http/client"

url = "{{baseUrl}}/V1/amazon/order-ref"

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

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

func main() {

	url := "{{baseUrl}}/V1/amazon/order-ref"

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

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

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

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

}
DELETE /baseUrl/V1/amazon/order-ref HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/amazon/order-ref")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/amazon/order-ref")
  .asString();
const 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}}/V1/amazon/order-ref');

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

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/amazon/order-ref'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/amazon/order-ref';
const options = {method: 'DELETE'};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/V1/amazon/order-ref")
  .delete(null)
  .build()

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

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/amazon/order-ref',
  headers: {}
};

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

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

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

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

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/amazon/order-ref'};

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

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

const req = unirest('DELETE', '{{baseUrl}}/V1/amazon/order-ref');

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}}/V1/amazon/order-ref'};

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

const url = '{{baseUrl}}/V1/amazon/order-ref';
const options = {method: 'DELETE'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/amazon/order-ref"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

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

let uri = Uri.of_string "{{baseUrl}}/V1/amazon/order-ref" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/amazon/order-ref');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/amazon/order-ref');
$request->setMethod(HTTP_METH_DELETE);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/amazon/order-ref');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/amazon/order-ref' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/amazon/order-ref' -Method DELETE 
import http.client

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

conn.request("DELETE", "/baseUrl/V1/amazon/order-ref")

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

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

url = "{{baseUrl}}/V1/amazon/order-ref"

response = requests.delete(url)

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

url <- "{{baseUrl}}/V1/amazon/order-ref"

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

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

url = URI("{{baseUrl}}/V1/amazon/order-ref")

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

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

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

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

response = conn.delete('/baseUrl/V1/amazon/order-ref') do |req|
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/amazon/order-ref";

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

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

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/amazon/order-ref
http DELETE {{baseUrl}}/V1/amazon/order-ref
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/amazon/order-ref
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/amazon/order-ref")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

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

dataTask.resume()
PUT amazon-shipping-address-{amazonOrderReferenceId}
{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId
QUERY PARAMS

amazonOrderReferenceId
BODY json

{
  "addressConsentToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"addressConsentToken\": \"\"\n}");

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

(client/put "{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId" {:content-type :json
                                                                                              :form-params {:addressConsentToken ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId"

	payload := strings.NewReader("{\n  \"addressConsentToken\": \"\"\n}")

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

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

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

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

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

}
PUT /baseUrl/V1/amazon-shipping-address/:amazonOrderReferenceId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 31

{
  "addressConsentToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"addressConsentToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId")
  .header("content-type", "application/json")
  .body("{\n  \"addressConsentToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  addressConsentToken: ''
});

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

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

xhr.open('PUT', '{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId',
  headers: {'content-type': 'application/json'},
  data: {addressConsentToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"addressConsentToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "addressConsentToken": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"addressConsentToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/amazon-shipping-address/:amazonOrderReferenceId',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId',
  headers: {'content-type': 'application/json'},
  body: {addressConsentToken: ''},
  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}}/V1/amazon-shipping-address/:amazonOrderReferenceId');

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

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

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}}/V1/amazon-shipping-address/:amazonOrderReferenceId',
  headers: {'content-type': 'application/json'},
  data: {addressConsentToken: ''}
};

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

const url = '{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"addressConsentToken":""}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"addressConsentToken": @"" };

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

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

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId', [
  'body' => '{
  "addressConsentToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId');
$request->setMethod(HTTP_METH_PUT);

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

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'addressConsentToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId');
$request->setRequestMethod('PUT');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "addressConsentToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "addressConsentToken": ""
}'
import http.client

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

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

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

conn.request("PUT", "/baseUrl/V1/amazon-shipping-address/:amazonOrderReferenceId", payload, headers)

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

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

url = "{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId"

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

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

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

url <- "{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId"

payload <- "{\n  \"addressConsentToken\": \"\"\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId")

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

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"addressConsentToken\": \"\"\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/V1/amazon-shipping-address/:amazonOrderReferenceId') do |req|
  req.body = "{\n  \"addressConsentToken\": \"\"\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}}/V1/amazon-shipping-address/:amazonOrderReferenceId";

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

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

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

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

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId \
  --header 'content-type: application/json' \
  --data '{
  "addressConsentToken": ""
}'
echo '{
  "addressConsentToken": ""
}' |  \
  http PUT {{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "addressConsentToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId
import Foundation

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/amazon-shipping-address/:amazonOrderReferenceId")! 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}}/V1/analytics/link");

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

(client/get "{{baseUrl}}/V1/analytics/link")
require "http/client"

url = "{{baseUrl}}/V1/analytics/link"

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

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

func main() {

	url := "{{baseUrl}}/V1/analytics/link"

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

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

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

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

}
GET /baseUrl/V1/analytics/link HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/analytics/link")
  .get()
  .build();

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

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

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

xhr.open('GET', '{{baseUrl}}/V1/analytics/link');

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

const options = {method: 'GET', url: '{{baseUrl}}/V1/analytics/link'};

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

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

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

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

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

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

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/V1/analytics/link'};

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

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

const req = unirest('GET', '{{baseUrl}}/V1/analytics/link');

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

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

const options = {method: 'GET', url: '{{baseUrl}}/V1/analytics/link'};

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

const url = '{{baseUrl}}/V1/analytics/link';
const options = {method: 'GET'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/analytics/link"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

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

let uri = Uri.of_string "{{baseUrl}}/V1/analytics/link" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/analytics/link');

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

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

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

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

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

conn.request("GET", "/baseUrl/V1/analytics/link")

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

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

url = "{{baseUrl}}/V1/analytics/link"

response = requests.get(url)

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

url <- "{{baseUrl}}/V1/analytics/link"

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

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

url = URI("{{baseUrl}}/V1/analytics/link")

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

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

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

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

response = conn.get('/baseUrl/V1/analytics/link') do |req|
end

puts response.status
puts response.body
use reqwest;

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

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/analytics/link
http GET {{baseUrl}}/V1/analytics/link
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/analytics/link
import Foundation

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

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

dataTask.resume()
GET attributeMetadata-customer
{{baseUrl}}/V1/attributeMetadata/customer
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/attributeMetadata/customer");

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

(client/get "{{baseUrl}}/V1/attributeMetadata/customer")
require "http/client"

url = "{{baseUrl}}/V1/attributeMetadata/customer"

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

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

func main() {

	url := "{{baseUrl}}/V1/attributeMetadata/customer"

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

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

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

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

}
GET /baseUrl/V1/attributeMetadata/customer HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/attributeMetadata/customer")
  .get()
  .build();

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

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

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

xhr.open('GET', '{{baseUrl}}/V1/attributeMetadata/customer');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customer'
};

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

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

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

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

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

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

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customer'
};

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

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

const req = unirest('GET', '{{baseUrl}}/V1/attributeMetadata/customer');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customer'
};

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

const url = '{{baseUrl}}/V1/attributeMetadata/customer';
const options = {method: 'GET'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/attributeMetadata/customer"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

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

let uri = Uri.of_string "{{baseUrl}}/V1/attributeMetadata/customer" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/attributeMetadata/customer');

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

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

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

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

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

conn.request("GET", "/baseUrl/V1/attributeMetadata/customer")

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

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

url = "{{baseUrl}}/V1/attributeMetadata/customer"

response = requests.get(url)

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

url <- "{{baseUrl}}/V1/attributeMetadata/customer"

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

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

url = URI("{{baseUrl}}/V1/attributeMetadata/customer")

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

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

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

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

response = conn.get('/baseUrl/V1/attributeMetadata/customer') do |req|
end

puts response.status
puts response.body
use reqwest;

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

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/attributeMetadata/customer
http GET {{baseUrl}}/V1/attributeMetadata/customer
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/attributeMetadata/customer
import Foundation

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

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

dataTask.resume()
GET attributeMetadata-customer-attribute-{attributeCode}
{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode
QUERY PARAMS

attributeCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode");

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

(client/get "{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode")
require "http/client"

url = "{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode"

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

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

func main() {

	url := "{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode"

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

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

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

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

}
GET /baseUrl/V1/attributeMetadata/customer/attribute/:attributeCode HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode';
const options = {method: 'GET'};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/attributeMetadata/customer/attribute/:attributeCode',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode'
};

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

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

const req = unirest('GET', '{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode'
};

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

const url = '{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode';
const options = {method: 'GET'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

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

let uri = Uri.of_string "{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/V1/attributeMetadata/customer/attribute/:attributeCode")

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

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

url = "{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode"

response = requests.get(url)

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

url <- "{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode"

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

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

url = URI("{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode")

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

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

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

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

response = conn.get('/baseUrl/V1/attributeMetadata/customer/attribute/:attributeCode') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode";

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode
http GET {{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/attributeMetadata/customer/attribute/:attributeCode
import Foundation

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

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

dataTask.resume()
GET attributeMetadata-customer-custom
{{baseUrl}}/V1/attributeMetadata/customer/custom
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/attributeMetadata/customer/custom");

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

(client/get "{{baseUrl}}/V1/attributeMetadata/customer/custom")
require "http/client"

url = "{{baseUrl}}/V1/attributeMetadata/customer/custom"

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

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

func main() {

	url := "{{baseUrl}}/V1/attributeMetadata/customer/custom"

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

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

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

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

}
GET /baseUrl/V1/attributeMetadata/customer/custom HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/attributeMetadata/customer/custom")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/attributeMetadata/customer/custom")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/V1/attributeMetadata/customer/custom');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customer/custom'
};

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

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/V1/attributeMetadata/customer/custom")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/attributeMetadata/customer/custom',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customer/custom'
};

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

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

const req = unirest('GET', '{{baseUrl}}/V1/attributeMetadata/customer/custom');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customer/custom'
};

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

const url = '{{baseUrl}}/V1/attributeMetadata/customer/custom';
const options = {method: 'GET'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/attributeMetadata/customer/custom"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

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

let uri = Uri.of_string "{{baseUrl}}/V1/attributeMetadata/customer/custom" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/attributeMetadata/customer/custom');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/attributeMetadata/customer/custom');
$request->setMethod(HTTP_METH_GET);

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

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

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

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

conn.request("GET", "/baseUrl/V1/attributeMetadata/customer/custom")

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

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

url = "{{baseUrl}}/V1/attributeMetadata/customer/custom"

response = requests.get(url)

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

url <- "{{baseUrl}}/V1/attributeMetadata/customer/custom"

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

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

url = URI("{{baseUrl}}/V1/attributeMetadata/customer/custom")

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

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

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

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

response = conn.get('/baseUrl/V1/attributeMetadata/customer/custom') do |req|
end

puts response.status
puts response.body
use reqwest;

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

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/attributeMetadata/customer/custom
http GET {{baseUrl}}/V1/attributeMetadata/customer/custom
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/attributeMetadata/customer/custom
import Foundation

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

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

dataTask.resume()
GET attributeMetadata-customer-form-{formCode}
{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode
QUERY PARAMS

formCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode");

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

(client/get "{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode")
require "http/client"

url = "{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode"

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

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

func main() {

	url := "{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode"

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

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

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

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

}
GET /baseUrl/V1/attributeMetadata/customer/form/:formCode HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode';
const options = {method: 'GET'};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/attributeMetadata/customer/form/:formCode',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode'
};

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

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

const req = unirest('GET', '{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode'
};

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

const url = '{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode';
const options = {method: 'GET'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

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

let uri = Uri.of_string "{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/V1/attributeMetadata/customer/form/:formCode")

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

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

url = "{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode"

response = requests.get(url)

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

url <- "{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode"

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

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

url = URI("{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode")

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

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

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

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

response = conn.get('/baseUrl/V1/attributeMetadata/customer/form/:formCode') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/attributeMetadata/customer/form/:formCode";

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/attributeMetadata/customer/form/:formCode
http GET {{baseUrl}}/V1/attributeMetadata/customer/form/:formCode
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/attributeMetadata/customer/form/:formCode
import Foundation

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

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

dataTask.resume()
GET attributeMetadata-customerAddress
{{baseUrl}}/V1/attributeMetadata/customerAddress
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/attributeMetadata/customerAddress");

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

(client/get "{{baseUrl}}/V1/attributeMetadata/customerAddress")
require "http/client"

url = "{{baseUrl}}/V1/attributeMetadata/customerAddress"

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

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

func main() {

	url := "{{baseUrl}}/V1/attributeMetadata/customerAddress"

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

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

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

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

}
GET /baseUrl/V1/attributeMetadata/customerAddress HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/attributeMetadata/customerAddress")
  .get()
  .build();

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

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

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

xhr.open('GET', '{{baseUrl}}/V1/attributeMetadata/customerAddress');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customerAddress'
};

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

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

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

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

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

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

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customerAddress'
};

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

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

const req = unirest('GET', '{{baseUrl}}/V1/attributeMetadata/customerAddress');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customerAddress'
};

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

const url = '{{baseUrl}}/V1/attributeMetadata/customerAddress';
const options = {method: 'GET'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/attributeMetadata/customerAddress"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

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

let uri = Uri.of_string "{{baseUrl}}/V1/attributeMetadata/customerAddress" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/attributeMetadata/customerAddress');

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

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

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

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

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

conn.request("GET", "/baseUrl/V1/attributeMetadata/customerAddress")

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

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

url = "{{baseUrl}}/V1/attributeMetadata/customerAddress"

response = requests.get(url)

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

url <- "{{baseUrl}}/V1/attributeMetadata/customerAddress"

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

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

url = URI("{{baseUrl}}/V1/attributeMetadata/customerAddress")

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

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

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

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

response = conn.get('/baseUrl/V1/attributeMetadata/customerAddress') do |req|
end

puts response.status
puts response.body
use reqwest;

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

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/attributeMetadata/customerAddress
http GET {{baseUrl}}/V1/attributeMetadata/customerAddress
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/attributeMetadata/customerAddress
import Foundation

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

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

dataTask.resume()
GET attributeMetadata-customerAddress-attribute-{attributeCode}
{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode
QUERY PARAMS

attributeCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode");

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

(client/get "{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode")
require "http/client"

url = "{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode"

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

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

func main() {

	url := "{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode"

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

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

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

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

}
GET /baseUrl/V1/attributeMetadata/customerAddress/attribute/:attributeCode HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode';
const options = {method: 'GET'};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/attributeMetadata/customerAddress/attribute/:attributeCode',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode'
};

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

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

const req = unirest('GET', '{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode'
};

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

const url = '{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode';
const options = {method: 'GET'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

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

let uri = Uri.of_string "{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/V1/attributeMetadata/customerAddress/attribute/:attributeCode")

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

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

url = "{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode"

response = requests.get(url)

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

url <- "{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode"

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

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

url = URI("{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode")

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

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

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

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

response = conn.get('/baseUrl/V1/attributeMetadata/customerAddress/attribute/:attributeCode') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode";

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode
http GET {{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/attributeMetadata/customerAddress/attribute/:attributeCode
import Foundation

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

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

dataTask.resume()
GET attributeMetadata-customerAddress-custom
{{baseUrl}}/V1/attributeMetadata/customerAddress/custom
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/attributeMetadata/customerAddress/custom");

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

(client/get "{{baseUrl}}/V1/attributeMetadata/customerAddress/custom")
require "http/client"

url = "{{baseUrl}}/V1/attributeMetadata/customerAddress/custom"

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

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

func main() {

	url := "{{baseUrl}}/V1/attributeMetadata/customerAddress/custom"

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

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

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

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

}
GET /baseUrl/V1/attributeMetadata/customerAddress/custom HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/attributeMetadata/customerAddress/custom")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/attributeMetadata/customerAddress/custom")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/V1/attributeMetadata/customerAddress/custom');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customerAddress/custom'
};

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

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/V1/attributeMetadata/customerAddress/custom")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/attributeMetadata/customerAddress/custom',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customerAddress/custom'
};

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

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

const req = unirest('GET', '{{baseUrl}}/V1/attributeMetadata/customerAddress/custom');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customerAddress/custom'
};

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

const url = '{{baseUrl}}/V1/attributeMetadata/customerAddress/custom';
const options = {method: 'GET'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/attributeMetadata/customerAddress/custom"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

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

let uri = Uri.of_string "{{baseUrl}}/V1/attributeMetadata/customerAddress/custom" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/attributeMetadata/customerAddress/custom');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/attributeMetadata/customerAddress/custom');
$request->setMethod(HTTP_METH_GET);

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

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

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

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

conn.request("GET", "/baseUrl/V1/attributeMetadata/customerAddress/custom")

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

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

url = "{{baseUrl}}/V1/attributeMetadata/customerAddress/custom"

response = requests.get(url)

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

url <- "{{baseUrl}}/V1/attributeMetadata/customerAddress/custom"

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

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

url = URI("{{baseUrl}}/V1/attributeMetadata/customerAddress/custom")

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

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

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

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

response = conn.get('/baseUrl/V1/attributeMetadata/customerAddress/custom') do |req|
end

puts response.status
puts response.body
use reqwest;

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

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/attributeMetadata/customerAddress/custom
http GET {{baseUrl}}/V1/attributeMetadata/customerAddress/custom
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/attributeMetadata/customerAddress/custom
import Foundation

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

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

dataTask.resume()
GET attributeMetadata-customerAddress-form-{formCode}
{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode
QUERY PARAMS

formCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode");

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

(client/get "{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode")
require "http/client"

url = "{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode"

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

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

func main() {

	url := "{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode"

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

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

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

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

}
GET /baseUrl/V1/attributeMetadata/customerAddress/form/:formCode HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode';
const options = {method: 'GET'};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/attributeMetadata/customerAddress/form/:formCode',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode'
};

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

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

const req = unirest('GET', '{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode'
};

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

const url = '{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode';
const options = {method: 'GET'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

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

let uri = Uri.of_string "{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/V1/attributeMetadata/customerAddress/form/:formCode")

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

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

url = "{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode"

response = requests.get(url)

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

url <- "{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode"

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

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

url = URI("{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode")

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

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

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

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

response = conn.get('/baseUrl/V1/attributeMetadata/customerAddress/form/:formCode') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode";

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode
http GET {{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/attributeMetadata/customerAddress/form/:formCode
import Foundation

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

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

dataTask.resume()
GET bulk-{bulkUuid}-detailed-status
{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status
QUERY PARAMS

bulkUuid
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status");

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

(client/get "{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status")
require "http/client"

url = "{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status"

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

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

func main() {

	url := "{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status"

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

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

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

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

}
GET /baseUrl/V1/bulk/:bulkUuid/detailed-status HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status';
const options = {method: 'GET'};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/bulk/:bulkUuid/detailed-status',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status'
};

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

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

const req = unirest('GET', '{{baseUrl}}/V1/bulk/:bulkUuid/detailed-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: 'GET',
  url: '{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status'
};

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

const url = '{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status';
const options = {method: 'GET'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

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

let uri = Uri.of_string "{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/V1/bulk/:bulkUuid/detailed-status")

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

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

url = "{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status"

response = requests.get(url)

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

url <- "{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status"

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

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

url = URI("{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status")

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

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

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

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

response = conn.get('/baseUrl/V1/bulk/:bulkUuid/detailed-status') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status";

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/bulk/:bulkUuid/detailed-status
http GET {{baseUrl}}/V1/bulk/:bulkUuid/detailed-status
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/bulk/:bulkUuid/detailed-status
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/bulk/:bulkUuid/detailed-status")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

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

dataTask.resume()
GET bulk-{bulkUuid}-operation-status-{status}
{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status
QUERY PARAMS

bulkUuid
status
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status");

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

(client/get "{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status")
require "http/client"

url = "{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status"

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

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

func main() {

	url := "{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status"

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

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

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

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

}
GET /baseUrl/V1/bulk/:bulkUuid/operation-status/:status HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status';
const options = {method: 'GET'};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/bulk/:bulkUuid/operation-status/:status',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status'
};

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

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

const req = unirest('GET', '{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/: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: 'GET',
  url: '{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status'
};

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

const url = '{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status';
const options = {method: 'GET'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

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

let uri = Uri.of_string "{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/V1/bulk/:bulkUuid/operation-status/:status")

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

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

url = "{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status"

response = requests.get(url)

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

url <- "{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status"

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

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

url = URI("{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status")

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

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

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

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

response = conn.get('/baseUrl/V1/bulk/:bulkUuid/operation-status/:status') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status";

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status
http GET {{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/bulk/:bulkUuid/operation-status/:status")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

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

dataTask.resume()
GET bulk-{bulkUuid}-status
{{baseUrl}}/V1/bulk/:bulkUuid/status
QUERY PARAMS

bulkUuid
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/bulk/:bulkUuid/status");

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

(client/get "{{baseUrl}}/V1/bulk/:bulkUuid/status")
require "http/client"

url = "{{baseUrl}}/V1/bulk/:bulkUuid/status"

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

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

func main() {

	url := "{{baseUrl}}/V1/bulk/:bulkUuid/status"

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

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

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

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

}
GET /baseUrl/V1/bulk/:bulkUuid/status HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/bulk/:bulkUuid/status")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/bulk/:bulkUuid/status")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/V1/bulk/:bulkUuid/status');

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

const options = {method: 'GET', url: '{{baseUrl}}/V1/bulk/:bulkUuid/status'};

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

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/V1/bulk/:bulkUuid/status")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/bulk/:bulkUuid/status',
  headers: {}
};

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/V1/bulk/:bulkUuid/status'};

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

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

const req = unirest('GET', '{{baseUrl}}/V1/bulk/:bulkUuid/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: 'GET', url: '{{baseUrl}}/V1/bulk/:bulkUuid/status'};

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

const url = '{{baseUrl}}/V1/bulk/:bulkUuid/status';
const options = {method: 'GET'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/bulk/:bulkUuid/status"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

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

let uri = Uri.of_string "{{baseUrl}}/V1/bulk/:bulkUuid/status" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/bulk/:bulkUuid/status');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/bulk/:bulkUuid/status');
$request->setMethod(HTTP_METH_GET);

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

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

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

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

conn.request("GET", "/baseUrl/V1/bulk/:bulkUuid/status")

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

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

url = "{{baseUrl}}/V1/bulk/:bulkUuid/status"

response = requests.get(url)

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

url <- "{{baseUrl}}/V1/bulk/:bulkUuid/status"

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

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

url = URI("{{baseUrl}}/V1/bulk/:bulkUuid/status")

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

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

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

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

response = conn.get('/baseUrl/V1/bulk/:bulkUuid/status') do |req|
end

puts response.status
puts response.body
use reqwest;

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

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/bulk/:bulkUuid/status
http GET {{baseUrl}}/V1/bulk/:bulkUuid/status
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/bulk/:bulkUuid/status
import Foundation

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

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

dataTask.resume()
GET bundle-products-{productSku}-children
{{baseUrl}}/V1/bundle-products/:productSku/children
QUERY PARAMS

productSku
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/bundle-products/:productSku/children");

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

(client/get "{{baseUrl}}/V1/bundle-products/:productSku/children")
require "http/client"

url = "{{baseUrl}}/V1/bundle-products/:productSku/children"

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

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

func main() {

	url := "{{baseUrl}}/V1/bundle-products/:productSku/children"

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

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

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

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

}
GET /baseUrl/V1/bundle-products/:productSku/children HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/bundle-products/:productSku/children")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/:productSku/children")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/bundle-products/:productSku/children")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/V1/bundle-products/:productSku/children');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/bundle-products/:productSku/children'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/bundle-products/:productSku/children';
const options = {method: 'GET'};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/:productSku/children")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/bundle-products/:productSku/children',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/bundle-products/:productSku/children'
};

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

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

const req = unirest('GET', '{{baseUrl}}/V1/bundle-products/:productSku/children');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/bundle-products/:productSku/children'
};

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

const url = '{{baseUrl}}/V1/bundle-products/:productSku/children';
const options = {method: 'GET'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/bundle-products/:productSku/children"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

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

let uri = Uri.of_string "{{baseUrl}}/V1/bundle-products/:productSku/children" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/bundle-products/:productSku/children');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/bundle-products/:productSku/children');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/bundle-products/:productSku/children');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/bundle-products/:productSku/children' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/bundle-products/:productSku/children' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/V1/bundle-products/:productSku/children")

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

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

url = "{{baseUrl}}/V1/bundle-products/:productSku/children"

response = requests.get(url)

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

url <- "{{baseUrl}}/V1/bundle-products/:productSku/children"

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

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

url = URI("{{baseUrl}}/V1/bundle-products/:productSku/children")

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

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

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

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

response = conn.get('/baseUrl/V1/bundle-products/:productSku/children') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/bundle-products/:productSku/children";

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/bundle-products/:productSku/children
http GET {{baseUrl}}/V1/bundle-products/:productSku/children
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/bundle-products/:productSku/children
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/bundle-products/:productSku/children")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

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

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/bundle-products/:sku/links/:id");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}");

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

(client/put "{{baseUrl}}/V1/bundle-products/:sku/links/:id" {:content-type :json
                                                                             :form-params {:linkedProduct {:can_change_quantity 0
                                                                                                           :extension_attributes {}
                                                                                                           :id ""
                                                                                                           :is_default false
                                                                                                           :option_id 0
                                                                                                           :position 0
                                                                                                           :price ""
                                                                                                           :price_type 0
                                                                                                           :qty ""
                                                                                                           :sku ""}}})
require "http/client"

url = "{{baseUrl}}/V1/bundle-products/:sku/links/:id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\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}}/V1/bundle-products/:sku/links/:id"),
    Content = new StringContent("{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\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}}/V1/bundle-products/:sku/links/:id");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/V1/bundle-products/:sku/links/:id"

	payload := strings.NewReader("{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}")

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

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

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

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

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

}
PUT /baseUrl/V1/bundle-products/:sku/links/:id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 235

{
  "linkedProduct": {
    "can_change_quantity": 0,
    "extension_attributes": {},
    "id": "",
    "is_default": false,
    "option_id": 0,
    "position": 0,
    "price": "",
    "price_type": 0,
    "qty": "",
    "sku": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/bundle-products/:sku/links/:id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/bundle-products/:sku/links/:id"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\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  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/:sku/links/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/bundle-products/:sku/links/:id")
  .header("content-type", "application/json")
  .body("{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  linkedProduct: {
    can_change_quantity: 0,
    extension_attributes: {},
    id: '',
    is_default: false,
    option_id: 0,
    position: 0,
    price: '',
    price_type: 0,
    qty: '',
    sku: ''
  }
});

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

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

xhr.open('PUT', '{{baseUrl}}/V1/bundle-products/:sku/links/:id');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/bundle-products/:sku/links/:id',
  headers: {'content-type': 'application/json'},
  data: {
    linkedProduct: {
      can_change_quantity: 0,
      extension_attributes: {},
      id: '',
      is_default: false,
      option_id: 0,
      position: 0,
      price: '',
      price_type: 0,
      qty: '',
      sku: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/bundle-products/:sku/links/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"linkedProduct":{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/bundle-products/:sku/links/:id',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "linkedProduct": {\n    "can_change_quantity": 0,\n    "extension_attributes": {},\n    "id": "",\n    "is_default": false,\n    "option_id": 0,\n    "position": 0,\n    "price": "",\n    "price_type": 0,\n    "qty": "",\n    "sku": ""\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  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/:sku/links/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/bundle-products/:sku/links/:id',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  linkedProduct: {
    can_change_quantity: 0,
    extension_attributes: {},
    id: '',
    is_default: false,
    option_id: 0,
    position: 0,
    price: '',
    price_type: 0,
    qty: '',
    sku: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/bundle-products/:sku/links/:id',
  headers: {'content-type': 'application/json'},
  body: {
    linkedProduct: {
      can_change_quantity: 0,
      extension_attributes: {},
      id: '',
      is_default: false,
      option_id: 0,
      position: 0,
      price: '',
      price_type: 0,
      qty: '',
      sku: ''
    }
  },
  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}}/V1/bundle-products/:sku/links/:id');

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

req.type('json');
req.send({
  linkedProduct: {
    can_change_quantity: 0,
    extension_attributes: {},
    id: '',
    is_default: false,
    option_id: 0,
    position: 0,
    price: '',
    price_type: 0,
    qty: '',
    sku: ''
  }
});

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}}/V1/bundle-products/:sku/links/:id',
  headers: {'content-type': 'application/json'},
  data: {
    linkedProduct: {
      can_change_quantity: 0,
      extension_attributes: {},
      id: '',
      is_default: false,
      option_id: 0,
      position: 0,
      price: '',
      price_type: 0,
      qty: '',
      sku: ''
    }
  }
};

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

const url = '{{baseUrl}}/V1/bundle-products/:sku/links/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"linkedProduct":{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"linkedProduct": @{ @"can_change_quantity": @0, @"extension_attributes": @{  }, @"id": @"", @"is_default": @NO, @"option_id": @0, @"position": @0, @"price": @"", @"price_type": @0, @"qty": @"", @"sku": @"" } };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/bundle-products/:sku/links/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

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

let uri = Uri.of_string "{{baseUrl}}/V1/bundle-products/:sku/links/:id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/bundle-products/:sku/links/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'linkedProduct' => [
        'can_change_quantity' => 0,
        'extension_attributes' => [
                
        ],
        'id' => '',
        'is_default' => null,
        'option_id' => 0,
        'position' => 0,
        'price' => '',
        'price_type' => 0,
        'qty' => '',
        'sku' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/bundle-products/:sku/links/:id', [
  'body' => '{
  "linkedProduct": {
    "can_change_quantity": 0,
    "extension_attributes": {},
    "id": "",
    "is_default": false,
    "option_id": 0,
    "position": 0,
    "price": "",
    "price_type": 0,
    "qty": "",
    "sku": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/bundle-products/:sku/links/:id');
$request->setMethod(HTTP_METH_PUT);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'linkedProduct' => [
    'can_change_quantity' => 0,
    'extension_attributes' => [
        
    ],
    'id' => '',
    'is_default' => null,
    'option_id' => 0,
    'position' => 0,
    'price' => '',
    'price_type' => 0,
    'qty' => '',
    'sku' => ''
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'linkedProduct' => [
    'can_change_quantity' => 0,
    'extension_attributes' => [
        
    ],
    'id' => '',
    'is_default' => null,
    'option_id' => 0,
    'position' => 0,
    'price' => '',
    'price_type' => 0,
    'qty' => '',
    'sku' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/bundle-products/:sku/links/:id');
$request->setRequestMethod('PUT');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/bundle-products/:sku/links/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "linkedProduct": {
    "can_change_quantity": 0,
    "extension_attributes": {},
    "id": "",
    "is_default": false,
    "option_id": 0,
    "position": 0,
    "price": "",
    "price_type": 0,
    "qty": "",
    "sku": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/bundle-products/:sku/links/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "linkedProduct": {
    "can_change_quantity": 0,
    "extension_attributes": {},
    "id": "",
    "is_default": false,
    "option_id": 0,
    "position": 0,
    "price": "",
    "price_type": 0,
    "qty": "",
    "sku": ""
  }
}'
import http.client

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

payload = "{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}"

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

conn.request("PUT", "/baseUrl/V1/bundle-products/:sku/links/:id", payload, headers)

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

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

url = "{{baseUrl}}/V1/bundle-products/:sku/links/:id"

payload = { "linkedProduct": {
        "can_change_quantity": 0,
        "extension_attributes": {},
        "id": "",
        "is_default": False,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
    } }
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/V1/bundle-products/:sku/links/:id"

payload <- "{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}"

encode <- "json"

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

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/bundle-products/:sku/links/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\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/V1/bundle-products/:sku/links/:id') do |req|
  req.body = "{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\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}}/V1/bundle-products/:sku/links/:id";

    let payload = json!({"linkedProduct": json!({
            "can_change_quantity": 0,
            "extension_attributes": json!({}),
            "id": "",
            "is_default": false,
            "option_id": 0,
            "position": 0,
            "price": "",
            "price_type": 0,
            "qty": "",
            "sku": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/bundle-products/:sku/links/:id \
  --header 'content-type: application/json' \
  --data '{
  "linkedProduct": {
    "can_change_quantity": 0,
    "extension_attributes": {},
    "id": "",
    "is_default": false,
    "option_id": 0,
    "position": 0,
    "price": "",
    "price_type": 0,
    "qty": "",
    "sku": ""
  }
}'
echo '{
  "linkedProduct": {
    "can_change_quantity": 0,
    "extension_attributes": {},
    "id": "",
    "is_default": false,
    "option_id": 0,
    "position": 0,
    "price": "",
    "price_type": 0,
    "qty": "",
    "sku": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/bundle-products/:sku/links/:id \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "linkedProduct": {\n    "can_change_quantity": 0,\n    "extension_attributes": {},\n    "id": "",\n    "is_default": false,\n    "option_id": 0,\n    "position": 0,\n    "price": "",\n    "price_type": 0,\n    "qty": "",\n    "sku": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/bundle-products/:sku/links/:id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["linkedProduct": [
    "can_change_quantity": 0,
    "extension_attributes": [],
    "id": "",
    "is_default": false,
    "option_id": 0,
    "position": 0,
    "price": "",
    "price_type": 0,
    "qty": "",
    "sku": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/bundle-products/:sku/links/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/bundle-products/:sku/links/:optionId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/bundle-products/:sku/links/:optionId" {:content-type :json
                                                                                    :form-params {:linkedProduct {:can_change_quantity 0
                                                                                                                  :extension_attributes {}
                                                                                                                  :id ""
                                                                                                                  :is_default false
                                                                                                                  :option_id 0
                                                                                                                  :position 0
                                                                                                                  :price ""
                                                                                                                  :price_type 0
                                                                                                                  :qty ""
                                                                                                                  :sku ""}}})
require "http/client"

url = "{{baseUrl}}/V1/bundle-products/:sku/links/:optionId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\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}}/V1/bundle-products/:sku/links/:optionId"),
    Content = new StringContent("{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\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}}/V1/bundle-products/:sku/links/:optionId");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/bundle-products/:sku/links/:optionId"

	payload := strings.NewReader("{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/bundle-products/:sku/links/:optionId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 235

{
  "linkedProduct": {
    "can_change_quantity": 0,
    "extension_attributes": {},
    "id": "",
    "is_default": false,
    "option_id": 0,
    "position": 0,
    "price": "",
    "price_type": 0,
    "qty": "",
    "sku": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/bundle-products/:sku/links/:optionId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/bundle-products/:sku/links/:optionId"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\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  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/:sku/links/:optionId")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/bundle-products/:sku/links/:optionId")
  .header("content-type", "application/json")
  .body("{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  linkedProduct: {
    can_change_quantity: 0,
    extension_attributes: {},
    id: '',
    is_default: false,
    option_id: 0,
    position: 0,
    price: '',
    price_type: 0,
    qty: '',
    sku: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/bundle-products/:sku/links/:optionId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/bundle-products/:sku/links/:optionId',
  headers: {'content-type': 'application/json'},
  data: {
    linkedProduct: {
      can_change_quantity: 0,
      extension_attributes: {},
      id: '',
      is_default: false,
      option_id: 0,
      position: 0,
      price: '',
      price_type: 0,
      qty: '',
      sku: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/bundle-products/:sku/links/:optionId';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"linkedProduct":{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/bundle-products/:sku/links/:optionId',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "linkedProduct": {\n    "can_change_quantity": 0,\n    "extension_attributes": {},\n    "id": "",\n    "is_default": false,\n    "option_id": 0,\n    "position": 0,\n    "price": "",\n    "price_type": 0,\n    "qty": "",\n    "sku": ""\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  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/:sku/links/:optionId")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/bundle-products/:sku/links/:optionId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  linkedProduct: {
    can_change_quantity: 0,
    extension_attributes: {},
    id: '',
    is_default: false,
    option_id: 0,
    position: 0,
    price: '',
    price_type: 0,
    qty: '',
    sku: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/bundle-products/:sku/links/:optionId',
  headers: {'content-type': 'application/json'},
  body: {
    linkedProduct: {
      can_change_quantity: 0,
      extension_attributes: {},
      id: '',
      is_default: false,
      option_id: 0,
      position: 0,
      price: '',
      price_type: 0,
      qty: '',
      sku: ''
    }
  },
  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}}/V1/bundle-products/:sku/links/:optionId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  linkedProduct: {
    can_change_quantity: 0,
    extension_attributes: {},
    id: '',
    is_default: false,
    option_id: 0,
    position: 0,
    price: '',
    price_type: 0,
    qty: '',
    sku: ''
  }
});

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}}/V1/bundle-products/:sku/links/:optionId',
  headers: {'content-type': 'application/json'},
  data: {
    linkedProduct: {
      can_change_quantity: 0,
      extension_attributes: {},
      id: '',
      is_default: false,
      option_id: 0,
      position: 0,
      price: '',
      price_type: 0,
      qty: '',
      sku: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/bundle-products/:sku/links/:optionId';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"linkedProduct":{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"linkedProduct": @{ @"can_change_quantity": @0, @"extension_attributes": @{  }, @"id": @"", @"is_default": @NO, @"option_id": @0, @"position": @0, @"price": @"", @"price_type": @0, @"qty": @"", @"sku": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/bundle-products/:sku/links/:optionId"]
                                                       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}}/V1/bundle-products/:sku/links/:optionId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/bundle-products/:sku/links/:optionId",
  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([
    'linkedProduct' => [
        'can_change_quantity' => 0,
        'extension_attributes' => [
                
        ],
        'id' => '',
        'is_default' => null,
        'option_id' => 0,
        'position' => 0,
        'price' => '',
        'price_type' => 0,
        'qty' => '',
        'sku' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/bundle-products/:sku/links/:optionId', [
  'body' => '{
  "linkedProduct": {
    "can_change_quantity": 0,
    "extension_attributes": {},
    "id": "",
    "is_default": false,
    "option_id": 0,
    "position": 0,
    "price": "",
    "price_type": 0,
    "qty": "",
    "sku": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/bundle-products/:sku/links/:optionId');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'linkedProduct' => [
    'can_change_quantity' => 0,
    'extension_attributes' => [
        
    ],
    'id' => '',
    'is_default' => null,
    'option_id' => 0,
    'position' => 0,
    'price' => '',
    'price_type' => 0,
    'qty' => '',
    'sku' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'linkedProduct' => [
    'can_change_quantity' => 0,
    'extension_attributes' => [
        
    ],
    'id' => '',
    'is_default' => null,
    'option_id' => 0,
    'position' => 0,
    'price' => '',
    'price_type' => 0,
    'qty' => '',
    'sku' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/bundle-products/:sku/links/:optionId');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/bundle-products/:sku/links/:optionId' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "linkedProduct": {
    "can_change_quantity": 0,
    "extension_attributes": {},
    "id": "",
    "is_default": false,
    "option_id": 0,
    "position": 0,
    "price": "",
    "price_type": 0,
    "qty": "",
    "sku": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/bundle-products/:sku/links/:optionId' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "linkedProduct": {
    "can_change_quantity": 0,
    "extension_attributes": {},
    "id": "",
    "is_default": false,
    "option_id": 0,
    "position": 0,
    "price": "",
    "price_type": 0,
    "qty": "",
    "sku": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/bundle-products/:sku/links/:optionId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/bundle-products/:sku/links/:optionId"

payload = { "linkedProduct": {
        "can_change_quantity": 0,
        "extension_attributes": {},
        "id": "",
        "is_default": False,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/bundle-products/:sku/links/:optionId"

payload <- "{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/bundle-products/:sku/links/:optionId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\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/V1/bundle-products/:sku/links/:optionId') do |req|
  req.body = "{\n  \"linkedProduct\": {\n    \"can_change_quantity\": 0,\n    \"extension_attributes\": {},\n    \"id\": \"\",\n    \"is_default\": false,\n    \"option_id\": 0,\n    \"position\": 0,\n    \"price\": \"\",\n    \"price_type\": 0,\n    \"qty\": \"\",\n    \"sku\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/bundle-products/:sku/links/:optionId";

    let payload = json!({"linkedProduct": json!({
            "can_change_quantity": 0,
            "extension_attributes": json!({}),
            "id": "",
            "is_default": false,
            "option_id": 0,
            "position": 0,
            "price": "",
            "price_type": 0,
            "qty": "",
            "sku": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/bundle-products/:sku/links/:optionId \
  --header 'content-type: application/json' \
  --data '{
  "linkedProduct": {
    "can_change_quantity": 0,
    "extension_attributes": {},
    "id": "",
    "is_default": false,
    "option_id": 0,
    "position": 0,
    "price": "",
    "price_type": 0,
    "qty": "",
    "sku": ""
  }
}'
echo '{
  "linkedProduct": {
    "can_change_quantity": 0,
    "extension_attributes": {},
    "id": "",
    "is_default": false,
    "option_id": 0,
    "position": 0,
    "price": "",
    "price_type": 0,
    "qty": "",
    "sku": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/bundle-products/:sku/links/:optionId \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "linkedProduct": {\n    "can_change_quantity": 0,\n    "extension_attributes": {},\n    "id": "",\n    "is_default": false,\n    "option_id": 0,\n    "position": 0,\n    "price": "",\n    "price_type": 0,\n    "qty": "",\n    "sku": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/bundle-products/:sku/links/:optionId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["linkedProduct": [
    "can_change_quantity": 0,
    "extension_attributes": [],
    "id": "",
    "is_default": false,
    "option_id": 0,
    "position": 0,
    "price": "",
    "price_type": 0,
    "qty": "",
    "sku": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/bundle-products/:sku/links/:optionId")! 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 bundle-products-{sku}-options-{optionId} (GET)
{{baseUrl}}/V1/bundle-products/:sku/options/:optionId
QUERY PARAMS

sku
optionId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId")
require "http/client"

url = "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/bundle-products/:sku/options/:optionId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/bundle-products/:sku/options/:optionId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/bundle-products/:sku/options/:optionId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/bundle-products/:sku/options/:optionId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/bundle-products/:sku/options/:optionId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/bundle-products/:sku/options/:optionId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/bundle-products/:sku/options/:optionId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/bundle-products/:sku/options/:optionId
http GET {{baseUrl}}/V1/bundle-products/:sku/options/:optionId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/bundle-products/:sku/options/:optionId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE bundle-products-{sku}-options-{optionId}
{{baseUrl}}/V1/bundle-products/:sku/options/:optionId
QUERY PARAMS

sku
optionId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId")
require "http/client"

url = "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/bundle-products/:sku/options/:optionId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId"))
    .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}}/V1/bundle-products/:sku/options/:optionId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId")
  .asString();
const 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}}/V1/bundle-products/:sku/options/:optionId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/bundle-products/:sku/options/:optionId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId');

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}}/V1/bundle-products/:sku/options/:optionId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/bundle-products/:sku/options/:optionId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/bundle-products/:sku/options/:optionId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/bundle-products/:sku/options/:optionId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/bundle-products/:sku/options/:optionId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/bundle-products/:sku/options/:optionId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/bundle-products/:sku/options/:optionId
http DELETE {{baseUrl}}/V1/bundle-products/:sku/options/:optionId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/bundle-products/:sku/options/:optionId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE bundle-products-{sku}-options-{optionId}-children-{childSku}
{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku
QUERY PARAMS

sku
optionId
childSku
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku")
require "http/client"

url = "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/bundle-products/:sku/options/:optionId/children/:childSku HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku"))
    .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}}/V1/bundle-products/:sku/options/:optionId/children/:childSku")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku")
  .asString();
const 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}}/V1/bundle-products/:sku/options/:optionId/children/:childSku');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/bundle-products/:sku/options/:optionId/children/:childSku',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku');

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}}/V1/bundle-products/:sku/options/:optionId/children/:childSku'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/bundle-products/:sku/options/:optionId/children/:childSku")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/bundle-products/:sku/options/:optionId/children/:childSku') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku
http DELETE {{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/bundle-products/:sku/options/:optionId/children/:childSku")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET bundle-products-{sku}-options-all
{{baseUrl}}/V1/bundle-products/:sku/options/all
QUERY PARAMS

sku
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/bundle-products/:sku/options/all");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/bundle-products/:sku/options/all")
require "http/client"

url = "{{baseUrl}}/V1/bundle-products/:sku/options/all"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/bundle-products/:sku/options/all"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/bundle-products/:sku/options/all");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/bundle-products/:sku/options/all"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/bundle-products/:sku/options/all HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/bundle-products/:sku/options/all")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/bundle-products/:sku/options/all"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/:sku/options/all")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/bundle-products/:sku/options/all")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/bundle-products/:sku/options/all');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/bundle-products/:sku/options/all'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/bundle-products/:sku/options/all';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/bundle-products/:sku/options/all',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/:sku/options/all")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/bundle-products/:sku/options/all',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/bundle-products/:sku/options/all'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/bundle-products/:sku/options/all');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/bundle-products/:sku/options/all'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/bundle-products/:sku/options/all';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/bundle-products/:sku/options/all"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/bundle-products/:sku/options/all" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/bundle-products/:sku/options/all",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/bundle-products/:sku/options/all');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/bundle-products/:sku/options/all');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/bundle-products/:sku/options/all');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/bundle-products/:sku/options/all' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/bundle-products/:sku/options/all' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/bundle-products/:sku/options/all")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/bundle-products/:sku/options/all"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/bundle-products/:sku/options/all"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/bundle-products/:sku/options/all")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/bundle-products/:sku/options/all') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/bundle-products/:sku/options/all";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/bundle-products/:sku/options/all
http GET {{baseUrl}}/V1/bundle-products/:sku/options/all
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/bundle-products/:sku/options/all
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/bundle-products/:sku/options/all")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT bundle-products-options-{optionId}
{{baseUrl}}/V1/bundle-products/options/:optionId
QUERY PARAMS

optionId
BODY json

{
  "option": {
    "extension_attributes": {},
    "option_id": 0,
    "position": 0,
    "product_links": [
      {
        "can_change_quantity": 0,
        "extension_attributes": {},
        "id": "",
        "is_default": false,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
      }
    ],
    "required": false,
    "sku": "",
    "title": "",
    "type": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/bundle-products/options/:optionId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/bundle-products/options/:optionId" {:content-type :json
                                                                                :form-params {:option {:extension_attributes {}
                                                                                                       :option_id 0
                                                                                                       :position 0
                                                                                                       :product_links [{:can_change_quantity 0
                                                                                                                        :extension_attributes {}
                                                                                                                        :id ""
                                                                                                                        :is_default false
                                                                                                                        :option_id 0
                                                                                                                        :position 0
                                                                                                                        :price ""
                                                                                                                        :price_type 0
                                                                                                                        :qty ""
                                                                                                                        :sku ""}]
                                                                                                       :required false
                                                                                                       :sku ""
                                                                                                       :title ""
                                                                                                       :type ""}}})
require "http/client"

url = "{{baseUrl}}/V1/bundle-products/options/:optionId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\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}}/V1/bundle-products/options/:optionId"),
    Content = new StringContent("{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\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}}/V1/bundle-products/options/:optionId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/bundle-products/options/:optionId"

	payload := strings.NewReader("{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/bundle-products/options/:optionId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 455

{
  "option": {
    "extension_attributes": {},
    "option_id": 0,
    "position": 0,
    "product_links": [
      {
        "can_change_quantity": 0,
        "extension_attributes": {},
        "id": "",
        "is_default": false,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
      }
    ],
    "required": false,
    "sku": "",
    "title": "",
    "type": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/bundle-products/options/:optionId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/bundle-products/options/:optionId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\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  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/options/:optionId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/bundle-products/options/:optionId")
  .header("content-type", "application/json")
  .body("{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  option: {
    extension_attributes: {},
    option_id: 0,
    position: 0,
    product_links: [
      {
        can_change_quantity: 0,
        extension_attributes: {},
        id: '',
        is_default: false,
        option_id: 0,
        position: 0,
        price: '',
        price_type: 0,
        qty: '',
        sku: ''
      }
    ],
    required: false,
    sku: '',
    title: '',
    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}}/V1/bundle-products/options/:optionId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/bundle-products/options/:optionId',
  headers: {'content-type': 'application/json'},
  data: {
    option: {
      extension_attributes: {},
      option_id: 0,
      position: 0,
      product_links: [
        {
          can_change_quantity: 0,
          extension_attributes: {},
          id: '',
          is_default: false,
          option_id: 0,
          position: 0,
          price: '',
          price_type: 0,
          qty: '',
          sku: ''
        }
      ],
      required: false,
      sku: '',
      title: '',
      type: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/bundle-products/options/:optionId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"option":{"extension_attributes":{},"option_id":0,"position":0,"product_links":[{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}],"required":false,"sku":"","title":"","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}}/V1/bundle-products/options/:optionId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "option": {\n    "extension_attributes": {},\n    "option_id": 0,\n    "position": 0,\n    "product_links": [\n      {\n        "can_change_quantity": 0,\n        "extension_attributes": {},\n        "id": "",\n        "is_default": false,\n        "option_id": 0,\n        "position": 0,\n        "price": "",\n        "price_type": 0,\n        "qty": "",\n        "sku": ""\n      }\n    ],\n    "required": false,\n    "sku": "",\n    "title": "",\n    "type": ""\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  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/options/:optionId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/bundle-products/options/:optionId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  option: {
    extension_attributes: {},
    option_id: 0,
    position: 0,
    product_links: [
      {
        can_change_quantity: 0,
        extension_attributes: {},
        id: '',
        is_default: false,
        option_id: 0,
        position: 0,
        price: '',
        price_type: 0,
        qty: '',
        sku: ''
      }
    ],
    required: false,
    sku: '',
    title: '',
    type: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/bundle-products/options/:optionId',
  headers: {'content-type': 'application/json'},
  body: {
    option: {
      extension_attributes: {},
      option_id: 0,
      position: 0,
      product_links: [
        {
          can_change_quantity: 0,
          extension_attributes: {},
          id: '',
          is_default: false,
          option_id: 0,
          position: 0,
          price: '',
          price_type: 0,
          qty: '',
          sku: ''
        }
      ],
      required: false,
      sku: '',
      title: '',
      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}}/V1/bundle-products/options/:optionId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  option: {
    extension_attributes: {},
    option_id: 0,
    position: 0,
    product_links: [
      {
        can_change_quantity: 0,
        extension_attributes: {},
        id: '',
        is_default: false,
        option_id: 0,
        position: 0,
        price: '',
        price_type: 0,
        qty: '',
        sku: ''
      }
    ],
    required: false,
    sku: '',
    title: '',
    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}}/V1/bundle-products/options/:optionId',
  headers: {'content-type': 'application/json'},
  data: {
    option: {
      extension_attributes: {},
      option_id: 0,
      position: 0,
      product_links: [
        {
          can_change_quantity: 0,
          extension_attributes: {},
          id: '',
          is_default: false,
          option_id: 0,
          position: 0,
          price: '',
          price_type: 0,
          qty: '',
          sku: ''
        }
      ],
      required: false,
      sku: '',
      title: '',
      type: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/bundle-products/options/:optionId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"option":{"extension_attributes":{},"option_id":0,"position":0,"product_links":[{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}],"required":false,"sku":"","title":"","type":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"option": @{ @"extension_attributes": @{  }, @"option_id": @0, @"position": @0, @"product_links": @[ @{ @"can_change_quantity": @0, @"extension_attributes": @{  }, @"id": @"", @"is_default": @NO, @"option_id": @0, @"position": @0, @"price": @"", @"price_type": @0, @"qty": @"", @"sku": @"" } ], @"required": @NO, @"sku": @"", @"title": @"", @"type": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/bundle-products/options/:optionId"]
                                                       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}}/V1/bundle-products/options/:optionId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/bundle-products/options/:optionId",
  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([
    'option' => [
        'extension_attributes' => [
                
        ],
        'option_id' => 0,
        'position' => 0,
        'product_links' => [
                [
                                'can_change_quantity' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => '',
                                'is_default' => null,
                                'option_id' => 0,
                                'position' => 0,
                                'price' => '',
                                'price_type' => 0,
                                'qty' => '',
                                'sku' => ''
                ]
        ],
        'required' => null,
        'sku' => '',
        'title' => '',
        'type' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/bundle-products/options/:optionId', [
  'body' => '{
  "option": {
    "extension_attributes": {},
    "option_id": 0,
    "position": 0,
    "product_links": [
      {
        "can_change_quantity": 0,
        "extension_attributes": {},
        "id": "",
        "is_default": false,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
      }
    ],
    "required": false,
    "sku": "",
    "title": "",
    "type": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/bundle-products/options/:optionId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'option' => [
    'extension_attributes' => [
        
    ],
    'option_id' => 0,
    'position' => 0,
    'product_links' => [
        [
                'can_change_quantity' => 0,
                'extension_attributes' => [
                                
                ],
                'id' => '',
                'is_default' => null,
                'option_id' => 0,
                'position' => 0,
                'price' => '',
                'price_type' => 0,
                'qty' => '',
                'sku' => ''
        ]
    ],
    'required' => null,
    'sku' => '',
    'title' => '',
    'type' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'option' => [
    'extension_attributes' => [
        
    ],
    'option_id' => 0,
    'position' => 0,
    'product_links' => [
        [
                'can_change_quantity' => 0,
                'extension_attributes' => [
                                
                ],
                'id' => '',
                'is_default' => null,
                'option_id' => 0,
                'position' => 0,
                'price' => '',
                'price_type' => 0,
                'qty' => '',
                'sku' => ''
        ]
    ],
    'required' => null,
    'sku' => '',
    'title' => '',
    'type' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/bundle-products/options/:optionId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/bundle-products/options/:optionId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "option": {
    "extension_attributes": {},
    "option_id": 0,
    "position": 0,
    "product_links": [
      {
        "can_change_quantity": 0,
        "extension_attributes": {},
        "id": "",
        "is_default": false,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
      }
    ],
    "required": false,
    "sku": "",
    "title": "",
    "type": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/bundle-products/options/:optionId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "option": {
    "extension_attributes": {},
    "option_id": 0,
    "position": 0,
    "product_links": [
      {
        "can_change_quantity": 0,
        "extension_attributes": {},
        "id": "",
        "is_default": false,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
      }
    ],
    "required": false,
    "sku": "",
    "title": "",
    "type": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/bundle-products/options/:optionId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/bundle-products/options/:optionId"

payload = { "option": {
        "extension_attributes": {},
        "option_id": 0,
        "position": 0,
        "product_links": [
            {
                "can_change_quantity": 0,
                "extension_attributes": {},
                "id": "",
                "is_default": False,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
            }
        ],
        "required": False,
        "sku": "",
        "title": "",
        "type": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/bundle-products/options/:optionId"

payload <- "{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/bundle-products/options/:optionId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\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/V1/bundle-products/options/:optionId') do |req|
  req.body = "{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\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}}/V1/bundle-products/options/:optionId";

    let payload = json!({"option": json!({
            "extension_attributes": json!({}),
            "option_id": 0,
            "position": 0,
            "product_links": (
                json!({
                    "can_change_quantity": 0,
                    "extension_attributes": json!({}),
                    "id": "",
                    "is_default": false,
                    "option_id": 0,
                    "position": 0,
                    "price": "",
                    "price_type": 0,
                    "qty": "",
                    "sku": ""
                })
            ),
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/bundle-products/options/:optionId \
  --header 'content-type: application/json' \
  --data '{
  "option": {
    "extension_attributes": {},
    "option_id": 0,
    "position": 0,
    "product_links": [
      {
        "can_change_quantity": 0,
        "extension_attributes": {},
        "id": "",
        "is_default": false,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
      }
    ],
    "required": false,
    "sku": "",
    "title": "",
    "type": ""
  }
}'
echo '{
  "option": {
    "extension_attributes": {},
    "option_id": 0,
    "position": 0,
    "product_links": [
      {
        "can_change_quantity": 0,
        "extension_attributes": {},
        "id": "",
        "is_default": false,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
      }
    ],
    "required": false,
    "sku": "",
    "title": "",
    "type": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/bundle-products/options/:optionId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "option": {\n    "extension_attributes": {},\n    "option_id": 0,\n    "position": 0,\n    "product_links": [\n      {\n        "can_change_quantity": 0,\n        "extension_attributes": {},\n        "id": "",\n        "is_default": false,\n        "option_id": 0,\n        "position": 0,\n        "price": "",\n        "price_type": 0,\n        "qty": "",\n        "sku": ""\n      }\n    ],\n    "required": false,\n    "sku": "",\n    "title": "",\n    "type": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/bundle-products/options/:optionId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["option": [
    "extension_attributes": [],
    "option_id": 0,
    "position": 0,
    "product_links": [
      [
        "can_change_quantity": 0,
        "extension_attributes": [],
        "id": "",
        "is_default": false,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
      ]
    ],
    "required": false,
    "sku": "",
    "title": "",
    "type": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/bundle-products/options/:optionId")! 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 bundle-products-options-add
{{baseUrl}}/V1/bundle-products/options/add
BODY json

{
  "option": {
    "extension_attributes": {},
    "option_id": 0,
    "position": 0,
    "product_links": [
      {
        "can_change_quantity": 0,
        "extension_attributes": {},
        "id": "",
        "is_default": false,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
      }
    ],
    "required": false,
    "sku": "",
    "title": "",
    "type": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/bundle-products/options/add");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/bundle-products/options/add" {:content-type :json
                                                                           :form-params {:option {:extension_attributes {}
                                                                                                  :option_id 0
                                                                                                  :position 0
                                                                                                  :product_links [{:can_change_quantity 0
                                                                                                                   :extension_attributes {}
                                                                                                                   :id ""
                                                                                                                   :is_default false
                                                                                                                   :option_id 0
                                                                                                                   :position 0
                                                                                                                   :price ""
                                                                                                                   :price_type 0
                                                                                                                   :qty ""
                                                                                                                   :sku ""}]
                                                                                                  :required false
                                                                                                  :sku ""
                                                                                                  :title ""
                                                                                                  :type ""}}})
require "http/client"

url = "{{baseUrl}}/V1/bundle-products/options/add"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\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}}/V1/bundle-products/options/add"),
    Content = new StringContent("{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\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}}/V1/bundle-products/options/add");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/bundle-products/options/add"

	payload := strings.NewReader("{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/bundle-products/options/add HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 455

{
  "option": {
    "extension_attributes": {},
    "option_id": 0,
    "position": 0,
    "product_links": [
      {
        "can_change_quantity": 0,
        "extension_attributes": {},
        "id": "",
        "is_default": false,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
      }
    ],
    "required": false,
    "sku": "",
    "title": "",
    "type": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/bundle-products/options/add")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/bundle-products/options/add"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\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  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/options/add")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/bundle-products/options/add")
  .header("content-type", "application/json")
  .body("{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  option: {
    extension_attributes: {},
    option_id: 0,
    position: 0,
    product_links: [
      {
        can_change_quantity: 0,
        extension_attributes: {},
        id: '',
        is_default: false,
        option_id: 0,
        position: 0,
        price: '',
        price_type: 0,
        qty: '',
        sku: ''
      }
    ],
    required: false,
    sku: '',
    title: '',
    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}}/V1/bundle-products/options/add');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/bundle-products/options/add',
  headers: {'content-type': 'application/json'},
  data: {
    option: {
      extension_attributes: {},
      option_id: 0,
      position: 0,
      product_links: [
        {
          can_change_quantity: 0,
          extension_attributes: {},
          id: '',
          is_default: false,
          option_id: 0,
          position: 0,
          price: '',
          price_type: 0,
          qty: '',
          sku: ''
        }
      ],
      required: false,
      sku: '',
      title: '',
      type: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/bundle-products/options/add';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"option":{"extension_attributes":{},"option_id":0,"position":0,"product_links":[{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}],"required":false,"sku":"","title":"","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}}/V1/bundle-products/options/add',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "option": {\n    "extension_attributes": {},\n    "option_id": 0,\n    "position": 0,\n    "product_links": [\n      {\n        "can_change_quantity": 0,\n        "extension_attributes": {},\n        "id": "",\n        "is_default": false,\n        "option_id": 0,\n        "position": 0,\n        "price": "",\n        "price_type": 0,\n        "qty": "",\n        "sku": ""\n      }\n    ],\n    "required": false,\n    "sku": "",\n    "title": "",\n    "type": ""\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  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/options/add")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/bundle-products/options/add',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  option: {
    extension_attributes: {},
    option_id: 0,
    position: 0,
    product_links: [
      {
        can_change_quantity: 0,
        extension_attributes: {},
        id: '',
        is_default: false,
        option_id: 0,
        position: 0,
        price: '',
        price_type: 0,
        qty: '',
        sku: ''
      }
    ],
    required: false,
    sku: '',
    title: '',
    type: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/bundle-products/options/add',
  headers: {'content-type': 'application/json'},
  body: {
    option: {
      extension_attributes: {},
      option_id: 0,
      position: 0,
      product_links: [
        {
          can_change_quantity: 0,
          extension_attributes: {},
          id: '',
          is_default: false,
          option_id: 0,
          position: 0,
          price: '',
          price_type: 0,
          qty: '',
          sku: ''
        }
      ],
      required: false,
      sku: '',
      title: '',
      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}}/V1/bundle-products/options/add');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  option: {
    extension_attributes: {},
    option_id: 0,
    position: 0,
    product_links: [
      {
        can_change_quantity: 0,
        extension_attributes: {},
        id: '',
        is_default: false,
        option_id: 0,
        position: 0,
        price: '',
        price_type: 0,
        qty: '',
        sku: ''
      }
    ],
    required: false,
    sku: '',
    title: '',
    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}}/V1/bundle-products/options/add',
  headers: {'content-type': 'application/json'},
  data: {
    option: {
      extension_attributes: {},
      option_id: 0,
      position: 0,
      product_links: [
        {
          can_change_quantity: 0,
          extension_attributes: {},
          id: '',
          is_default: false,
          option_id: 0,
          position: 0,
          price: '',
          price_type: 0,
          qty: '',
          sku: ''
        }
      ],
      required: false,
      sku: '',
      title: '',
      type: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/bundle-products/options/add';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"option":{"extension_attributes":{},"option_id":0,"position":0,"product_links":[{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}],"required":false,"sku":"","title":"","type":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"option": @{ @"extension_attributes": @{  }, @"option_id": @0, @"position": @0, @"product_links": @[ @{ @"can_change_quantity": @0, @"extension_attributes": @{  }, @"id": @"", @"is_default": @NO, @"option_id": @0, @"position": @0, @"price": @"", @"price_type": @0, @"qty": @"", @"sku": @"" } ], @"required": @NO, @"sku": @"", @"title": @"", @"type": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/bundle-products/options/add"]
                                                       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}}/V1/bundle-products/options/add" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/bundle-products/options/add",
  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([
    'option' => [
        'extension_attributes' => [
                
        ],
        'option_id' => 0,
        'position' => 0,
        'product_links' => [
                [
                                'can_change_quantity' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => '',
                                'is_default' => null,
                                'option_id' => 0,
                                'position' => 0,
                                'price' => '',
                                'price_type' => 0,
                                'qty' => '',
                                'sku' => ''
                ]
        ],
        'required' => null,
        'sku' => '',
        'title' => '',
        'type' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/bundle-products/options/add', [
  'body' => '{
  "option": {
    "extension_attributes": {},
    "option_id": 0,
    "position": 0,
    "product_links": [
      {
        "can_change_quantity": 0,
        "extension_attributes": {},
        "id": "",
        "is_default": false,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
      }
    ],
    "required": false,
    "sku": "",
    "title": "",
    "type": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/bundle-products/options/add');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'option' => [
    'extension_attributes' => [
        
    ],
    'option_id' => 0,
    'position' => 0,
    'product_links' => [
        [
                'can_change_quantity' => 0,
                'extension_attributes' => [
                                
                ],
                'id' => '',
                'is_default' => null,
                'option_id' => 0,
                'position' => 0,
                'price' => '',
                'price_type' => 0,
                'qty' => '',
                'sku' => ''
        ]
    ],
    'required' => null,
    'sku' => '',
    'title' => '',
    'type' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'option' => [
    'extension_attributes' => [
        
    ],
    'option_id' => 0,
    'position' => 0,
    'product_links' => [
        [
                'can_change_quantity' => 0,
                'extension_attributes' => [
                                
                ],
                'id' => '',
                'is_default' => null,
                'option_id' => 0,
                'position' => 0,
                'price' => '',
                'price_type' => 0,
                'qty' => '',
                'sku' => ''
        ]
    ],
    'required' => null,
    'sku' => '',
    'title' => '',
    'type' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/bundle-products/options/add');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/bundle-products/options/add' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "option": {
    "extension_attributes": {},
    "option_id": 0,
    "position": 0,
    "product_links": [
      {
        "can_change_quantity": 0,
        "extension_attributes": {},
        "id": "",
        "is_default": false,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
      }
    ],
    "required": false,
    "sku": "",
    "title": "",
    "type": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/bundle-products/options/add' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "option": {
    "extension_attributes": {},
    "option_id": 0,
    "position": 0,
    "product_links": [
      {
        "can_change_quantity": 0,
        "extension_attributes": {},
        "id": "",
        "is_default": false,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
      }
    ],
    "required": false,
    "sku": "",
    "title": "",
    "type": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/bundle-products/options/add", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/bundle-products/options/add"

payload = { "option": {
        "extension_attributes": {},
        "option_id": 0,
        "position": 0,
        "product_links": [
            {
                "can_change_quantity": 0,
                "extension_attributes": {},
                "id": "",
                "is_default": False,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
            }
        ],
        "required": False,
        "sku": "",
        "title": "",
        "type": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/bundle-products/options/add"

payload <- "{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/bundle-products/options/add")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\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/V1/bundle-products/options/add') do |req|
  req.body = "{\n  \"option\": {\n    \"extension_attributes\": {},\n    \"option_id\": 0,\n    \"position\": 0,\n    \"product_links\": [\n      {\n        \"can_change_quantity\": 0,\n        \"extension_attributes\": {},\n        \"id\": \"\",\n        \"is_default\": false,\n        \"option_id\": 0,\n        \"position\": 0,\n        \"price\": \"\",\n        \"price_type\": 0,\n        \"qty\": \"\",\n        \"sku\": \"\"\n      }\n    ],\n    \"required\": false,\n    \"sku\": \"\",\n    \"title\": \"\",\n    \"type\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/bundle-products/options/add";

    let payload = json!({"option": json!({
            "extension_attributes": json!({}),
            "option_id": 0,
            "position": 0,
            "product_links": (
                json!({
                    "can_change_quantity": 0,
                    "extension_attributes": json!({}),
                    "id": "",
                    "is_default": false,
                    "option_id": 0,
                    "position": 0,
                    "price": "",
                    "price_type": 0,
                    "qty": "",
                    "sku": ""
                })
            ),
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/bundle-products/options/add \
  --header 'content-type: application/json' \
  --data '{
  "option": {
    "extension_attributes": {},
    "option_id": 0,
    "position": 0,
    "product_links": [
      {
        "can_change_quantity": 0,
        "extension_attributes": {},
        "id": "",
        "is_default": false,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
      }
    ],
    "required": false,
    "sku": "",
    "title": "",
    "type": ""
  }
}'
echo '{
  "option": {
    "extension_attributes": {},
    "option_id": 0,
    "position": 0,
    "product_links": [
      {
        "can_change_quantity": 0,
        "extension_attributes": {},
        "id": "",
        "is_default": false,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
      }
    ],
    "required": false,
    "sku": "",
    "title": "",
    "type": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/bundle-products/options/add \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "option": {\n    "extension_attributes": {},\n    "option_id": 0,\n    "position": 0,\n    "product_links": [\n      {\n        "can_change_quantity": 0,\n        "extension_attributes": {},\n        "id": "",\n        "is_default": false,\n        "option_id": 0,\n        "position": 0,\n        "price": "",\n        "price_type": 0,\n        "qty": "",\n        "sku": ""\n      }\n    ],\n    "required": false,\n    "sku": "",\n    "title": "",\n    "type": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/bundle-products/options/add
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["option": [
    "extension_attributes": [],
    "option_id": 0,
    "position": 0,
    "product_links": [
      [
        "can_change_quantity": 0,
        "extension_attributes": [],
        "id": "",
        "is_default": false,
        "option_id": 0,
        "position": 0,
        "price": "",
        "price_type": 0,
        "qty": "",
        "sku": ""
      ]
    ],
    "required": false,
    "sku": "",
    "title": "",
    "type": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/bundle-products/options/add")! 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 bundle-products-options-types
{{baseUrl}}/V1/bundle-products/options/types
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/bundle-products/options/types");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/bundle-products/options/types")
require "http/client"

url = "{{baseUrl}}/V1/bundle-products/options/types"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/bundle-products/options/types"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/bundle-products/options/types");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/bundle-products/options/types"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/bundle-products/options/types HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/bundle-products/options/types")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/bundle-products/options/types"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/options/types")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/bundle-products/options/types")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/bundle-products/options/types');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/bundle-products/options/types'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/bundle-products/options/types';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/bundle-products/options/types',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/bundle-products/options/types")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/bundle-products/options/types',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/bundle-products/options/types'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/bundle-products/options/types');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/bundle-products/options/types'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/bundle-products/options/types';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/bundle-products/options/types"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/bundle-products/options/types" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/bundle-products/options/types",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/bundle-products/options/types');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/bundle-products/options/types');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/bundle-products/options/types');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/bundle-products/options/types' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/bundle-products/options/types' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/bundle-products/options/types")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/bundle-products/options/types"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/bundle-products/options/types"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/bundle-products/options/types")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/bundle-products/options/types') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/bundle-products/options/types";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/bundle-products/options/types
http GET {{baseUrl}}/V1/bundle-products/options/types
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/bundle-products/options/types
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/bundle-products/options/types")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-
{{baseUrl}}/V1/carts/
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/")
require "http/client"

url = "{{baseUrl}}/V1/carts/"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/ HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/"))
    .method("POST", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/carts/');

xhr.send(data);
import axios from 'axios';

const options = {method: 'POST', url: '{{baseUrl}}/V1/carts/'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'POST', url: '{{baseUrl}}/V1/carts/'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/carts/');

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}}/V1/carts/'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/V1/carts/")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/V1/carts/') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/
http POST {{baseUrl}}/V1/carts/
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/V1/carts/
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT carts-{cartId} (PUT)
{{baseUrl}}/V1/carts/:cartId
QUERY PARAMS

cartId
BODY json

{
  "customerId": 0,
  "storeId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"customerId\": 0,\n  \"storeId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/carts/:cartId" {:content-type :json
                                                            :form-params {:customerId 0
                                                                          :storeId 0}})
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"customerId\": 0,\n  \"storeId\": 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}}/V1/carts/:cartId"),
    Content = new StringContent("{\n  \"customerId\": 0,\n  \"storeId\": 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}}/V1/carts/:cartId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"customerId\": 0,\n  \"storeId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId"

	payload := strings.NewReader("{\n  \"customerId\": 0,\n  \"storeId\": 0\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/carts/:cartId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 37

{
  "customerId": 0,
  "storeId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/carts/:cartId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"customerId\": 0,\n  \"storeId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"customerId\": 0,\n  \"storeId\": 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  \"customerId\": 0,\n  \"storeId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/carts/:cartId")
  .header("content-type", "application/json")
  .body("{\n  \"customerId\": 0,\n  \"storeId\": 0\n}")
  .asString();
const data = JSON.stringify({
  customerId: 0,
  storeId: 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}}/V1/carts/:cartId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/:cartId',
  headers: {'content-type': 'application/json'},
  data: {customerId: 0, storeId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"customerId":0,"storeId":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}}/V1/carts/:cartId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "customerId": 0,\n  "storeId": 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  \"customerId\": 0,\n  \"storeId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({customerId: 0, storeId: 0}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/:cartId',
  headers: {'content-type': 'application/json'},
  body: {customerId: 0, storeId: 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}}/V1/carts/:cartId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  customerId: 0,
  storeId: 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}}/V1/carts/:cartId',
  headers: {'content-type': 'application/json'},
  data: {customerId: 0, storeId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"customerId":0,"storeId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"customerId": @0,
                              @"storeId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId"]
                                                       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}}/V1/carts/:cartId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"customerId\": 0,\n  \"storeId\": 0\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId",
  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([
    'customerId' => 0,
    'storeId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/carts/:cartId', [
  'body' => '{
  "customerId": 0,
  "storeId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'customerId' => 0,
  'storeId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'customerId' => 0,
  'storeId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/:cartId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "customerId": 0,
  "storeId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "customerId": 0,
  "storeId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"customerId\": 0,\n  \"storeId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/carts/:cartId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId"

payload = {
    "customerId": 0,
    "storeId": 0
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId"

payload <- "{\n  \"customerId\": 0,\n  \"storeId\": 0\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"customerId\": 0,\n  \"storeId\": 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/V1/carts/:cartId') do |req|
  req.body = "{\n  \"customerId\": 0,\n  \"storeId\": 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}}/V1/carts/:cartId";

    let payload = json!({
        "customerId": 0,
        "storeId": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/carts/:cartId \
  --header 'content-type: application/json' \
  --data '{
  "customerId": 0,
  "storeId": 0
}'
echo '{
  "customerId": 0,
  "storeId": 0
}' |  \
  http PUT {{baseUrl}}/V1/carts/:cartId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "customerId": 0,\n  "storeId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "customerId": 0,
  "storeId": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId")! 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 carts-{cartId}
{{baseUrl}}/V1/carts/:cartId
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/:cartId")
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/:cartId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/:cartId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/:cartId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/:cartId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/:cartId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/:cartId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/:cartId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/:cartId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/:cartId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/:cartId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/:cartId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/:cartId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/:cartId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/:cartId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/:cartId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/:cartId
http GET {{baseUrl}}/V1/carts/:cartId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-{cartId}-billing-address (POST)
{{baseUrl}}/V1/carts/:cartId/billing-address
QUERY PARAMS

cartId
BODY json

{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/billing-address");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/:cartId/billing-address" {:content-type :json
                                                                             :form-params {:address {:city ""
                                                                                                     :company ""
                                                                                                     :country_id ""
                                                                                                     :custom_attributes [{:attribute_code ""
                                                                                                                          :value ""}]
                                                                                                     :customer_address_id 0
                                                                                                     :customer_id 0
                                                                                                     :email ""
                                                                                                     :extension_attributes {:checkout_fields [{}]
                                                                                                                            :gift_registry_id 0}
                                                                                                     :fax ""
                                                                                                     :firstname ""
                                                                                                     :id 0
                                                                                                     :lastname ""
                                                                                                     :middlename ""
                                                                                                     :postcode ""
                                                                                                     :prefix ""
                                                                                                     :region ""
                                                                                                     :region_code ""
                                                                                                     :region_id 0
                                                                                                     :same_as_billing 0
                                                                                                     :save_in_address_book 0
                                                                                                     :street []
                                                                                                     :suffix ""
                                                                                                     :telephone ""
                                                                                                     :vat_id ""}
                                                                                           :useForShipping false}})
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/billing-address"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": 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}}/V1/carts/:cartId/billing-address"),
    Content = new StringContent("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": 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}}/V1/carts/:cartId/billing-address");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/billing-address"

	payload := strings.NewReader("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/:cartId/billing-address HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 708

{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/:cartId/billing-address")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/billing-address"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": 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\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/billing-address")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/:cartId/billing-address")
  .header("content-type", "application/json")
  .body("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}")
  .asString();
const data = JSON.stringify({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  useForShipping: 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}}/V1/carts/:cartId/billing-address');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/:cartId/billing-address',
  headers: {'content-type': 'application/json'},
  data: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    useForShipping: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/billing-address';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"useForShipping":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}}/V1/carts/:cartId/billing-address',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "useForShipping": 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\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/billing-address")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/billing-address',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  useForShipping: false
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/:cartId/billing-address',
  headers: {'content-type': 'application/json'},
  body: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    useForShipping: 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}}/V1/carts/:cartId/billing-address');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  useForShipping: 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}}/V1/carts/:cartId/billing-address',
  headers: {'content-type': 'application/json'},
  data: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    useForShipping: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/billing-address';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"useForShipping":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" },
                              @"useForShipping": @NO };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/billing-address"]
                                                       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}}/V1/carts/:cartId/billing-address" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/billing-address",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'useForShipping' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/:cartId/billing-address', [
  'body' => '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/billing-address');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'useForShipping' => null
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'useForShipping' => null
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/:cartId/billing-address');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/billing-address' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/billing-address' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/:cartId/billing-address", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/billing-address"

payload = {
    "address": {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "extension_attributes": {
            "checkout_fields": [{}],
            "gift_registry_id": 0
        },
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "same_as_billing": 0,
        "save_in_address_book": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
    },
    "useForShipping": False
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/billing-address"

payload <- "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/billing-address")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": 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/V1/carts/:cartId/billing-address') do |req|
  req.body = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/billing-address";

    let payload = json!({
        "address": json!({
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": json!({
                "checkout_fields": (json!({})),
                "gift_registry_id": 0
            }),
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": (),
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        }),
        "useForShipping": false
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/:cartId/billing-address \
  --header 'content-type: application/json' \
  --data '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}'
echo '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}' |  \
  http POST {{baseUrl}}/V1/carts/:cartId/billing-address \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "address": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "useForShipping": false\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/billing-address
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "address": [
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": [
      "checkout_fields": [[]],
      "gift_registry_id": 0
    ],
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  ],
  "useForShipping": false
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/billing-address")! 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 carts-{cartId}-billing-address
{{baseUrl}}/V1/carts/:cartId/billing-address
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/billing-address");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/:cartId/billing-address")
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/billing-address"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/:cartId/billing-address"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/:cartId/billing-address");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/billing-address"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/:cartId/billing-address HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/:cartId/billing-address")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/billing-address"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/billing-address")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/:cartId/billing-address")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/:cartId/billing-address');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/billing-address'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/billing-address';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/billing-address',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/billing-address")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/billing-address',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/billing-address'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/:cartId/billing-address');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/billing-address'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/billing-address';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/billing-address"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/:cartId/billing-address" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/billing-address",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/:cartId/billing-address');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/billing-address');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/:cartId/billing-address');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/billing-address' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/billing-address' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/:cartId/billing-address")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/billing-address"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/billing-address"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/billing-address")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/:cartId/billing-address') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/billing-address";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/:cartId/billing-address
http GET {{baseUrl}}/V1/carts/:cartId/billing-address
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/billing-address
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/billing-address")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET carts-{cartId}-coupons (GET)
{{baseUrl}}/V1/carts/:cartId/coupons
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/coupons");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/:cartId/coupons")
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/coupons"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/:cartId/coupons"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/:cartId/coupons");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/coupons"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/:cartId/coupons HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/:cartId/coupons")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/coupons"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/coupons")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/:cartId/coupons")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/:cartId/coupons');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/:cartId/coupons'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/coupons';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/coupons',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/coupons")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/coupons',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/:cartId/coupons'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/:cartId/coupons');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/:cartId/coupons'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/coupons';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/coupons"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/:cartId/coupons" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/coupons",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/:cartId/coupons');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/coupons');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/:cartId/coupons');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/coupons' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/coupons' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/:cartId/coupons")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/coupons"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/coupons"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/coupons")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/:cartId/coupons') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/coupons";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/:cartId/coupons
http GET {{baseUrl}}/V1/carts/:cartId/coupons
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/coupons
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/coupons")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE carts-{cartId}-coupons
{{baseUrl}}/V1/carts/:cartId/coupons
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/coupons");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/carts/:cartId/coupons")
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/coupons"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/:cartId/coupons"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/:cartId/coupons");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/coupons"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/carts/:cartId/coupons HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/carts/:cartId/coupons")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/coupons"))
    .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}}/V1/carts/:cartId/coupons")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/carts/:cartId/coupons")
  .asString();
const 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}}/V1/carts/:cartId/coupons');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/carts/:cartId/coupons'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/coupons';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/coupons',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/coupons")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/coupons',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/carts/:cartId/coupons'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/carts/:cartId/coupons');

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}}/V1/carts/:cartId/coupons'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/coupons';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/coupons"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/:cartId/coupons" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/coupons",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/carts/:cartId/coupons');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/coupons');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/:cartId/coupons');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/coupons' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/coupons' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/carts/:cartId/coupons")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/coupons"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/coupons"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/coupons")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/carts/:cartId/coupons') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/coupons";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/carts/:cartId/coupons
http DELETE {{baseUrl}}/V1/carts/:cartId/coupons
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/coupons
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/coupons")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT carts-{cartId}-coupons-{couponCode}
{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode
QUERY PARAMS

cartId
couponCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode")
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode"

response = HTTP::Client.put url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode");
var request = new RestRequest("", Method.Put);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode"

	req, _ := http.NewRequest("PUT", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/carts/:cartId/coupons/:couponCode HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode"))
    .method("PUT", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode")
  .put(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode';
const options = {method: 'PUT'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode',
  method: 'PUT',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode")
  .put(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/coupons/:couponCode',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode');

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}}/V1/carts/:cartId/coupons/:couponCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode';
const options = {method: 'PUT'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode" in

Client.call `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode');
$request->setMethod(HTTP_METH_PUT);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode');
$request->setRequestMethod('PUT');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode' -Method PUT 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode' -Method PUT 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("PUT", "/baseUrl/V1/carts/:cartId/coupons/:couponCode")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode"

response = requests.put(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode"

response <- VERB("PUT", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/V1/carts/:cartId/coupons/:couponCode') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/carts/:cartId/coupons/:couponCode
http PUT {{baseUrl}}/V1/carts/:cartId/coupons/:couponCode
wget --quiet \
  --method PUT \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/coupons/:couponCode
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/coupons/:couponCode")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-{cartId}-estimate-shipping-methods
{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods
QUERY PARAMS

cartId
BODY json

{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods" {:content-type :json
                                                                                       :form-params {:address {:city ""
                                                                                                               :company ""
                                                                                                               :country_id ""
                                                                                                               :custom_attributes [{:attribute_code ""
                                                                                                                                    :value ""}]
                                                                                                               :customer_address_id 0
                                                                                                               :customer_id 0
                                                                                                               :email ""
                                                                                                               :extension_attributes {:checkout_fields [{}]
                                                                                                                                      :gift_registry_id 0}
                                                                                                               :fax ""
                                                                                                               :firstname ""
                                                                                                               :id 0
                                                                                                               :lastname ""
                                                                                                               :middlename ""
                                                                                                               :postcode ""
                                                                                                               :prefix ""
                                                                                                               :region ""
                                                                                                               :region_code ""
                                                                                                               :region_id 0
                                                                                                               :same_as_billing 0
                                                                                                               :save_in_address_book 0
                                                                                                               :street []
                                                                                                               :suffix ""
                                                                                                               :telephone ""
                                                                                                               :vat_id ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\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}}/V1/carts/:cartId/estimate-shipping-methods"),
    Content = new StringContent("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\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}}/V1/carts/:cartId/estimate-shipping-methods");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods"

	payload := strings.NewReader("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/:cartId/estimate-shipping-methods HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 681

{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\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\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods")
  .header("content-type", "application/json")
  .body("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_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}}/V1/carts/:cartId/estimate-shipping-methods');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  data: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_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}}/V1/carts/:cartId/estimate-shipping-methods',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\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\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/estimate-shipping-methods',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  body: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_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}}/V1/carts/:cartId/estimate-shipping-methods');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_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}}/V1/carts/:cartId/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  data: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods"]
                                                       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}}/V1/carts/:cartId/estimate-shipping-methods" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods', [
  'body' => '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/:cartId/estimate-shipping-methods", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods"

payload = { "address": {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "extension_attributes": {
            "checkout_fields": [{}],
            "gift_registry_id": 0
        },
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "same_as_billing": 0,
        "save_in_address_book": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods"

payload <- "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\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/V1/carts/:cartId/estimate-shipping-methods') do |req|
  req.body = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods";

    let payload = json!({"address": json!({
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": json!({
                "checkout_fields": (json!({})),
                "gift_registry_id": 0
            }),
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": (),
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods \
  --header 'content-type: application/json' \
  --data '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}'
echo '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "address": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["address": [
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": [
      "checkout_fields": [[]],
      "gift_registry_id": 0
    ],
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods")! 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 carts-{cartId}-estimate-shipping-methods-by-address-id
{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id
QUERY PARAMS

cartId
BODY json

{
  "addressId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"addressId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id" {:content-type :json
                                                                                                     :form-params {:addressId 0}})
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"addressId\": 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}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id"),
    Content = new StringContent("{\n  \"addressId\": 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}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"addressId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id"

	payload := strings.NewReader("{\n  \"addressId\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/:cartId/estimate-shipping-methods-by-address-id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 20

{
  "addressId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"addressId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"addressId\": 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  \"addressId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id")
  .header("content-type", "application/json")
  .body("{\n  \"addressId\": 0\n}")
  .asString();
const data = JSON.stringify({
  addressId: 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}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id',
  headers: {'content-type': 'application/json'},
  data: {addressId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressId":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}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "addressId": 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  \"addressId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/estimate-shipping-methods-by-address-id',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({addressId: 0}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id',
  headers: {'content-type': 'application/json'},
  body: {addressId: 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}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  addressId: 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}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id',
  headers: {'content-type': 'application/json'},
  data: {addressId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"addressId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"addressId\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'addressId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id', [
  'body' => '{
  "addressId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'addressId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'addressId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"addressId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/:cartId/estimate-shipping-methods-by-address-id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id"

payload = { "addressId": 0 }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id"

payload <- "{\n  \"addressId\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"addressId\": 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/V1/carts/:cartId/estimate-shipping-methods-by-address-id') do |req|
  req.body = "{\n  \"addressId\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id";

    let payload = json!({"addressId": 0});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id \
  --header 'content-type: application/json' \
  --data '{
  "addressId": 0
}'
echo '{
  "addressId": 0
}' |  \
  http POST {{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "addressId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["addressId": 0] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/estimate-shipping-methods-by-address-id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-{cartId}-gift-message (POST)
{{baseUrl}}/V1/carts/:cartId/gift-message
QUERY PARAMS

cartId
BODY json

{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/gift-message");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/:cartId/gift-message" {:content-type :json
                                                                          :form-params {:giftMessage {:customer_id 0
                                                                                                      :extension_attributes {:entity_id ""
                                                                                                                             :entity_type ""
                                                                                                                             :wrapping_add_printed_card false
                                                                                                                             :wrapping_allow_gift_receipt false
                                                                                                                             :wrapping_id 0}
                                                                                                      :gift_message_id 0
                                                                                                      :message ""
                                                                                                      :recipient ""
                                                                                                      :sender ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/gift-message"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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}}/V1/carts/:cartId/gift-message"),
    Content = new StringContent("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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}}/V1/carts/:cartId/gift-message");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/gift-message"

	payload := strings.NewReader("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/:cartId/gift-message HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 325

{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/:cartId/gift-message")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/gift-message"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/gift-message")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/:cartId/gift-message")
  .header("content-type", "application/json")
  .body("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/carts/:cartId/gift-message');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/:cartId/gift-message',
  headers: {'content-type': 'application/json'},
  data: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/gift-message';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftMessage":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/gift-message',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "giftMessage": {\n    "customer_id": 0,\n    "extension_attributes": {\n      "entity_id": "",\n      "entity_type": "",\n      "wrapping_add_printed_card": false,\n      "wrapping_allow_gift_receipt": false,\n      "wrapping_id": 0\n    },\n    "gift_message_id": 0,\n    "message": "",\n    "recipient": "",\n    "sender": ""\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  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/gift-message")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/gift-message',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/:cartId/gift-message',
  headers: {'content-type': 'application/json'},
  body: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  },
  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}}/V1/carts/:cartId/gift-message');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
});

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}}/V1/carts/:cartId/gift-message',
  headers: {'content-type': 'application/json'},
  data: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/gift-message';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftMessage":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"giftMessage": @{ @"customer_id": @0, @"extension_attributes": @{ @"entity_id": @"", @"entity_type": @"", @"wrapping_add_printed_card": @NO, @"wrapping_allow_gift_receipt": @NO, @"wrapping_id": @0 }, @"gift_message_id": @0, @"message": @"", @"recipient": @"", @"sender": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/gift-message"]
                                                       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}}/V1/carts/:cartId/gift-message" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/gift-message",
  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([
    'giftMessage' => [
        'customer_id' => 0,
        'extension_attributes' => [
                'entity_id' => '',
                'entity_type' => '',
                'wrapping_add_printed_card' => null,
                'wrapping_allow_gift_receipt' => null,
                'wrapping_id' => 0
        ],
        'gift_message_id' => 0,
        'message' => '',
        'recipient' => '',
        'sender' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/:cartId/gift-message', [
  'body' => '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/gift-message');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'giftMessage' => [
    'customer_id' => 0,
    'extension_attributes' => [
        'entity_id' => '',
        'entity_type' => '',
        'wrapping_add_printed_card' => null,
        'wrapping_allow_gift_receipt' => null,
        'wrapping_id' => 0
    ],
    'gift_message_id' => 0,
    'message' => '',
    'recipient' => '',
    'sender' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'giftMessage' => [
    'customer_id' => 0,
    'extension_attributes' => [
        'entity_id' => '',
        'entity_type' => '',
        'wrapping_add_printed_card' => null,
        'wrapping_allow_gift_receipt' => null,
        'wrapping_id' => 0
    ],
    'gift_message_id' => 0,
    'message' => '',
    'recipient' => '',
    'sender' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/:cartId/gift-message');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/gift-message' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/gift-message' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/:cartId/gift-message", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/gift-message"

payload = { "giftMessage": {
        "customer_id": 0,
        "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": False,
            "wrapping_allow_gift_receipt": False,
            "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/gift-message"

payload <- "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/gift-message")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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/V1/carts/:cartId/gift-message') do |req|
  req.body = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/gift-message";

    let payload = json!({"giftMessage": json!({
            "customer_id": 0,
            "extension_attributes": json!({
                "entity_id": "",
                "entity_type": "",
                "wrapping_add_printed_card": false,
                "wrapping_allow_gift_receipt": false,
                "wrapping_id": 0
            }),
            "gift_message_id": 0,
            "message": "",
            "recipient": "",
            "sender": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/:cartId/gift-message \
  --header 'content-type: application/json' \
  --data '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
echo '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/carts/:cartId/gift-message \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "giftMessage": {\n    "customer_id": 0,\n    "extension_attributes": {\n      "entity_id": "",\n      "entity_type": "",\n      "wrapping_add_printed_card": false,\n      "wrapping_allow_gift_receipt": false,\n      "wrapping_id": 0\n    },\n    "gift_message_id": 0,\n    "message": "",\n    "recipient": "",\n    "sender": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/gift-message
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["giftMessage": [
    "customer_id": 0,
    "extension_attributes": [
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    ],
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/gift-message")! 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 carts-{cartId}-gift-message
{{baseUrl}}/V1/carts/:cartId/gift-message
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/gift-message");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/:cartId/gift-message")
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/gift-message"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/:cartId/gift-message"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/:cartId/gift-message");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/gift-message"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/:cartId/gift-message HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/:cartId/gift-message")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/gift-message"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/gift-message")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/:cartId/gift-message")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/:cartId/gift-message');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/gift-message'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/gift-message';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/gift-message',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/gift-message")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/gift-message',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/gift-message'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/:cartId/gift-message');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/gift-message'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/gift-message';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/gift-message"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/:cartId/gift-message" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/gift-message",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/:cartId/gift-message');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/gift-message');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/:cartId/gift-message');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/gift-message' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/gift-message' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/:cartId/gift-message")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/gift-message"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/gift-message"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/gift-message")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/:cartId/gift-message') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/gift-message";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/:cartId/gift-message
http GET {{baseUrl}}/V1/carts/:cartId/gift-message
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/gift-message
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/gift-message")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-{cartId}-gift-message-{itemId} (POST)
{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId
QUERY PARAMS

cartId
itemId
BODY json

{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId" {:content-type :json
                                                                                  :form-params {:giftMessage {:customer_id 0
                                                                                                              :extension_attributes {:entity_id ""
                                                                                                                                     :entity_type ""
                                                                                                                                     :wrapping_add_printed_card false
                                                                                                                                     :wrapping_allow_gift_receipt false
                                                                                                                                     :wrapping_id 0}
                                                                                                              :gift_message_id 0
                                                                                                              :message ""
                                                                                                              :recipient ""
                                                                                                              :sender ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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}}/V1/carts/:cartId/gift-message/:itemId"),
    Content = new StringContent("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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}}/V1/carts/:cartId/gift-message/:itemId");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId"

	payload := strings.NewReader("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/:cartId/gift-message/:itemId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 325

{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId")
  .header("content-type", "application/json")
  .body("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId',
  headers: {'content-type': 'application/json'},
  data: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftMessage":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "giftMessage": {\n    "customer_id": 0,\n    "extension_attributes": {\n      "entity_id": "",\n      "entity_type": "",\n      "wrapping_add_printed_card": false,\n      "wrapping_allow_gift_receipt": false,\n      "wrapping_id": 0\n    },\n    "gift_message_id": 0,\n    "message": "",\n    "recipient": "",\n    "sender": ""\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  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/gift-message/:itemId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId',
  headers: {'content-type': 'application/json'},
  body: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  },
  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}}/V1/carts/:cartId/gift-message/:itemId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
});

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}}/V1/carts/:cartId/gift-message/:itemId',
  headers: {'content-type': 'application/json'},
  data: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftMessage":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"giftMessage": @{ @"customer_id": @0, @"extension_attributes": @{ @"entity_id": @"", @"entity_type": @"", @"wrapping_add_printed_card": @NO, @"wrapping_allow_gift_receipt": @NO, @"wrapping_id": @0 }, @"gift_message_id": @0, @"message": @"", @"recipient": @"", @"sender": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId"]
                                                       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}}/V1/carts/:cartId/gift-message/:itemId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId",
  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([
    'giftMessage' => [
        'customer_id' => 0,
        'extension_attributes' => [
                'entity_id' => '',
                'entity_type' => '',
                'wrapping_add_printed_card' => null,
                'wrapping_allow_gift_receipt' => null,
                'wrapping_id' => 0
        ],
        'gift_message_id' => 0,
        'message' => '',
        'recipient' => '',
        'sender' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId', [
  'body' => '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'giftMessage' => [
    'customer_id' => 0,
    'extension_attributes' => [
        'entity_id' => '',
        'entity_type' => '',
        'wrapping_add_printed_card' => null,
        'wrapping_allow_gift_receipt' => null,
        'wrapping_id' => 0
    ],
    'gift_message_id' => 0,
    'message' => '',
    'recipient' => '',
    'sender' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'giftMessage' => [
    'customer_id' => 0,
    'extension_attributes' => [
        'entity_id' => '',
        'entity_type' => '',
        'wrapping_add_printed_card' => null,
        'wrapping_allow_gift_receipt' => null,
        'wrapping_id' => 0
    ],
    'gift_message_id' => 0,
    'message' => '',
    'recipient' => '',
    'sender' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/:cartId/gift-message/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId"

payload = { "giftMessage": {
        "customer_id": 0,
        "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": False,
            "wrapping_allow_gift_receipt": False,
            "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId"

payload <- "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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/V1/carts/:cartId/gift-message/:itemId') do |req|
  req.body = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId";

    let payload = json!({"giftMessage": json!({
            "customer_id": 0,
            "extension_attributes": json!({
                "entity_id": "",
                "entity_type": "",
                "wrapping_add_printed_card": false,
                "wrapping_allow_gift_receipt": false,
                "wrapping_id": 0
            }),
            "gift_message_id": 0,
            "message": "",
            "recipient": "",
            "sender": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/:cartId/gift-message/:itemId \
  --header 'content-type: application/json' \
  --data '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
echo '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/carts/:cartId/gift-message/:itemId \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "giftMessage": {\n    "customer_id": 0,\n    "extension_attributes": {\n      "entity_id": "",\n      "entity_type": "",\n      "wrapping_add_printed_card": false,\n      "wrapping_allow_gift_receipt": false,\n      "wrapping_id": 0\n    },\n    "gift_message_id": 0,\n    "message": "",\n    "recipient": "",\n    "sender": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/gift-message/:itemId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["giftMessage": [
    "customer_id": 0,
    "extension_attributes": [
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    ],
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId")! 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 carts-{cartId}-gift-message-{itemId}
{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId
QUERY PARAMS

cartId
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId")
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/:cartId/gift-message/:itemId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/gift-message/:itemId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/:cartId/gift-message/:itemId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/:cartId/gift-message/:itemId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/:cartId/gift-message/:itemId
http GET {{baseUrl}}/V1/carts/:cartId/gift-message/:itemId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/gift-message/:itemId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/gift-message/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT carts-{cartId}-giftCards
{{baseUrl}}/V1/carts/:cartId/giftCards
QUERY PARAMS

cartId
BODY json

{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/giftCards");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/carts/:cartId/giftCards" {:content-type :json
                                                                      :form-params {:giftCardAccountData {:base_gift_cards_amount ""
                                                                                                          :base_gift_cards_amount_used ""
                                                                                                          :extension_attributes {}
                                                                                                          :gift_cards []
                                                                                                          :gift_cards_amount ""
                                                                                                          :gift_cards_amount_used ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/giftCards"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\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}}/V1/carts/:cartId/giftCards"),
    Content = new StringContent("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\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}}/V1/carts/:cartId/giftCards");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/giftCards"

	payload := strings.NewReader("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/carts/:cartId/giftCards HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 223

{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/carts/:cartId/giftCards")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/giftCards"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\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  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/giftCards")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/carts/:cartId/giftCards")
  .header("content-type", "application/json")
  .body("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  giftCardAccountData: {
    base_gift_cards_amount: '',
    base_gift_cards_amount_used: '',
    extension_attributes: {},
    gift_cards: [],
    gift_cards_amount: '',
    gift_cards_amount_used: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/carts/:cartId/giftCards');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/:cartId/giftCards',
  headers: {'content-type': 'application/json'},
  data: {
    giftCardAccountData: {
      base_gift_cards_amount: '',
      base_gift_cards_amount_used: '',
      extension_attributes: {},
      gift_cards: [],
      gift_cards_amount: '',
      gift_cards_amount_used: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/giftCards';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"giftCardAccountData":{"base_gift_cards_amount":"","base_gift_cards_amount_used":"","extension_attributes":{},"gift_cards":[],"gift_cards_amount":"","gift_cards_amount_used":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/giftCards',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "giftCardAccountData": {\n    "base_gift_cards_amount": "",\n    "base_gift_cards_amount_used": "",\n    "extension_attributes": {},\n    "gift_cards": [],\n    "gift_cards_amount": "",\n    "gift_cards_amount_used": ""\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  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/giftCards")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/giftCards',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  giftCardAccountData: {
    base_gift_cards_amount: '',
    base_gift_cards_amount_used: '',
    extension_attributes: {},
    gift_cards: [],
    gift_cards_amount: '',
    gift_cards_amount_used: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/:cartId/giftCards',
  headers: {'content-type': 'application/json'},
  body: {
    giftCardAccountData: {
      base_gift_cards_amount: '',
      base_gift_cards_amount_used: '',
      extension_attributes: {},
      gift_cards: [],
      gift_cards_amount: '',
      gift_cards_amount_used: ''
    }
  },
  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}}/V1/carts/:cartId/giftCards');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  giftCardAccountData: {
    base_gift_cards_amount: '',
    base_gift_cards_amount_used: '',
    extension_attributes: {},
    gift_cards: [],
    gift_cards_amount: '',
    gift_cards_amount_used: ''
  }
});

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}}/V1/carts/:cartId/giftCards',
  headers: {'content-type': 'application/json'},
  data: {
    giftCardAccountData: {
      base_gift_cards_amount: '',
      base_gift_cards_amount_used: '',
      extension_attributes: {},
      gift_cards: [],
      gift_cards_amount: '',
      gift_cards_amount_used: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/giftCards';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"giftCardAccountData":{"base_gift_cards_amount":"","base_gift_cards_amount_used":"","extension_attributes":{},"gift_cards":[],"gift_cards_amount":"","gift_cards_amount_used":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"giftCardAccountData": @{ @"base_gift_cards_amount": @"", @"base_gift_cards_amount_used": @"", @"extension_attributes": @{  }, @"gift_cards": @[  ], @"gift_cards_amount": @"", @"gift_cards_amount_used": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/giftCards"]
                                                       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}}/V1/carts/:cartId/giftCards" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/giftCards",
  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([
    'giftCardAccountData' => [
        'base_gift_cards_amount' => '',
        'base_gift_cards_amount_used' => '',
        'extension_attributes' => [
                
        ],
        'gift_cards' => [
                
        ],
        'gift_cards_amount' => '',
        'gift_cards_amount_used' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/carts/:cartId/giftCards', [
  'body' => '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/giftCards');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'giftCardAccountData' => [
    'base_gift_cards_amount' => '',
    'base_gift_cards_amount_used' => '',
    'extension_attributes' => [
        
    ],
    'gift_cards' => [
        
    ],
    'gift_cards_amount' => '',
    'gift_cards_amount_used' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'giftCardAccountData' => [
    'base_gift_cards_amount' => '',
    'base_gift_cards_amount_used' => '',
    'extension_attributes' => [
        
    ],
    'gift_cards' => [
        
    ],
    'gift_cards_amount' => '',
    'gift_cards_amount_used' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/:cartId/giftCards');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/giftCards' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/giftCards' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/carts/:cartId/giftCards", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/giftCards"

payload = { "giftCardAccountData": {
        "base_gift_cards_amount": "",
        "base_gift_cards_amount_used": "",
        "extension_attributes": {},
        "gift_cards": [],
        "gift_cards_amount": "",
        "gift_cards_amount_used": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/giftCards"

payload <- "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/giftCards")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\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/V1/carts/:cartId/giftCards') do |req|
  req.body = "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\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}}/V1/carts/:cartId/giftCards";

    let payload = json!({"giftCardAccountData": json!({
            "base_gift_cards_amount": "",
            "base_gift_cards_amount_used": "",
            "extension_attributes": json!({}),
            "gift_cards": (),
            "gift_cards_amount": "",
            "gift_cards_amount_used": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/carts/:cartId/giftCards \
  --header 'content-type: application/json' \
  --data '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}'
echo '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/carts/:cartId/giftCards \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "giftCardAccountData": {\n    "base_gift_cards_amount": "",\n    "base_gift_cards_amount_used": "",\n    "extension_attributes": {},\n    "gift_cards": [],\n    "gift_cards_amount": "",\n    "gift_cards_amount_used": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/giftCards
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["giftCardAccountData": [
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": [],
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/giftCards")! 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()
DELETE carts-{cartId}-giftCards-{giftCardCode}
{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode
QUERY PARAMS

cartId
giftCardCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode")
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/carts/:cartId/giftCards/:giftCardCode HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode"))
    .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}}/V1/carts/:cartId/giftCards/:giftCardCode")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode")
  .asString();
const 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}}/V1/carts/:cartId/giftCards/:giftCardCode');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/giftCards/:giftCardCode',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode');

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}}/V1/carts/:cartId/giftCards/:giftCardCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/carts/:cartId/giftCards/:giftCardCode")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/carts/:cartId/giftCards/:giftCardCode') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode
http DELETE {{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/giftCards/:giftCardCode")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET carts-{cartId}-items
{{baseUrl}}/V1/carts/:cartId/items
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/items");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/:cartId/items")
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/items"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/:cartId/items"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/:cartId/items");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/items"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/:cartId/items HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/:cartId/items")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/items"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/items")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/:cartId/items")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/:cartId/items');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/:cartId/items'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/items';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/items',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/items")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/items',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/:cartId/items'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/:cartId/items');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/:cartId/items'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/items';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/items"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/:cartId/items" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/items",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/:cartId/items');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/items');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/:cartId/items');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/items' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/items' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/:cartId/items")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/items"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/items"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/items")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/:cartId/items') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/items";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/:cartId/items
http GET {{baseUrl}}/V1/carts/:cartId/items
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/items
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/items")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT carts-{cartId}-items-{itemId} (PUT)
{{baseUrl}}/V1/carts/:cartId/items/:itemId
QUERY PARAMS

cartId
itemId
BODY json

{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/items/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/carts/:cartId/items/:itemId" {:content-type :json
                                                                          :form-params {:cartItem {:extension_attributes {:negotiable_quote_item {:extension_attributes {}
                                                                                                                                                  :item_id 0
                                                                                                                                                  :original_discount_amount ""
                                                                                                                                                  :original_price ""
                                                                                                                                                  :original_tax_amount ""}}
                                                                                                   :item_id 0
                                                                                                   :name ""
                                                                                                   :price ""
                                                                                                   :product_option {:extension_attributes {:bundle_options [{:extension_attributes {}
                                                                                                                                                             :option_id 0
                                                                                                                                                             :option_qty 0
                                                                                                                                                             :option_selections []}]
                                                                                                                                           :configurable_item_options [{:extension_attributes {}
                                                                                                                                                                        :option_id ""
                                                                                                                                                                        :option_value 0}]
                                                                                                                                           :custom_options [{:extension_attributes {:file_info {:base64_encoded_data ""
                                                                                                                                                                                                :name ""
                                                                                                                                                                                                :type ""}}
                                                                                                                                                             :option_id ""
                                                                                                                                                             :option_value ""}]
                                                                                                                                           :downloadable_option {:downloadable_links []}
                                                                                                                                           :giftcard_item_option {:custom_giftcard_amount ""
                                                                                                                                                                  :extension_attributes {}
                                                                                                                                                                  :giftcard_amount ""
                                                                                                                                                                  :giftcard_message ""
                                                                                                                                                                  :giftcard_recipient_email ""
                                                                                                                                                                  :giftcard_recipient_name ""
                                                                                                                                                                  :giftcard_sender_email ""
                                                                                                                                                                  :giftcard_sender_name ""}}}
                                                                                                   :product_type ""
                                                                                                   :qty ""
                                                                                                   :quote_id ""
                                                                                                   :sku ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/items/:itemId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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}}/V1/carts/:cartId/items/:itemId"),
    Content = new StringContent("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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}}/V1/carts/:cartId/items/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/items/:itemId"

	payload := strings.NewReader("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/carts/:cartId/items/:itemId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1573

{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/carts/:cartId/items/:itemId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/items/:itemId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/items/:itemId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/carts/:cartId/items/:itemId")
  .header("content-type", "application/json")
  .body("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [
          {
            extension_attributes: {},
            option_id: 0,
            option_qty: 0,
            option_selections: []
          }
        ],
        configurable_item_options: [
          {
            extension_attributes: {},
            option_id: '',
            option_value: 0
          }
        ],
        custom_options: [
          {
            extension_attributes: {
              file_info: {
                base64_encoded_data: '',
                name: '',
                type: ''
              }
            },
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {
          downloadable_links: []
        },
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/carts/:cartId/items/:itemId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/:cartId/items/:itemId',
  headers: {'content-type': 'application/json'},
  data: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/items/:itemId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"cartItem":{"extension_attributes":{"negotiable_quote_item":{"extension_attributes":{},"item_id":0,"original_discount_amount":"","original_price":"","original_tax_amount":""}},"item_id":0,"name":"","price":"","product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty":"","quote_id":"","sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/items/:itemId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "cartItem": {\n    "extension_attributes": {\n      "negotiable_quote_item": {\n        "extension_attributes": {},\n        "item_id": 0,\n        "original_discount_amount": "",\n        "original_price": "",\n        "original_tax_amount": ""\n      }\n    },\n    "item_id": 0,\n    "name": "",\n    "price": "",\n    "product_option": {\n      "extension_attributes": {\n        "bundle_options": [\n          {\n            "extension_attributes": {},\n            "option_id": 0,\n            "option_qty": 0,\n            "option_selections": []\n          }\n        ],\n        "configurable_item_options": [\n          {\n            "extension_attributes": {},\n            "option_id": "",\n            "option_value": 0\n          }\n        ],\n        "custom_options": [\n          {\n            "extension_attributes": {\n              "file_info": {\n                "base64_encoded_data": "",\n                "name": "",\n                "type": ""\n              }\n            },\n            "option_id": "",\n            "option_value": ""\n          }\n        ],\n        "downloadable_option": {\n          "downloadable_links": []\n        },\n        "giftcard_item_option": {\n          "custom_giftcard_amount": "",\n          "extension_attributes": {},\n          "giftcard_amount": "",\n          "giftcard_message": "",\n          "giftcard_recipient_email": "",\n          "giftcard_recipient_name": "",\n          "giftcard_sender_email": "",\n          "giftcard_sender_name": ""\n        }\n      }\n    },\n    "product_type": "",\n    "qty": "",\n    "quote_id": "",\n    "sku": ""\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  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/items/:itemId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/items/:itemId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
        configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
        custom_options: [
          {
            extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {downloadable_links: []},
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/:cartId/items/:itemId',
  headers: {'content-type': 'application/json'},
  body: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  },
  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}}/V1/carts/:cartId/items/:itemId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [
          {
            extension_attributes: {},
            option_id: 0,
            option_qty: 0,
            option_selections: []
          }
        ],
        configurable_item_options: [
          {
            extension_attributes: {},
            option_id: '',
            option_value: 0
          }
        ],
        custom_options: [
          {
            extension_attributes: {
              file_info: {
                base64_encoded_data: '',
                name: '',
                type: ''
              }
            },
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {
          downloadable_links: []
        },
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
});

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}}/V1/carts/:cartId/items/:itemId',
  headers: {'content-type': 'application/json'},
  data: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/items/:itemId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"cartItem":{"extension_attributes":{"negotiable_quote_item":{"extension_attributes":{},"item_id":0,"original_discount_amount":"","original_price":"","original_tax_amount":""}},"item_id":0,"name":"","price":"","product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty":"","quote_id":"","sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"cartItem": @{ @"extension_attributes": @{ @"negotiable_quote_item": @{ @"extension_attributes": @{  }, @"item_id": @0, @"original_discount_amount": @"", @"original_price": @"", @"original_tax_amount": @"" } }, @"item_id": @0, @"name": @"", @"price": @"", @"product_option": @{ @"extension_attributes": @{ @"bundle_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @0, @"option_qty": @0, @"option_selections": @[  ] } ], @"configurable_item_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @"", @"option_value": @0 } ], @"custom_options": @[ @{ @"extension_attributes": @{ @"file_info": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" } }, @"option_id": @"", @"option_value": @"" } ], @"downloadable_option": @{ @"downloadable_links": @[  ] }, @"giftcard_item_option": @{ @"custom_giftcard_amount": @"", @"extension_attributes": @{  }, @"giftcard_amount": @"", @"giftcard_message": @"", @"giftcard_recipient_email": @"", @"giftcard_recipient_name": @"", @"giftcard_sender_email": @"", @"giftcard_sender_name": @"" } } }, @"product_type": @"", @"qty": @"", @"quote_id": @"", @"sku": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/items/: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}}/V1/carts/:cartId/items/:itemId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/items/: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([
    'cartItem' => [
        'extension_attributes' => [
                'negotiable_quote_item' => [
                                'extension_attributes' => [
                                                                
                                ],
                                'item_id' => 0,
                                'original_discount_amount' => '',
                                'original_price' => '',
                                'original_tax_amount' => ''
                ]
        ],
        'item_id' => 0,
        'name' => '',
        'price' => '',
        'product_option' => [
                'extension_attributes' => [
                                'bundle_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'option_id' => 0,
                                                                                                                                'option_qty' => 0,
                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'configurable_item_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'option_id' => '',
                                                                                                                                'option_value' => 0
                                                                ]
                                ],
                                'custom_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'option_id' => '',
                                                                                                                                'option_value' => ''
                                                                ]
                                ],
                                'downloadable_option' => [
                                                                'downloadable_links' => [
                                                                                                                                
                                                                ]
                                ],
                                'giftcard_item_option' => [
                                                                'custom_giftcard_amount' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'giftcard_amount' => '',
                                                                'giftcard_message' => '',
                                                                'giftcard_recipient_email' => '',
                                                                'giftcard_recipient_name' => '',
                                                                'giftcard_sender_email' => '',
                                                                'giftcard_sender_name' => ''
                                ]
                ]
        ],
        'product_type' => '',
        'qty' => '',
        'quote_id' => '',
        'sku' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/carts/:cartId/items/:itemId', [
  'body' => '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/items/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'cartItem' => [
    'extension_attributes' => [
        'negotiable_quote_item' => [
                'extension_attributes' => [
                                
                ],
                'item_id' => 0,
                'original_discount_amount' => '',
                'original_price' => '',
                'original_tax_amount' => ''
        ]
    ],
    'item_id' => 0,
    'name' => '',
    'price' => '',
    'product_option' => [
        'extension_attributes' => [
                'bundle_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'option_qty' => 0,
                                                                'option_selections' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'configurable_item_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => 0
                                ]
                ],
                'custom_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ]
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => ''
                                ]
                ],
                'downloadable_option' => [
                                'downloadable_links' => [
                                                                
                                ]
                ],
                'giftcard_item_option' => [
                                'custom_giftcard_amount' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'giftcard_amount' => '',
                                'giftcard_message' => '',
                                'giftcard_recipient_email' => '',
                                'giftcard_recipient_name' => '',
                                'giftcard_sender_email' => '',
                                'giftcard_sender_name' => ''
                ]
        ]
    ],
    'product_type' => '',
    'qty' => '',
    'quote_id' => '',
    'sku' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'cartItem' => [
    'extension_attributes' => [
        'negotiable_quote_item' => [
                'extension_attributes' => [
                                
                ],
                'item_id' => 0,
                'original_discount_amount' => '',
                'original_price' => '',
                'original_tax_amount' => ''
        ]
    ],
    'item_id' => 0,
    'name' => '',
    'price' => '',
    'product_option' => [
        'extension_attributes' => [
                'bundle_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'option_qty' => 0,
                                                                'option_selections' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'configurable_item_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => 0
                                ]
                ],
                'custom_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ]
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => ''
                                ]
                ],
                'downloadable_option' => [
                                'downloadable_links' => [
                                                                
                                ]
                ],
                'giftcard_item_option' => [
                                'custom_giftcard_amount' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'giftcard_amount' => '',
                                'giftcard_message' => '',
                                'giftcard_recipient_email' => '',
                                'giftcard_recipient_name' => '',
                                'giftcard_sender_email' => '',
                                'giftcard_sender_name' => ''
                ]
        ]
    ],
    'product_type' => '',
    'qty' => '',
    'quote_id' => '',
    'sku' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/:cartId/items/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/items/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/items/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/carts/:cartId/items/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/items/:itemId"

payload = { "cartItem": {
        "extension_attributes": { "negotiable_quote_item": {
                "extension_attributes": {},
                "item_id": 0,
                "original_discount_amount": "",
                "original_price": "",
                "original_tax_amount": ""
            } },
        "item_id": 0,
        "name": "",
        "price": "",
        "product_option": { "extension_attributes": {
                "bundle_options": [
                    {
                        "extension_attributes": {},
                        "option_id": 0,
                        "option_qty": 0,
                        "option_selections": []
                    }
                ],
                "configurable_item_options": [
                    {
                        "extension_attributes": {},
                        "option_id": "",
                        "option_value": 0
                    }
                ],
                "custom_options": [
                    {
                        "extension_attributes": { "file_info": {
                                "base64_encoded_data": "",
                                "name": "",
                                "type": ""
                            } },
                        "option_id": "",
                        "option_value": ""
                    }
                ],
                "downloadable_option": { "downloadable_links": [] },
                "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                }
            } },
        "product_type": "",
        "qty": "",
        "quote_id": "",
        "sku": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/items/:itemId"

payload <- "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/items/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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/V1/carts/:cartId/items/:itemId') do |req|
  req.body = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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}}/V1/carts/:cartId/items/:itemId";

    let payload = json!({"cartItem": json!({
            "extension_attributes": json!({"negotiable_quote_item": json!({
                    "extension_attributes": json!({}),
                    "item_id": 0,
                    "original_discount_amount": "",
                    "original_price": "",
                    "original_tax_amount": ""
                })}),
            "item_id": 0,
            "name": "",
            "price": "",
            "product_option": json!({"extension_attributes": json!({
                    "bundle_options": (
                        json!({
                            "extension_attributes": json!({}),
                            "option_id": 0,
                            "option_qty": 0,
                            "option_selections": ()
                        })
                    ),
                    "configurable_item_options": (
                        json!({
                            "extension_attributes": json!({}),
                            "option_id": "",
                            "option_value": 0
                        })
                    ),
                    "custom_options": (
                        json!({
                            "extension_attributes": json!({"file_info": json!({
                                    "base64_encoded_data": "",
                                    "name": "",
                                    "type": ""
                                })}),
                            "option_id": "",
                            "option_value": ""
                        })
                    ),
                    "downloadable_option": json!({"downloadable_links": ()}),
                    "giftcard_item_option": json!({
                        "custom_giftcard_amount": "",
                        "extension_attributes": json!({}),
                        "giftcard_amount": "",
                        "giftcard_message": "",
                        "giftcard_recipient_email": "",
                        "giftcard_recipient_name": "",
                        "giftcard_sender_email": "",
                        "giftcard_sender_name": ""
                    })
                })}),
            "product_type": "",
            "qty": "",
            "quote_id": "",
            "sku": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/carts/:cartId/items/:itemId \
  --header 'content-type: application/json' \
  --data '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
echo '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/carts/:cartId/items/:itemId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "cartItem": {\n    "extension_attributes": {\n      "negotiable_quote_item": {\n        "extension_attributes": {},\n        "item_id": 0,\n        "original_discount_amount": "",\n        "original_price": "",\n        "original_tax_amount": ""\n      }\n    },\n    "item_id": 0,\n    "name": "",\n    "price": "",\n    "product_option": {\n      "extension_attributes": {\n        "bundle_options": [\n          {\n            "extension_attributes": {},\n            "option_id": 0,\n            "option_qty": 0,\n            "option_selections": []\n          }\n        ],\n        "configurable_item_options": [\n          {\n            "extension_attributes": {},\n            "option_id": "",\n            "option_value": 0\n          }\n        ],\n        "custom_options": [\n          {\n            "extension_attributes": {\n              "file_info": {\n                "base64_encoded_data": "",\n                "name": "",\n                "type": ""\n              }\n            },\n            "option_id": "",\n            "option_value": ""\n          }\n        ],\n        "downloadable_option": {\n          "downloadable_links": []\n        },\n        "giftcard_item_option": {\n          "custom_giftcard_amount": "",\n          "extension_attributes": {},\n          "giftcard_amount": "",\n          "giftcard_message": "",\n          "giftcard_recipient_email": "",\n          "giftcard_recipient_name": "",\n          "giftcard_sender_email": "",\n          "giftcard_sender_name": ""\n        }\n      }\n    },\n    "product_type": "",\n    "qty": "",\n    "quote_id": "",\n    "sku": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/items/:itemId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["cartItem": [
    "extension_attributes": ["negotiable_quote_item": [
        "extension_attributes": [],
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      ]],
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": ["extension_attributes": [
        "bundle_options": [
          [
            "extension_attributes": [],
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          ]
        ],
        "configurable_item_options": [
          [
            "extension_attributes": [],
            "option_id": "",
            "option_value": 0
          ]
        ],
        "custom_options": [
          [
            "extension_attributes": ["file_info": [
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              ]],
            "option_id": "",
            "option_value": ""
          ]
        ],
        "downloadable_option": ["downloadable_links": []],
        "giftcard_item_option": [
          "custom_giftcard_amount": "",
          "extension_attributes": [],
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        ]
      ]],
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/items/: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()
DELETE carts-{cartId}-items-{itemId}
{{baseUrl}}/V1/carts/:cartId/items/:itemId
QUERY PARAMS

cartId
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/items/:itemId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/carts/:cartId/items/:itemId")
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/items/:itemId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/:cartId/items/:itemId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/:cartId/items/:itemId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/items/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/carts/:cartId/items/:itemId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/carts/:cartId/items/:itemId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/items/:itemId"))
    .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}}/V1/carts/:cartId/items/:itemId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/carts/:cartId/items/:itemId")
  .asString();
const 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}}/V1/carts/:cartId/items/:itemId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/carts/:cartId/items/:itemId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/items/:itemId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/items/:itemId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/items/:itemId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/items/:itemId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/carts/:cartId/items/:itemId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/carts/:cartId/items/:itemId');

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}}/V1/carts/:cartId/items/:itemId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/items/:itemId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/items/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/:cartId/items/:itemId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/items/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/carts/:cartId/items/:itemId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/items/:itemId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/:cartId/items/:itemId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/items/:itemId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/items/:itemId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/carts/:cartId/items/:itemId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/items/:itemId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/items/:itemId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/items/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/carts/:cartId/items/:itemId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/items/:itemId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/carts/:cartId/items/:itemId
http DELETE {{baseUrl}}/V1/carts/:cartId/items/:itemId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/items/:itemId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/items/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT carts-{cartId}-order
{{baseUrl}}/V1/carts/:cartId/order
QUERY PARAMS

cartId
BODY json

{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/order");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/carts/:cartId/order" {:content-type :json
                                                                  :form-params {:paymentMethod {:additional_data []
                                                                                                :extension_attributes {:agreement_ids []}
                                                                                                :method ""
                                                                                                :po_number ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/order"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/carts/:cartId/order"),
    Content = new StringContent("{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/carts/:cartId/order");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/order"

	payload := strings.NewReader("{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/carts/:cartId/order HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 156

{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/carts/:cartId/order")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/order"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/order")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/carts/:cartId/order")
  .header("content-type", "application/json")
  .body("{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/carts/:cartId/order');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/:cartId/order',
  headers: {'content-type': 'application/json'},
  data: {
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/order';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/order',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\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  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/order")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/order',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  paymentMethod: {
    additional_data: [],
    extension_attributes: {agreement_ids: []},
    method: '',
    po_number: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/:cartId/order',
  headers: {'content-type': 'application/json'},
  body: {
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/carts/:cartId/order');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/:cartId/order',
  headers: {'content-type': 'application/json'},
  data: {
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/order';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"paymentMethod": @{ @"additional_data": @[  ], @"extension_attributes": @{ @"agreement_ids": @[  ] }, @"method": @"", @"po_number": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/order"]
                                                       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}}/V1/carts/:cartId/order" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/order",
  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([
    'paymentMethod' => [
        'additional_data' => [
                
        ],
        'extension_attributes' => [
                'agreement_ids' => [
                                
                ]
        ],
        'method' => '',
        'po_number' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/carts/:cartId/order', [
  'body' => '{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/order');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/:cartId/order');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/order' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/order' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/carts/:cartId/order", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/order"

payload = { "paymentMethod": {
        "additional_data": [],
        "extension_attributes": { "agreement_ids": [] },
        "method": "",
        "po_number": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/order"

payload <- "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/order")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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/V1/carts/:cartId/order') do |req|
  req.body = "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/carts/:cartId/order";

    let payload = json!({"paymentMethod": json!({
            "additional_data": (),
            "extension_attributes": json!({"agreement_ids": ()}),
            "method": "",
            "po_number": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/carts/:cartId/order \
  --header 'content-type: application/json' \
  --data '{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
echo '{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/carts/:cartId/order \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/order
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["paymentMethod": [
    "additional_data": [],
    "extension_attributes": ["agreement_ids": []],
    "method": "",
    "po_number": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/order")! 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 carts-{cartId}-payment-methods
{{baseUrl}}/V1/carts/:cartId/payment-methods
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/payment-methods");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/:cartId/payment-methods")
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/payment-methods"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/:cartId/payment-methods"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/:cartId/payment-methods");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/payment-methods"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/:cartId/payment-methods HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/:cartId/payment-methods")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/payment-methods"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/payment-methods")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/:cartId/payment-methods")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/:cartId/payment-methods');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/payment-methods'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/payment-methods';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/payment-methods',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/payment-methods")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/payment-methods',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/payment-methods'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/:cartId/payment-methods');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/payment-methods'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/payment-methods';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/payment-methods"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/:cartId/payment-methods" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/payment-methods",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/:cartId/payment-methods');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/payment-methods');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/:cartId/payment-methods');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/payment-methods' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/payment-methods' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/:cartId/payment-methods")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/payment-methods"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/payment-methods"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/payment-methods")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/:cartId/payment-methods') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/payment-methods";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/:cartId/payment-methods
http GET {{baseUrl}}/V1/carts/:cartId/payment-methods
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/payment-methods
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/payment-methods")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT carts-{cartId}-selected-payment-method (PUT)
{{baseUrl}}/V1/carts/:cartId/selected-payment-method
QUERY PARAMS

cartId
BODY json

{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/selected-payment-method");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/carts/:cartId/selected-payment-method" {:content-type :json
                                                                                    :form-params {:method {:additional_data []
                                                                                                           :extension_attributes {:agreement_ids []}
                                                                                                           :method ""
                                                                                                           :po_number ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/selected-payment-method"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/carts/:cartId/selected-payment-method"),
    Content = new StringContent("{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/carts/:cartId/selected-payment-method");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/selected-payment-method"

	payload := strings.NewReader("{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/carts/:cartId/selected-payment-method HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 149

{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/carts/:cartId/selected-payment-method")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/selected-payment-method"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/selected-payment-method")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/carts/:cartId/selected-payment-method")
  .header("content-type", "application/json")
  .body("{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  method: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/carts/:cartId/selected-payment-method');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/:cartId/selected-payment-method',
  headers: {'content-type': 'application/json'},
  data: {
    method: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/selected-payment-method';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"method":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/selected-payment-method',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "method": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\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  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/selected-payment-method")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/selected-payment-method',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  method: {
    additional_data: [],
    extension_attributes: {agreement_ids: []},
    method: '',
    po_number: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/:cartId/selected-payment-method',
  headers: {'content-type': 'application/json'},
  body: {
    method: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/carts/:cartId/selected-payment-method');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  method: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/:cartId/selected-payment-method',
  headers: {'content-type': 'application/json'},
  data: {
    method: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/selected-payment-method';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"method":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"method": @{ @"additional_data": @[  ], @"extension_attributes": @{ @"agreement_ids": @[  ] }, @"method": @"", @"po_number": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/selected-payment-method"]
                                                       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}}/V1/carts/:cartId/selected-payment-method" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/selected-payment-method",
  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([
    'method' => [
        'additional_data' => [
                
        ],
        'extension_attributes' => [
                'agreement_ids' => [
                                
                ]
        ],
        'method' => '',
        'po_number' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/carts/:cartId/selected-payment-method', [
  'body' => '{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/selected-payment-method');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'method' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'method' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/:cartId/selected-payment-method');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/selected-payment-method' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/selected-payment-method' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/carts/:cartId/selected-payment-method", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/selected-payment-method"

payload = { "method": {
        "additional_data": [],
        "extension_attributes": { "agreement_ids": [] },
        "method": "",
        "po_number": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/selected-payment-method"

payload <- "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/selected-payment-method")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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/V1/carts/:cartId/selected-payment-method') do |req|
  req.body = "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/carts/:cartId/selected-payment-method";

    let payload = json!({"method": json!({
            "additional_data": (),
            "extension_attributes": json!({"agreement_ids": ()}),
            "method": "",
            "po_number": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/carts/:cartId/selected-payment-method \
  --header 'content-type: application/json' \
  --data '{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
echo '{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/carts/:cartId/selected-payment-method \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "method": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/selected-payment-method
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["method": [
    "additional_data": [],
    "extension_attributes": ["agreement_ids": []],
    "method": "",
    "po_number": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/selected-payment-method")! 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 carts-{cartId}-selected-payment-method
{{baseUrl}}/V1/carts/:cartId/selected-payment-method
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/selected-payment-method");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/:cartId/selected-payment-method")
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/selected-payment-method"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/:cartId/selected-payment-method"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/:cartId/selected-payment-method");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/selected-payment-method"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/:cartId/selected-payment-method HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/:cartId/selected-payment-method")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/selected-payment-method"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/selected-payment-method")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/:cartId/selected-payment-method")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/:cartId/selected-payment-method');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/selected-payment-method'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/selected-payment-method';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/selected-payment-method',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/selected-payment-method")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/selected-payment-method',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/selected-payment-method'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/:cartId/selected-payment-method');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/selected-payment-method'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/selected-payment-method';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/selected-payment-method"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/:cartId/selected-payment-method" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/selected-payment-method",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/:cartId/selected-payment-method');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/selected-payment-method');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/:cartId/selected-payment-method');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/selected-payment-method' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/selected-payment-method' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/:cartId/selected-payment-method")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/selected-payment-method"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/selected-payment-method"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/selected-payment-method")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/:cartId/selected-payment-method') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/selected-payment-method";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/:cartId/selected-payment-method
http GET {{baseUrl}}/V1/carts/:cartId/selected-payment-method
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/selected-payment-method
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/selected-payment-method")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-{cartId}-shipping-information
{{baseUrl}}/V1/carts/:cartId/shipping-information
QUERY PARAMS

cartId
BODY json

{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/shipping-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/:cartId/shipping-information" {:content-type :json
                                                                                  :form-params {:addressInformation {:billing_address {:city ""
                                                                                                                                       :company ""
                                                                                                                                       :country_id ""
                                                                                                                                       :custom_attributes [{:attribute_code ""
                                                                                                                                                            :value ""}]
                                                                                                                                       :customer_address_id 0
                                                                                                                                       :customer_id 0
                                                                                                                                       :email ""
                                                                                                                                       :extension_attributes {:checkout_fields [{}]
                                                                                                                                                              :gift_registry_id 0}
                                                                                                                                       :fax ""
                                                                                                                                       :firstname ""
                                                                                                                                       :id 0
                                                                                                                                       :lastname ""
                                                                                                                                       :middlename ""
                                                                                                                                       :postcode ""
                                                                                                                                       :prefix ""
                                                                                                                                       :region ""
                                                                                                                                       :region_code ""
                                                                                                                                       :region_id 0
                                                                                                                                       :same_as_billing 0
                                                                                                                                       :save_in_address_book 0
                                                                                                                                       :street []
                                                                                                                                       :suffix ""
                                                                                                                                       :telephone ""
                                                                                                                                       :vat_id ""}
                                                                                                                     :custom_attributes [{}]
                                                                                                                     :extension_attributes {}
                                                                                                                     :shipping_address {}
                                                                                                                     :shipping_carrier_code ""
                                                                                                                     :shipping_method_code ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/shipping-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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}}/V1/carts/:cartId/shipping-information"),
    Content = new StringContent("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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}}/V1/carts/:cartId/shipping-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/shipping-information"

	payload := strings.NewReader("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/:cartId/shipping-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 959

{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/:cartId/shipping-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/shipping-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/shipping-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/:cartId/shipping-information")
  .header("content-type", "application/json")
  .body("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  addressInformation: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [
      {}
    ],
    extension_attributes: {},
    shipping_address: {},
    shipping_carrier_code: '',
    shipping_method_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}}/V1/carts/:cartId/shipping-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/:cartId/shipping-information',
  headers: {'content-type': 'application/json'},
  data: {
    addressInformation: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_address: {},
      shipping_carrier_code: '',
      shipping_method_code: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/shipping-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressInformation":{"billing_address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"custom_attributes":[{}],"extension_attributes":{},"shipping_address":{},"shipping_carrier_code":"","shipping_method_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}}/V1/carts/:cartId/shipping-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "addressInformation": {\n    "billing_address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "custom_attributes": [\n      {}\n    ],\n    "extension_attributes": {},\n    "shipping_address": {},\n    "shipping_carrier_code": "",\n    "shipping_method_code": ""\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  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/shipping-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/shipping-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  addressInformation: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [{}],
    extension_attributes: {},
    shipping_address: {},
    shipping_carrier_code: '',
    shipping_method_code: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/:cartId/shipping-information',
  headers: {'content-type': 'application/json'},
  body: {
    addressInformation: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_address: {},
      shipping_carrier_code: '',
      shipping_method_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}}/V1/carts/:cartId/shipping-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  addressInformation: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [
      {}
    ],
    extension_attributes: {},
    shipping_address: {},
    shipping_carrier_code: '',
    shipping_method_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}}/V1/carts/:cartId/shipping-information',
  headers: {'content-type': 'application/json'},
  data: {
    addressInformation: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_address: {},
      shipping_carrier_code: '',
      shipping_method_code: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/shipping-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressInformation":{"billing_address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"custom_attributes":[{}],"extension_attributes":{},"shipping_address":{},"shipping_carrier_code":"","shipping_method_code":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"addressInformation": @{ @"billing_address": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" }, @"custom_attributes": @[ @{  } ], @"extension_attributes": @{  }, @"shipping_address": @{  }, @"shipping_carrier_code": @"", @"shipping_method_code": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/shipping-information"]
                                                       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}}/V1/carts/:cartId/shipping-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/shipping-information",
  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([
    'addressInformation' => [
        'billing_address' => [
                'city' => '',
                'company' => '',
                'country_id' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_address_id' => 0,
                'customer_id' => 0,
                'email' => '',
                'extension_attributes' => [
                                'checkout_fields' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'gift_registry_id' => 0
                ],
                'fax' => '',
                'firstname' => '',
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'postcode' => '',
                'prefix' => '',
                'region' => '',
                'region_code' => '',
                'region_id' => 0,
                'same_as_billing' => 0,
                'save_in_address_book' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => ''
        ],
        'custom_attributes' => [
                [
                                
                ]
        ],
        'extension_attributes' => [
                
        ],
        'shipping_address' => [
                
        ],
        'shipping_carrier_code' => '',
        'shipping_method_code' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/:cartId/shipping-information', [
  'body' => '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/shipping-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'addressInformation' => [
    'billing_address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'extension_attributes' => [
        
    ],
    'shipping_address' => [
        
    ],
    'shipping_carrier_code' => '',
    'shipping_method_code' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'addressInformation' => [
    'billing_address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'extension_attributes' => [
        
    ],
    'shipping_address' => [
        
    ],
    'shipping_carrier_code' => '',
    'shipping_method_code' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/:cartId/shipping-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/shipping-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/shipping-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/:cartId/shipping-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/shipping-information"

payload = { "addressInformation": {
        "billing_address": {
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": [
                {
                    "attribute_code": "",
                    "value": ""
                }
            ],
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": {
                "checkout_fields": [{}],
                "gift_registry_id": 0
            },
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": [],
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        },
        "custom_attributes": [{}],
        "extension_attributes": {},
        "shipping_address": {},
        "shipping_carrier_code": "",
        "shipping_method_code": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/shipping-information"

payload <- "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/shipping-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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/V1/carts/:cartId/shipping-information') do |req|
  req.body = "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/shipping-information";

    let payload = json!({"addressInformation": json!({
            "billing_address": json!({
                "city": "",
                "company": "",
                "country_id": "",
                "custom_attributes": (
                    json!({
                        "attribute_code": "",
                        "value": ""
                    })
                ),
                "customer_address_id": 0,
                "customer_id": 0,
                "email": "",
                "extension_attributes": json!({
                    "checkout_fields": (json!({})),
                    "gift_registry_id": 0
                }),
                "fax": "",
                "firstname": "",
                "id": 0,
                "lastname": "",
                "middlename": "",
                "postcode": "",
                "prefix": "",
                "region": "",
                "region_code": "",
                "region_id": 0,
                "same_as_billing": 0,
                "save_in_address_book": 0,
                "street": (),
                "suffix": "",
                "telephone": "",
                "vat_id": ""
            }),
            "custom_attributes": (json!({})),
            "extension_attributes": json!({}),
            "shipping_address": json!({}),
            "shipping_carrier_code": "",
            "shipping_method_code": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/:cartId/shipping-information \
  --header 'content-type: application/json' \
  --data '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
echo '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/carts/:cartId/shipping-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "addressInformation": {\n    "billing_address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "custom_attributes": [\n      {}\n    ],\n    "extension_attributes": {},\n    "shipping_address": {},\n    "shipping_carrier_code": "",\n    "shipping_method_code": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/shipping-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["addressInformation": [
    "billing_address": [
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        [
          "attribute_code": "",
          "value": ""
        ]
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": [
        "checkout_fields": [[]],
        "gift_registry_id": 0
      ],
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    ],
    "custom_attributes": [[]],
    "extension_attributes": [],
    "shipping_address": [],
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/shipping-information")! 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 carts-{cartId}-shipping-methods
{{baseUrl}}/V1/carts/:cartId/shipping-methods
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/shipping-methods");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/:cartId/shipping-methods")
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/shipping-methods"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/:cartId/shipping-methods"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/:cartId/shipping-methods");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/shipping-methods"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/:cartId/shipping-methods HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/:cartId/shipping-methods")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/shipping-methods"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/shipping-methods")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/:cartId/shipping-methods")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/:cartId/shipping-methods');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/shipping-methods'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/shipping-methods';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/shipping-methods',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/shipping-methods")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/shipping-methods',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/shipping-methods'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/:cartId/shipping-methods');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/:cartId/shipping-methods'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/shipping-methods';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/shipping-methods"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/:cartId/shipping-methods" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/shipping-methods",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/:cartId/shipping-methods');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/shipping-methods');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/:cartId/shipping-methods');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/shipping-methods' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/shipping-methods' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/:cartId/shipping-methods")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/shipping-methods"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/shipping-methods"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/shipping-methods")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/:cartId/shipping-methods') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/shipping-methods";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/:cartId/shipping-methods
http GET {{baseUrl}}/V1/carts/:cartId/shipping-methods
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/shipping-methods
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/shipping-methods")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET carts-{cartId}-totals
{{baseUrl}}/V1/carts/:cartId/totals
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/totals");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/:cartId/totals")
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/totals"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/:cartId/totals"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/:cartId/totals");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/totals"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/:cartId/totals HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/:cartId/totals")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/totals"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/totals")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/:cartId/totals")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/:cartId/totals');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/:cartId/totals'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/totals';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:cartId/totals',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/totals")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/totals',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/:cartId/totals'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/:cartId/totals');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/:cartId/totals'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/totals';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/totals"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/:cartId/totals" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/totals",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/:cartId/totals');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/totals');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/:cartId/totals');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/totals' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/totals' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/:cartId/totals")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/totals"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/totals"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/totals")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/:cartId/totals') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/totals";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/:cartId/totals
http GET {{baseUrl}}/V1/carts/:cartId/totals
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/totals
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/totals")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-{cartId}-totals-information
{{baseUrl}}/V1/carts/:cartId/totals-information
QUERY PARAMS

cartId
BODY json

{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:cartId/totals-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/:cartId/totals-information" {:content-type :json
                                                                                :form-params {:addressInformation {:address {:city ""
                                                                                                                             :company ""
                                                                                                                             :country_id ""
                                                                                                                             :custom_attributes [{:attribute_code ""
                                                                                                                                                  :value ""}]
                                                                                                                             :customer_address_id 0
                                                                                                                             :customer_id 0
                                                                                                                             :email ""
                                                                                                                             :extension_attributes {:checkout_fields [{}]
                                                                                                                                                    :gift_registry_id 0}
                                                                                                                             :fax ""
                                                                                                                             :firstname ""
                                                                                                                             :id 0
                                                                                                                             :lastname ""
                                                                                                                             :middlename ""
                                                                                                                             :postcode ""
                                                                                                                             :prefix ""
                                                                                                                             :region ""
                                                                                                                             :region_code ""
                                                                                                                             :region_id 0
                                                                                                                             :same_as_billing 0
                                                                                                                             :save_in_address_book 0
                                                                                                                             :street []
                                                                                                                             :suffix ""
                                                                                                                             :telephone ""
                                                                                                                             :vat_id ""}
                                                                                                                   :custom_attributes [{}]
                                                                                                                   :extension_attributes {}
                                                                                                                   :shipping_carrier_code ""
                                                                                                                   :shipping_method_code ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/:cartId/totals-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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}}/V1/carts/:cartId/totals-information"),
    Content = new StringContent("{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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}}/V1/carts/:cartId/totals-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:cartId/totals-information"

	payload := strings.NewReader("{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/:cartId/totals-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 923

{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/:cartId/totals-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:cartId/totals-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/totals-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/:cartId/totals-information")
  .header("content-type", "application/json")
  .body("{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  addressInformation: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [
      {}
    ],
    extension_attributes: {},
    shipping_carrier_code: '',
    shipping_method_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}}/V1/carts/:cartId/totals-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/:cartId/totals-information',
  headers: {'content-type': 'application/json'},
  data: {
    addressInformation: {
      address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_carrier_code: '',
      shipping_method_code: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:cartId/totals-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressInformation":{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"custom_attributes":[{}],"extension_attributes":{},"shipping_carrier_code":"","shipping_method_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}}/V1/carts/:cartId/totals-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "addressInformation": {\n    "address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "custom_attributes": [\n      {}\n    ],\n    "extension_attributes": {},\n    "shipping_carrier_code": "",\n    "shipping_method_code": ""\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  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:cartId/totals-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:cartId/totals-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  addressInformation: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [{}],
    extension_attributes: {},
    shipping_carrier_code: '',
    shipping_method_code: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/:cartId/totals-information',
  headers: {'content-type': 'application/json'},
  body: {
    addressInformation: {
      address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_carrier_code: '',
      shipping_method_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}}/V1/carts/:cartId/totals-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  addressInformation: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [
      {}
    ],
    extension_attributes: {},
    shipping_carrier_code: '',
    shipping_method_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}}/V1/carts/:cartId/totals-information',
  headers: {'content-type': 'application/json'},
  data: {
    addressInformation: {
      address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_carrier_code: '',
      shipping_method_code: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:cartId/totals-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressInformation":{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"custom_attributes":[{}],"extension_attributes":{},"shipping_carrier_code":"","shipping_method_code":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"addressInformation": @{ @"address": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" }, @"custom_attributes": @[ @{  } ], @"extension_attributes": @{  }, @"shipping_carrier_code": @"", @"shipping_method_code": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:cartId/totals-information"]
                                                       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}}/V1/carts/:cartId/totals-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:cartId/totals-information",
  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([
    'addressInformation' => [
        'address' => [
                'city' => '',
                'company' => '',
                'country_id' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_address_id' => 0,
                'customer_id' => 0,
                'email' => '',
                'extension_attributes' => [
                                'checkout_fields' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'gift_registry_id' => 0
                ],
                'fax' => '',
                'firstname' => '',
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'postcode' => '',
                'prefix' => '',
                'region' => '',
                'region_code' => '',
                'region_id' => 0,
                'same_as_billing' => 0,
                'save_in_address_book' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => ''
        ],
        'custom_attributes' => [
                [
                                
                ]
        ],
        'extension_attributes' => [
                
        ],
        'shipping_carrier_code' => '',
        'shipping_method_code' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/:cartId/totals-information', [
  'body' => '{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:cartId/totals-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'addressInformation' => [
    'address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'extension_attributes' => [
        
    ],
    'shipping_carrier_code' => '',
    'shipping_method_code' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'addressInformation' => [
    'address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'extension_attributes' => [
        
    ],
    'shipping_carrier_code' => '',
    'shipping_method_code' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/:cartId/totals-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:cartId/totals-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:cartId/totals-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/:cartId/totals-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:cartId/totals-information"

payload = { "addressInformation": {
        "address": {
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": [
                {
                    "attribute_code": "",
                    "value": ""
                }
            ],
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": {
                "checkout_fields": [{}],
                "gift_registry_id": 0
            },
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": [],
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        },
        "custom_attributes": [{}],
        "extension_attributes": {},
        "shipping_carrier_code": "",
        "shipping_method_code": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:cartId/totals-information"

payload <- "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:cartId/totals-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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/V1/carts/:cartId/totals-information') do |req|
  req.body = "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:cartId/totals-information";

    let payload = json!({"addressInformation": json!({
            "address": json!({
                "city": "",
                "company": "",
                "country_id": "",
                "custom_attributes": (
                    json!({
                        "attribute_code": "",
                        "value": ""
                    })
                ),
                "customer_address_id": 0,
                "customer_id": 0,
                "email": "",
                "extension_attributes": json!({
                    "checkout_fields": (json!({})),
                    "gift_registry_id": 0
                }),
                "fax": "",
                "firstname": "",
                "id": 0,
                "lastname": "",
                "middlename": "",
                "postcode": "",
                "prefix": "",
                "region": "",
                "region_code": "",
                "region_id": 0,
                "same_as_billing": 0,
                "save_in_address_book": 0,
                "street": (),
                "suffix": "",
                "telephone": "",
                "vat_id": ""
            }),
            "custom_attributes": (json!({})),
            "extension_attributes": json!({}),
            "shipping_carrier_code": "",
            "shipping_method_code": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/:cartId/totals-information \
  --header 'content-type: application/json' \
  --data '{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
echo '{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/carts/:cartId/totals-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "addressInformation": {\n    "address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "custom_attributes": [\n      {}\n    ],\n    "extension_attributes": {},\n    "shipping_carrier_code": "",\n    "shipping_method_code": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/:cartId/totals-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["addressInformation": [
    "address": [
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        [
          "attribute_code": "",
          "value": ""
        ]
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": [
        "checkout_fields": [[]],
        "gift_registry_id": 0
      ],
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    ],
    "custom_attributes": [[]],
    "extension_attributes": [],
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:cartId/totals-information")! 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 carts-{quoteId}-giftCards
{{baseUrl}}/V1/carts/:quoteId/giftCards
QUERY PARAMS

quoteId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:quoteId/giftCards");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/:quoteId/giftCards")
require "http/client"

url = "{{baseUrl}}/V1/carts/:quoteId/giftCards"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/:quoteId/giftCards"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/:quoteId/giftCards");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:quoteId/giftCards"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/:quoteId/giftCards HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/:quoteId/giftCards")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:quoteId/giftCards"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:quoteId/giftCards")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/:quoteId/giftCards")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/:quoteId/giftCards');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/:quoteId/giftCards'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:quoteId/giftCards';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:quoteId/giftCards',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:quoteId/giftCards")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:quoteId/giftCards',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/:quoteId/giftCards'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/:quoteId/giftCards');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/:quoteId/giftCards'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:quoteId/giftCards';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:quoteId/giftCards"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/:quoteId/giftCards" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:quoteId/giftCards",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/:quoteId/giftCards');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:quoteId/giftCards');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/:quoteId/giftCards');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:quoteId/giftCards' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:quoteId/giftCards' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/:quoteId/giftCards")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:quoteId/giftCards"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:quoteId/giftCards"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:quoteId/giftCards")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/:quoteId/giftCards') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:quoteId/giftCards";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/:quoteId/giftCards
http GET {{baseUrl}}/V1/carts/:quoteId/giftCards
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/:quoteId/giftCards
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:quoteId/giftCards")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-{quoteId}-items
{{baseUrl}}/V1/carts/:quoteId/items
QUERY PARAMS

quoteId
BODY json

{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/:quoteId/items");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/:quoteId/items" {:content-type :json
                                                                    :form-params {:cartItem {:extension_attributes {:negotiable_quote_item {:extension_attributes {}
                                                                                                                                            :item_id 0
                                                                                                                                            :original_discount_amount ""
                                                                                                                                            :original_price ""
                                                                                                                                            :original_tax_amount ""}}
                                                                                             :item_id 0
                                                                                             :name ""
                                                                                             :price ""
                                                                                             :product_option {:extension_attributes {:bundle_options [{:extension_attributes {}
                                                                                                                                                       :option_id 0
                                                                                                                                                       :option_qty 0
                                                                                                                                                       :option_selections []}]
                                                                                                                                     :configurable_item_options [{:extension_attributes {}
                                                                                                                                                                  :option_id ""
                                                                                                                                                                  :option_value 0}]
                                                                                                                                     :custom_options [{:extension_attributes {:file_info {:base64_encoded_data ""
                                                                                                                                                                                          :name ""
                                                                                                                                                                                          :type ""}}
                                                                                                                                                       :option_id ""
                                                                                                                                                       :option_value ""}]
                                                                                                                                     :downloadable_option {:downloadable_links []}
                                                                                                                                     :giftcard_item_option {:custom_giftcard_amount ""
                                                                                                                                                            :extension_attributes {}
                                                                                                                                                            :giftcard_amount ""
                                                                                                                                                            :giftcard_message ""
                                                                                                                                                            :giftcard_recipient_email ""
                                                                                                                                                            :giftcard_recipient_name ""
                                                                                                                                                            :giftcard_sender_email ""
                                                                                                                                                            :giftcard_sender_name ""}}}
                                                                                             :product_type ""
                                                                                             :qty ""
                                                                                             :quote_id ""
                                                                                             :sku ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/:quoteId/items"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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}}/V1/carts/:quoteId/items"),
    Content = new StringContent("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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}}/V1/carts/:quoteId/items");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/:quoteId/items"

	payload := strings.NewReader("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/:quoteId/items HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1573

{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/:quoteId/items")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/:quoteId/items"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/:quoteId/items")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/:quoteId/items")
  .header("content-type", "application/json")
  .body("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [
          {
            extension_attributes: {},
            option_id: 0,
            option_qty: 0,
            option_selections: []
          }
        ],
        configurable_item_options: [
          {
            extension_attributes: {},
            option_id: '',
            option_value: 0
          }
        ],
        custom_options: [
          {
            extension_attributes: {
              file_info: {
                base64_encoded_data: '',
                name: '',
                type: ''
              }
            },
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {
          downloadable_links: []
        },
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/carts/:quoteId/items');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/:quoteId/items',
  headers: {'content-type': 'application/json'},
  data: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/:quoteId/items';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"cartItem":{"extension_attributes":{"negotiable_quote_item":{"extension_attributes":{},"item_id":0,"original_discount_amount":"","original_price":"","original_tax_amount":""}},"item_id":0,"name":"","price":"","product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty":"","quote_id":"","sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/:quoteId/items',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "cartItem": {\n    "extension_attributes": {\n      "negotiable_quote_item": {\n        "extension_attributes": {},\n        "item_id": 0,\n        "original_discount_amount": "",\n        "original_price": "",\n        "original_tax_amount": ""\n      }\n    },\n    "item_id": 0,\n    "name": "",\n    "price": "",\n    "product_option": {\n      "extension_attributes": {\n        "bundle_options": [\n          {\n            "extension_attributes": {},\n            "option_id": 0,\n            "option_qty": 0,\n            "option_selections": []\n          }\n        ],\n        "configurable_item_options": [\n          {\n            "extension_attributes": {},\n            "option_id": "",\n            "option_value": 0\n          }\n        ],\n        "custom_options": [\n          {\n            "extension_attributes": {\n              "file_info": {\n                "base64_encoded_data": "",\n                "name": "",\n                "type": ""\n              }\n            },\n            "option_id": "",\n            "option_value": ""\n          }\n        ],\n        "downloadable_option": {\n          "downloadable_links": []\n        },\n        "giftcard_item_option": {\n          "custom_giftcard_amount": "",\n          "extension_attributes": {},\n          "giftcard_amount": "",\n          "giftcard_message": "",\n          "giftcard_recipient_email": "",\n          "giftcard_recipient_name": "",\n          "giftcard_sender_email": "",\n          "giftcard_sender_name": ""\n        }\n      }\n    },\n    "product_type": "",\n    "qty": "",\n    "quote_id": "",\n    "sku": ""\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  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/:quoteId/items")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/:quoteId/items',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
        configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
        custom_options: [
          {
            extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {downloadable_links: []},
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/:quoteId/items',
  headers: {'content-type': 'application/json'},
  body: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  },
  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}}/V1/carts/:quoteId/items');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [
          {
            extension_attributes: {},
            option_id: 0,
            option_qty: 0,
            option_selections: []
          }
        ],
        configurable_item_options: [
          {
            extension_attributes: {},
            option_id: '',
            option_value: 0
          }
        ],
        custom_options: [
          {
            extension_attributes: {
              file_info: {
                base64_encoded_data: '',
                name: '',
                type: ''
              }
            },
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {
          downloadable_links: []
        },
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
});

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}}/V1/carts/:quoteId/items',
  headers: {'content-type': 'application/json'},
  data: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/:quoteId/items';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"cartItem":{"extension_attributes":{"negotiable_quote_item":{"extension_attributes":{},"item_id":0,"original_discount_amount":"","original_price":"","original_tax_amount":""}},"item_id":0,"name":"","price":"","product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty":"","quote_id":"","sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"cartItem": @{ @"extension_attributes": @{ @"negotiable_quote_item": @{ @"extension_attributes": @{  }, @"item_id": @0, @"original_discount_amount": @"", @"original_price": @"", @"original_tax_amount": @"" } }, @"item_id": @0, @"name": @"", @"price": @"", @"product_option": @{ @"extension_attributes": @{ @"bundle_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @0, @"option_qty": @0, @"option_selections": @[  ] } ], @"configurable_item_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @"", @"option_value": @0 } ], @"custom_options": @[ @{ @"extension_attributes": @{ @"file_info": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" } }, @"option_id": @"", @"option_value": @"" } ], @"downloadable_option": @{ @"downloadable_links": @[  ] }, @"giftcard_item_option": @{ @"custom_giftcard_amount": @"", @"extension_attributes": @{  }, @"giftcard_amount": @"", @"giftcard_message": @"", @"giftcard_recipient_email": @"", @"giftcard_recipient_name": @"", @"giftcard_sender_email": @"", @"giftcard_sender_name": @"" } } }, @"product_type": @"", @"qty": @"", @"quote_id": @"", @"sku": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/:quoteId/items"]
                                                       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}}/V1/carts/:quoteId/items" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/:quoteId/items",
  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([
    'cartItem' => [
        'extension_attributes' => [
                'negotiable_quote_item' => [
                                'extension_attributes' => [
                                                                
                                ],
                                'item_id' => 0,
                                'original_discount_amount' => '',
                                'original_price' => '',
                                'original_tax_amount' => ''
                ]
        ],
        'item_id' => 0,
        'name' => '',
        'price' => '',
        'product_option' => [
                'extension_attributes' => [
                                'bundle_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'option_id' => 0,
                                                                                                                                'option_qty' => 0,
                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'configurable_item_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'option_id' => '',
                                                                                                                                'option_value' => 0
                                                                ]
                                ],
                                'custom_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'option_id' => '',
                                                                                                                                'option_value' => ''
                                                                ]
                                ],
                                'downloadable_option' => [
                                                                'downloadable_links' => [
                                                                                                                                
                                                                ]
                                ],
                                'giftcard_item_option' => [
                                                                'custom_giftcard_amount' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'giftcard_amount' => '',
                                                                'giftcard_message' => '',
                                                                'giftcard_recipient_email' => '',
                                                                'giftcard_recipient_name' => '',
                                                                'giftcard_sender_email' => '',
                                                                'giftcard_sender_name' => ''
                                ]
                ]
        ],
        'product_type' => '',
        'qty' => '',
        'quote_id' => '',
        'sku' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/:quoteId/items', [
  'body' => '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/:quoteId/items');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'cartItem' => [
    'extension_attributes' => [
        'negotiable_quote_item' => [
                'extension_attributes' => [
                                
                ],
                'item_id' => 0,
                'original_discount_amount' => '',
                'original_price' => '',
                'original_tax_amount' => ''
        ]
    ],
    'item_id' => 0,
    'name' => '',
    'price' => '',
    'product_option' => [
        'extension_attributes' => [
                'bundle_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'option_qty' => 0,
                                                                'option_selections' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'configurable_item_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => 0
                                ]
                ],
                'custom_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ]
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => ''
                                ]
                ],
                'downloadable_option' => [
                                'downloadable_links' => [
                                                                
                                ]
                ],
                'giftcard_item_option' => [
                                'custom_giftcard_amount' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'giftcard_amount' => '',
                                'giftcard_message' => '',
                                'giftcard_recipient_email' => '',
                                'giftcard_recipient_name' => '',
                                'giftcard_sender_email' => '',
                                'giftcard_sender_name' => ''
                ]
        ]
    ],
    'product_type' => '',
    'qty' => '',
    'quote_id' => '',
    'sku' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'cartItem' => [
    'extension_attributes' => [
        'negotiable_quote_item' => [
                'extension_attributes' => [
                                
                ],
                'item_id' => 0,
                'original_discount_amount' => '',
                'original_price' => '',
                'original_tax_amount' => ''
        ]
    ],
    'item_id' => 0,
    'name' => '',
    'price' => '',
    'product_option' => [
        'extension_attributes' => [
                'bundle_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'option_qty' => 0,
                                                                'option_selections' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'configurable_item_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => 0
                                ]
                ],
                'custom_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ]
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => ''
                                ]
                ],
                'downloadable_option' => [
                                'downloadable_links' => [
                                                                
                                ]
                ],
                'giftcard_item_option' => [
                                'custom_giftcard_amount' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'giftcard_amount' => '',
                                'giftcard_message' => '',
                                'giftcard_recipient_email' => '',
                                'giftcard_recipient_name' => '',
                                'giftcard_sender_email' => '',
                                'giftcard_sender_name' => ''
                ]
        ]
    ],
    'product_type' => '',
    'qty' => '',
    'quote_id' => '',
    'sku' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/:quoteId/items');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/:quoteId/items' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/:quoteId/items' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/:quoteId/items", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/:quoteId/items"

payload = { "cartItem": {
        "extension_attributes": { "negotiable_quote_item": {
                "extension_attributes": {},
                "item_id": 0,
                "original_discount_amount": "",
                "original_price": "",
                "original_tax_amount": ""
            } },
        "item_id": 0,
        "name": "",
        "price": "",
        "product_option": { "extension_attributes": {
                "bundle_options": [
                    {
                        "extension_attributes": {},
                        "option_id": 0,
                        "option_qty": 0,
                        "option_selections": []
                    }
                ],
                "configurable_item_options": [
                    {
                        "extension_attributes": {},
                        "option_id": "",
                        "option_value": 0
                    }
                ],
                "custom_options": [
                    {
                        "extension_attributes": { "file_info": {
                                "base64_encoded_data": "",
                                "name": "",
                                "type": ""
                            } },
                        "option_id": "",
                        "option_value": ""
                    }
                ],
                "downloadable_option": { "downloadable_links": [] },
                "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                }
            } },
        "product_type": "",
        "qty": "",
        "quote_id": "",
        "sku": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/:quoteId/items"

payload <- "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/:quoteId/items")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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/V1/carts/:quoteId/items') do |req|
  req.body = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/:quoteId/items";

    let payload = json!({"cartItem": json!({
            "extension_attributes": json!({"negotiable_quote_item": json!({
                    "extension_attributes": json!({}),
                    "item_id": 0,
                    "original_discount_amount": "",
                    "original_price": "",
                    "original_tax_amount": ""
                })}),
            "item_id": 0,
            "name": "",
            "price": "",
            "product_option": json!({"extension_attributes": json!({
                    "bundle_options": (
                        json!({
                            "extension_attributes": json!({}),
                            "option_id": 0,
                            "option_qty": 0,
                            "option_selections": ()
                        })
                    ),
                    "configurable_item_options": (
                        json!({
                            "extension_attributes": json!({}),
                            "option_id": "",
                            "option_value": 0
                        })
                    ),
                    "custom_options": (
                        json!({
                            "extension_attributes": json!({"file_info": json!({
                                    "base64_encoded_data": "",
                                    "name": "",
                                    "type": ""
                                })}),
                            "option_id": "",
                            "option_value": ""
                        })
                    ),
                    "downloadable_option": json!({"downloadable_links": ()}),
                    "giftcard_item_option": json!({
                        "custom_giftcard_amount": "",
                        "extension_attributes": json!({}),
                        "giftcard_amount": "",
                        "giftcard_message": "",
                        "giftcard_recipient_email": "",
                        "giftcard_recipient_name": "",
                        "giftcard_sender_email": "",
                        "giftcard_sender_name": ""
                    })
                })}),
            "product_type": "",
            "qty": "",
            "quote_id": "",
            "sku": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/:quoteId/items \
  --header 'content-type: application/json' \
  --data '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
echo '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/carts/:quoteId/items \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "cartItem": {\n    "extension_attributes": {\n      "negotiable_quote_item": {\n        "extension_attributes": {},\n        "item_id": 0,\n        "original_discount_amount": "",\n        "original_price": "",\n        "original_tax_amount": ""\n      }\n    },\n    "item_id": 0,\n    "name": "",\n    "price": "",\n    "product_option": {\n      "extension_attributes": {\n        "bundle_options": [\n          {\n            "extension_attributes": {},\n            "option_id": 0,\n            "option_qty": 0,\n            "option_selections": []\n          }\n        ],\n        "configurable_item_options": [\n          {\n            "extension_attributes": {},\n            "option_id": "",\n            "option_value": 0\n          }\n        ],\n        "custom_options": [\n          {\n            "extension_attributes": {\n              "file_info": {\n                "base64_encoded_data": "",\n                "name": "",\n                "type": ""\n              }\n            },\n            "option_id": "",\n            "option_value": ""\n          }\n        ],\n        "downloadable_option": {\n          "downloadable_links": []\n        },\n        "giftcard_item_option": {\n          "custom_giftcard_amount": "",\n          "extension_attributes": {},\n          "giftcard_amount": "",\n          "giftcard_message": "",\n          "giftcard_recipient_email": "",\n          "giftcard_recipient_name": "",\n          "giftcard_sender_email": "",\n          "giftcard_sender_name": ""\n        }\n      }\n    },\n    "product_type": "",\n    "qty": "",\n    "quote_id": "",\n    "sku": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/:quoteId/items
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["cartItem": [
    "extension_attributes": ["negotiable_quote_item": [
        "extension_attributes": [],
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      ]],
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": ["extension_attributes": [
        "bundle_options": [
          [
            "extension_attributes": [],
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          ]
        ],
        "configurable_item_options": [
          [
            "extension_attributes": [],
            "option_id": "",
            "option_value": 0
          ]
        ],
        "custom_options": [
          [
            "extension_attributes": ["file_info": [
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              ]],
            "option_id": "",
            "option_value": ""
          ]
        ],
        "downloadable_option": ["downloadable_links": []],
        "giftcard_item_option": [
          "custom_giftcard_amount": "",
          "extension_attributes": [],
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        ]
      ]],
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/:quoteId/items")! 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 carts-guest-carts-{cartId}-checkGiftCard-{giftCardCode}
{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode
QUERY PARAMS

cartId
giftCardCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode")
require "http/client"

url = "{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode
http GET {{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/guest-carts/:cartId/checkGiftCard/:giftCardCode")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-guest-carts-{cartId}-giftCards
{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards
QUERY PARAMS

cartId
BODY json

{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards" {:content-type :json
                                                                                   :form-params {:giftCardAccountData {:base_gift_cards_amount ""
                                                                                                                       :base_gift_cards_amount_used ""
                                                                                                                       :extension_attributes {}
                                                                                                                       :gift_cards []
                                                                                                                       :gift_cards_amount ""
                                                                                                                       :gift_cards_amount_used ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\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}}/V1/carts/guest-carts/:cartId/giftCards"),
    Content = new StringContent("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\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}}/V1/carts/guest-carts/:cartId/giftCards");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards"

	payload := strings.NewReader("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/guest-carts/:cartId/giftCards HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 223

{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\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  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards")
  .header("content-type", "application/json")
  .body("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  giftCardAccountData: {
    base_gift_cards_amount: '',
    base_gift_cards_amount_used: '',
    extension_attributes: {},
    gift_cards: [],
    gift_cards_amount: '',
    gift_cards_amount_used: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards',
  headers: {'content-type': 'application/json'},
  data: {
    giftCardAccountData: {
      base_gift_cards_amount: '',
      base_gift_cards_amount_used: '',
      extension_attributes: {},
      gift_cards: [],
      gift_cards_amount: '',
      gift_cards_amount_used: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftCardAccountData":{"base_gift_cards_amount":"","base_gift_cards_amount_used":"","extension_attributes":{},"gift_cards":[],"gift_cards_amount":"","gift_cards_amount_used":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "giftCardAccountData": {\n    "base_gift_cards_amount": "",\n    "base_gift_cards_amount_used": "",\n    "extension_attributes": {},\n    "gift_cards": [],\n    "gift_cards_amount": "",\n    "gift_cards_amount_used": ""\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  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/guest-carts/:cartId/giftCards',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  giftCardAccountData: {
    base_gift_cards_amount: '',
    base_gift_cards_amount_used: '',
    extension_attributes: {},
    gift_cards: [],
    gift_cards_amount: '',
    gift_cards_amount_used: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards',
  headers: {'content-type': 'application/json'},
  body: {
    giftCardAccountData: {
      base_gift_cards_amount: '',
      base_gift_cards_amount_used: '',
      extension_attributes: {},
      gift_cards: [],
      gift_cards_amount: '',
      gift_cards_amount_used: ''
    }
  },
  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}}/V1/carts/guest-carts/:cartId/giftCards');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  giftCardAccountData: {
    base_gift_cards_amount: '',
    base_gift_cards_amount_used: '',
    extension_attributes: {},
    gift_cards: [],
    gift_cards_amount: '',
    gift_cards_amount_used: ''
  }
});

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}}/V1/carts/guest-carts/:cartId/giftCards',
  headers: {'content-type': 'application/json'},
  data: {
    giftCardAccountData: {
      base_gift_cards_amount: '',
      base_gift_cards_amount_used: '',
      extension_attributes: {},
      gift_cards: [],
      gift_cards_amount: '',
      gift_cards_amount_used: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftCardAccountData":{"base_gift_cards_amount":"","base_gift_cards_amount_used":"","extension_attributes":{},"gift_cards":[],"gift_cards_amount":"","gift_cards_amount_used":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"giftCardAccountData": @{ @"base_gift_cards_amount": @"", @"base_gift_cards_amount_used": @"", @"extension_attributes": @{  }, @"gift_cards": @[  ], @"gift_cards_amount": @"", @"gift_cards_amount_used": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards"]
                                                       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}}/V1/carts/guest-carts/:cartId/giftCards" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards",
  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([
    'giftCardAccountData' => [
        'base_gift_cards_amount' => '',
        'base_gift_cards_amount_used' => '',
        'extension_attributes' => [
                
        ],
        'gift_cards' => [
                
        ],
        'gift_cards_amount' => '',
        'gift_cards_amount_used' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards', [
  'body' => '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'giftCardAccountData' => [
    'base_gift_cards_amount' => '',
    'base_gift_cards_amount_used' => '',
    'extension_attributes' => [
        
    ],
    'gift_cards' => [
        
    ],
    'gift_cards_amount' => '',
    'gift_cards_amount_used' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'giftCardAccountData' => [
    'base_gift_cards_amount' => '',
    'base_gift_cards_amount_used' => '',
    'extension_attributes' => [
        
    ],
    'gift_cards' => [
        
    ],
    'gift_cards_amount' => '',
    'gift_cards_amount_used' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/guest-carts/:cartId/giftCards", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards"

payload = { "giftCardAccountData": {
        "base_gift_cards_amount": "",
        "base_gift_cards_amount_used": "",
        "extension_attributes": {},
        "gift_cards": [],
        "gift_cards_amount": "",
        "gift_cards_amount_used": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards"

payload <- "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\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/V1/carts/guest-carts/:cartId/giftCards') do |req|
  req.body = "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards";

    let payload = json!({"giftCardAccountData": json!({
            "base_gift_cards_amount": "",
            "base_gift_cards_amount_used": "",
            "extension_attributes": json!({}),
            "gift_cards": (),
            "gift_cards_amount": "",
            "gift_cards_amount_used": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards \
  --header 'content-type: application/json' \
  --data '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}'
echo '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "giftCardAccountData": {\n    "base_gift_cards_amount": "",\n    "base_gift_cards_amount_used": "",\n    "extension_attributes": {},\n    "gift_cards": [],\n    "gift_cards_amount": "",\n    "gift_cards_amount_used": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["giftCardAccountData": [
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": [],
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards")! 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 carts-guest-carts-{cartId}-giftCards-{giftCardCode}
{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode
QUERY PARAMS

cartId
giftCardCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode")
require "http/client"

url = "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode"))
    .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}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode")
  .asString();
const 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}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode');

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}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode
http DELETE {{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/guest-carts/:cartId/giftCards/:giftCardCode")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET carts-licence
{{baseUrl}}/V1/carts/licence
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/licence");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/licence")
require "http/client"

url = "{{baseUrl}}/V1/carts/licence"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/licence"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/licence");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/licence"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/licence HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/licence")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/licence"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/licence")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/licence")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/licence');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/licence'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/licence';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/licence',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/licence")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/licence',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/licence'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/licence');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/licence'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/licence';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/licence"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/licence" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/licence",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/licence');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/licence');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/licence');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/licence' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/licence' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/licence")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/licence"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/licence"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/licence")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/licence') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/licence";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/licence
http GET {{baseUrl}}/V1/carts/licence
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/licence
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/licence")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-mine (POST)
{{baseUrl}}/V1/carts/mine
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/mine")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/mine HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/mine")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine"))
    .method("POST", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/mine")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/carts/mine');

xhr.send(data);
import axios from 'axios';

const options = {method: 'POST', url: '{{baseUrl}}/V1/carts/mine'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'POST', url: '{{baseUrl}}/V1/carts/mine'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/carts/mine');

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}}/V1/carts/mine'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/mine');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/V1/carts/mine")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/V1/carts/mine') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/mine
http POST {{baseUrl}}/V1/carts/mine
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/V1/carts/mine
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT carts-mine (PUT)
{{baseUrl}}/V1/carts/mine
BODY json

{
  "quote": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "converted_at": "",
    "created_at": "",
    "currency": {
      "base_currency_code": "",
      "base_to_global_rate": "",
      "base_to_quote_rate": "",
      "extension_attributes": {},
      "global_currency_code": "",
      "quote_currency_code": "",
      "store_currency_code": "",
      "store_to_base_rate": "",
      "store_to_quote_rate": ""
    },
    "customer": {
      "addresses": [
        {
          "city": "",
          "company": "",
          "country_id": "",
          "custom_attributes": [
            {}
          ],
          "customer_id": 0,
          "default_billing": false,
          "default_shipping": false,
          "extension_attributes": {},
          "fax": "",
          "firstname": "",
          "id": 0,
          "lastname": "",
          "middlename": "",
          "postcode": "",
          "prefix": "",
          "region": {
            "extension_attributes": {},
            "region": "",
            "region_code": "",
            "region_id": 0
          },
          "region_id": 0,
          "street": [],
          "suffix": "",
          "telephone": "",
          "vat_id": ""
        }
      ],
      "confirmation": "",
      "created_at": "",
      "created_in": "",
      "custom_attributes": [
        {}
      ],
      "default_billing": "",
      "default_shipping": "",
      "disable_auto_group_change": 0,
      "dob": "",
      "email": "",
      "extension_attributes": {
        "amazon_id": "",
        "company_attributes": {
          "company_id": 0,
          "customer_id": 0,
          "extension_attributes": {},
          "job_title": "",
          "status": 0,
          "telephone": ""
        },
        "is_subscribed": false,
        "vertex_customer_code": ""
      },
      "firstname": "",
      "gender": 0,
      "group_id": 0,
      "id": 0,
      "lastname": "",
      "middlename": "",
      "prefix": "",
      "store_id": 0,
      "suffix": "",
      "taxvat": "",
      "updated_at": "",
      "website_id": 0
    },
    "customer_is_guest": false,
    "customer_note": "",
    "customer_note_notify": false,
    "customer_tax_class_id": 0,
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "negotiable_quote": {
        "applied_rule_ids": "",
        "base_negotiated_total_price": "",
        "base_original_total_price": "",
        "creator_id": 0,
        "creator_type": 0,
        "deleted_sku": "",
        "email_notification_status": 0,
        "expiration_period": "",
        "extension_attributes": {},
        "has_unconfirmed_changes": false,
        "is_address_draft": false,
        "is_customer_price_changed": false,
        "is_regular_quote": false,
        "is_shipping_tax_changed": false,
        "negotiated_price_type": 0,
        "negotiated_price_value": "",
        "negotiated_total_price": "",
        "notifications": 0,
        "original_total_price": "",
        "quote_id": 0,
        "quote_name": "",
        "shipping_price": "",
        "status": ""
      },
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "extension_attributes": {
                "negotiable_quote_item": {
                  "extension_attributes": {},
                  "item_id": 0,
                  "original_discount_amount": "",
                  "original_price": "",
                  "original_tax_amount": ""
                }
              },
              "item_id": 0,
              "name": "",
              "price": "",
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty": "",
              "quote_id": "",
              "sku": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {},
            "method": ""
          }
        }
      ]
    },
    "id": 0,
    "is_active": false,
    "is_virtual": false,
    "items": [
      {}
    ],
    "items_count": 0,
    "items_qty": "",
    "orig_order_id": 0,
    "reserved_order_id": "",
    "store_id": 0,
    "updated_at": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/carts/mine" {:content-type :json
                                                         :form-params {:quote {:billing_address {:city ""
                                                                                                 :company ""
                                                                                                 :country_id ""
                                                                                                 :custom_attributes [{:attribute_code ""
                                                                                                                      :value ""}]
                                                                                                 :customer_address_id 0
                                                                                                 :customer_id 0
                                                                                                 :email ""
                                                                                                 :extension_attributes {:checkout_fields [{}]
                                                                                                                        :gift_registry_id 0}
                                                                                                 :fax ""
                                                                                                 :firstname ""
                                                                                                 :id 0
                                                                                                 :lastname ""
                                                                                                 :middlename ""
                                                                                                 :postcode ""
                                                                                                 :prefix ""
                                                                                                 :region ""
                                                                                                 :region_code ""
                                                                                                 :region_id 0
                                                                                                 :same_as_billing 0
                                                                                                 :save_in_address_book 0
                                                                                                 :street []
                                                                                                 :suffix ""
                                                                                                 :telephone ""
                                                                                                 :vat_id ""}
                                                                               :converted_at ""
                                                                               :created_at ""
                                                                               :currency {:base_currency_code ""
                                                                                          :base_to_global_rate ""
                                                                                          :base_to_quote_rate ""
                                                                                          :extension_attributes {}
                                                                                          :global_currency_code ""
                                                                                          :quote_currency_code ""
                                                                                          :store_currency_code ""
                                                                                          :store_to_base_rate ""
                                                                                          :store_to_quote_rate ""}
                                                                               :customer {:addresses [{:city ""
                                                                                                       :company ""
                                                                                                       :country_id ""
                                                                                                       :custom_attributes [{}]
                                                                                                       :customer_id 0
                                                                                                       :default_billing false
                                                                                                       :default_shipping false
                                                                                                       :extension_attributes {}
                                                                                                       :fax ""
                                                                                                       :firstname ""
                                                                                                       :id 0
                                                                                                       :lastname ""
                                                                                                       :middlename ""
                                                                                                       :postcode ""
                                                                                                       :prefix ""
                                                                                                       :region {:extension_attributes {}
                                                                                                                :region ""
                                                                                                                :region_code ""
                                                                                                                :region_id 0}
                                                                                                       :region_id 0
                                                                                                       :street []
                                                                                                       :suffix ""
                                                                                                       :telephone ""
                                                                                                       :vat_id ""}]
                                                                                          :confirmation ""
                                                                                          :created_at ""
                                                                                          :created_in ""
                                                                                          :custom_attributes [{}]
                                                                                          :default_billing ""
                                                                                          :default_shipping ""
                                                                                          :disable_auto_group_change 0
                                                                                          :dob ""
                                                                                          :email ""
                                                                                          :extension_attributes {:amazon_id ""
                                                                                                                 :company_attributes {:company_id 0
                                                                                                                                      :customer_id 0
                                                                                                                                      :extension_attributes {}
                                                                                                                                      :job_title ""
                                                                                                                                      :status 0
                                                                                                                                      :telephone ""}
                                                                                                                 :is_subscribed false
                                                                                                                 :vertex_customer_code ""}
                                                                                          :firstname ""
                                                                                          :gender 0
                                                                                          :group_id 0
                                                                                          :id 0
                                                                                          :lastname ""
                                                                                          :middlename ""
                                                                                          :prefix ""
                                                                                          :store_id 0
                                                                                          :suffix ""
                                                                                          :taxvat ""
                                                                                          :updated_at ""
                                                                                          :website_id 0}
                                                                               :customer_is_guest false
                                                                               :customer_note ""
                                                                               :customer_note_notify false
                                                                               :customer_tax_class_id 0
                                                                               :extension_attributes {:amazon_order_reference_id ""
                                                                                                      :negotiable_quote {:applied_rule_ids ""
                                                                                                                         :base_negotiated_total_price ""
                                                                                                                         :base_original_total_price ""
                                                                                                                         :creator_id 0
                                                                                                                         :creator_type 0
                                                                                                                         :deleted_sku ""
                                                                                                                         :email_notification_status 0
                                                                                                                         :expiration_period ""
                                                                                                                         :extension_attributes {}
                                                                                                                         :has_unconfirmed_changes false
                                                                                                                         :is_address_draft false
                                                                                                                         :is_customer_price_changed false
                                                                                                                         :is_regular_quote false
                                                                                                                         :is_shipping_tax_changed false
                                                                                                                         :negotiated_price_type 0
                                                                                                                         :negotiated_price_value ""
                                                                                                                         :negotiated_total_price ""
                                                                                                                         :notifications 0
                                                                                                                         :original_total_price ""
                                                                                                                         :quote_id 0
                                                                                                                         :quote_name ""
                                                                                                                         :shipping_price ""
                                                                                                                         :status ""}
                                                                                                      :shipping_assignments [{:extension_attributes {}
                                                                                                                              :items [{:extension_attributes {:negotiable_quote_item {:extension_attributes {}
                                                                                                                                                                                      :item_id 0
                                                                                                                                                                                      :original_discount_amount ""
                                                                                                                                                                                      :original_price ""
                                                                                                                                                                                      :original_tax_amount ""}}
                                                                                                                                       :item_id 0
                                                                                                                                       :name ""
                                                                                                                                       :price ""
                                                                                                                                       :product_option {:extension_attributes {:bundle_options [{:extension_attributes {}
                                                                                                                                                                                                 :option_id 0
                                                                                                                                                                                                 :option_qty 0
                                                                                                                                                                                                 :option_selections []}]
                                                                                                                                                                               :configurable_item_options [{:extension_attributes {}
                                                                                                                                                                                                            :option_id ""
                                                                                                                                                                                                            :option_value 0}]
                                                                                                                                                                               :custom_options [{:extension_attributes {:file_info {:base64_encoded_data ""
                                                                                                                                                                                                                                    :name ""
                                                                                                                                                                                                                                    :type ""}}
                                                                                                                                                                                                 :option_id ""
                                                                                                                                                                                                 :option_value ""}]
                                                                                                                                                                               :downloadable_option {:downloadable_links []}
                                                                                                                                                                               :giftcard_item_option {:custom_giftcard_amount ""
                                                                                                                                                                                                      :extension_attributes {}
                                                                                                                                                                                                      :giftcard_amount ""
                                                                                                                                                                                                      :giftcard_message ""
                                                                                                                                                                                                      :giftcard_recipient_email ""
                                                                                                                                                                                                      :giftcard_recipient_name ""
                                                                                                                                                                                                      :giftcard_sender_email ""
                                                                                                                                                                                                      :giftcard_sender_name ""}}}
                                                                                                                                       :product_type ""
                                                                                                                                       :qty ""
                                                                                                                                       :quote_id ""
                                                                                                                                       :sku ""}]
                                                                                                                              :shipping {:address {}
                                                                                                                                         :extension_attributes {}
                                                                                                                                         :method ""}}]}
                                                                               :id 0
                                                                               :is_active false
                                                                               :is_virtual false
                                                                               :items [{}]
                                                                               :items_count 0
                                                                               :items_qty ""
                                                                               :orig_order_id 0
                                                                               :reserved_order_id ""
                                                                               :store_id 0
                                                                               :updated_at ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\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}}/V1/carts/mine"),
    Content = new StringContent("{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\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}}/V1/carts/mine");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine"

	payload := strings.NewReader("{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/carts/mine HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 6493

{
  "quote": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "converted_at": "",
    "created_at": "",
    "currency": {
      "base_currency_code": "",
      "base_to_global_rate": "",
      "base_to_quote_rate": "",
      "extension_attributes": {},
      "global_currency_code": "",
      "quote_currency_code": "",
      "store_currency_code": "",
      "store_to_base_rate": "",
      "store_to_quote_rate": ""
    },
    "customer": {
      "addresses": [
        {
          "city": "",
          "company": "",
          "country_id": "",
          "custom_attributes": [
            {}
          ],
          "customer_id": 0,
          "default_billing": false,
          "default_shipping": false,
          "extension_attributes": {},
          "fax": "",
          "firstname": "",
          "id": 0,
          "lastname": "",
          "middlename": "",
          "postcode": "",
          "prefix": "",
          "region": {
            "extension_attributes": {},
            "region": "",
            "region_code": "",
            "region_id": 0
          },
          "region_id": 0,
          "street": [],
          "suffix": "",
          "telephone": "",
          "vat_id": ""
        }
      ],
      "confirmation": "",
      "created_at": "",
      "created_in": "",
      "custom_attributes": [
        {}
      ],
      "default_billing": "",
      "default_shipping": "",
      "disable_auto_group_change": 0,
      "dob": "",
      "email": "",
      "extension_attributes": {
        "amazon_id": "",
        "company_attributes": {
          "company_id": 0,
          "customer_id": 0,
          "extension_attributes": {},
          "job_title": "",
          "status": 0,
          "telephone": ""
        },
        "is_subscribed": false,
        "vertex_customer_code": ""
      },
      "firstname": "",
      "gender": 0,
      "group_id": 0,
      "id": 0,
      "lastname": "",
      "middlename": "",
      "prefix": "",
      "store_id": 0,
      "suffix": "",
      "taxvat": "",
      "updated_at": "",
      "website_id": 0
    },
    "customer_is_guest": false,
    "customer_note": "",
    "customer_note_notify": false,
    "customer_tax_class_id": 0,
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "negotiable_quote": {
        "applied_rule_ids": "",
        "base_negotiated_total_price": "",
        "base_original_total_price": "",
        "creator_id": 0,
        "creator_type": 0,
        "deleted_sku": "",
        "email_notification_status": 0,
        "expiration_period": "",
        "extension_attributes": {},
        "has_unconfirmed_changes": false,
        "is_address_draft": false,
        "is_customer_price_changed": false,
        "is_regular_quote": false,
        "is_shipping_tax_changed": false,
        "negotiated_price_type": 0,
        "negotiated_price_value": "",
        "negotiated_total_price": "",
        "notifications": 0,
        "original_total_price": "",
        "quote_id": 0,
        "quote_name": "",
        "shipping_price": "",
        "status": ""
      },
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "extension_attributes": {
                "negotiable_quote_item": {
                  "extension_attributes": {},
                  "item_id": 0,
                  "original_discount_amount": "",
                  "original_price": "",
                  "original_tax_amount": ""
                }
              },
              "item_id": 0,
              "name": "",
              "price": "",
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty": "",
              "quote_id": "",
              "sku": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {},
            "method": ""
          }
        }
      ]
    },
    "id": 0,
    "is_active": false,
    "is_virtual": false,
    "items": [
      {}
    ],
    "items_count": 0,
    "items_qty": "",
    "orig_order_id": 0,
    "reserved_order_id": "",
    "store_id": 0,
    "updated_at": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/carts/mine")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\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  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/carts/mine")
  .header("content-type", "application/json")
  .body("{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  quote: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    converted_at: '',
    created_at: '',
    currency: {
      base_currency_code: '',
      base_to_global_rate: '',
      base_to_quote_rate: '',
      extension_attributes: {},
      global_currency_code: '',
      quote_currency_code: '',
      store_currency_code: '',
      store_to_base_rate: '',
      store_to_quote_rate: ''
    },
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [
            {}
          ],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {
            extension_attributes: {},
            region: '',
            region_code: '',
            region_id: 0
          },
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [
        {}
      ],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_id: 0
    },
    customer_is_guest: false,
    customer_note: '',
    customer_note_notify: false,
    customer_tax_class_id: 0,
    extension_attributes: {
      amazon_order_reference_id: '',
      negotiable_quote: {
        applied_rule_ids: '',
        base_negotiated_total_price: '',
        base_original_total_price: '',
        creator_id: 0,
        creator_type: 0,
        deleted_sku: '',
        email_notification_status: 0,
        expiration_period: '',
        extension_attributes: {},
        has_unconfirmed_changes: false,
        is_address_draft: false,
        is_customer_price_changed: false,
        is_regular_quote: false,
        is_shipping_tax_changed: false,
        negotiated_price_type: 0,
        negotiated_price_value: '',
        negotiated_total_price: '',
        notifications: 0,
        original_total_price: '',
        quote_id: 0,
        quote_name: '',
        shipping_price: '',
        status: ''
      },
      shipping_assignments: [
        {
          extension_attributes: {},
          items: [
            {
              extension_attributes: {
                negotiable_quote_item: {
                  extension_attributes: {},
                  item_id: 0,
                  original_discount_amount: '',
                  original_price: '',
                  original_tax_amount: ''
                }
              },
              item_id: 0,
              name: '',
              price: '',
              product_option: {
                extension_attributes: {
                  bundle_options: [
                    {
                      extension_attributes: {},
                      option_id: 0,
                      option_qty: 0,
                      option_selections: []
                    }
                  ],
                  configurable_item_options: [
                    {
                      extension_attributes: {},
                      option_id: '',
                      option_value: 0
                    }
                  ],
                  custom_options: [
                    {
                      extension_attributes: {
                        file_info: {
                          base64_encoded_data: '',
                          name: '',
                          type: ''
                        }
                      },
                      option_id: '',
                      option_value: ''
                    }
                  ],
                  downloadable_option: {
                    downloadable_links: []
                  },
                  giftcard_item_option: {
                    custom_giftcard_amount: '',
                    extension_attributes: {},
                    giftcard_amount: '',
                    giftcard_message: '',
                    giftcard_recipient_email: '',
                    giftcard_recipient_name: '',
                    giftcard_sender_email: '',
                    giftcard_sender_name: ''
                  }
                }
              },
              product_type: '',
              qty: '',
              quote_id: '',
              sku: ''
            }
          ],
          shipping: {
            address: {},
            extension_attributes: {},
            method: ''
          }
        }
      ]
    },
    id: 0,
    is_active: false,
    is_virtual: false,
    items: [
      {}
    ],
    items_count: 0,
    items_qty: '',
    orig_order_id: 0,
    reserved_order_id: '',
    store_id: 0,
    updated_at: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/carts/mine');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/mine',
  headers: {'content-type': 'application/json'},
  data: {
    quote: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      converted_at: '',
      created_at: '',
      currency: {
        base_currency_code: '',
        base_to_global_rate: '',
        base_to_quote_rate: '',
        extension_attributes: {},
        global_currency_code: '',
        quote_currency_code: '',
        store_currency_code: '',
        store_to_base_rate: '',
        store_to_quote_rate: ''
      },
      customer: {
        addresses: [
          {
            city: '',
            company: '',
            country_id: '',
            custom_attributes: [{}],
            customer_id: 0,
            default_billing: false,
            default_shipping: false,
            extension_attributes: {},
            fax: '',
            firstname: '',
            id: 0,
            lastname: '',
            middlename: '',
            postcode: '',
            prefix: '',
            region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
            region_id: 0,
            street: [],
            suffix: '',
            telephone: '',
            vat_id: ''
          }
        ],
        confirmation: '',
        created_at: '',
        created_in: '',
        custom_attributes: [{}],
        default_billing: '',
        default_shipping: '',
        disable_auto_group_change: 0,
        dob: '',
        email: '',
        extension_attributes: {
          amazon_id: '',
          company_attributes: {
            company_id: 0,
            customer_id: 0,
            extension_attributes: {},
            job_title: '',
            status: 0,
            telephone: ''
          },
          is_subscribed: false,
          vertex_customer_code: ''
        },
        firstname: '',
        gender: 0,
        group_id: 0,
        id: 0,
        lastname: '',
        middlename: '',
        prefix: '',
        store_id: 0,
        suffix: '',
        taxvat: '',
        updated_at: '',
        website_id: 0
      },
      customer_is_guest: false,
      customer_note: '',
      customer_note_notify: false,
      customer_tax_class_id: 0,
      extension_attributes: {
        amazon_order_reference_id: '',
        negotiable_quote: {
          applied_rule_ids: '',
          base_negotiated_total_price: '',
          base_original_total_price: '',
          creator_id: 0,
          creator_type: 0,
          deleted_sku: '',
          email_notification_status: 0,
          expiration_period: '',
          extension_attributes: {},
          has_unconfirmed_changes: false,
          is_address_draft: false,
          is_customer_price_changed: false,
          is_regular_quote: false,
          is_shipping_tax_changed: false,
          negotiated_price_type: 0,
          negotiated_price_value: '',
          negotiated_total_price: '',
          notifications: 0,
          original_total_price: '',
          quote_id: 0,
          quote_name: '',
          shipping_price: '',
          status: ''
        },
        shipping_assignments: [
          {
            extension_attributes: {},
            items: [
              {
                extension_attributes: {
                  negotiable_quote_item: {
                    extension_attributes: {},
                    item_id: 0,
                    original_discount_amount: '',
                    original_price: '',
                    original_tax_amount: ''
                  }
                },
                item_id: 0,
                name: '',
                price: '',
                product_option: {
                  extension_attributes: {
                    bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                    configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                    custom_options: [
                      {
                        extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                        option_id: '',
                        option_value: ''
                      }
                    ],
                    downloadable_option: {downloadable_links: []},
                    giftcard_item_option: {
                      custom_giftcard_amount: '',
                      extension_attributes: {},
                      giftcard_amount: '',
                      giftcard_message: '',
                      giftcard_recipient_email: '',
                      giftcard_recipient_name: '',
                      giftcard_sender_email: '',
                      giftcard_sender_name: ''
                    }
                  }
                },
                product_type: '',
                qty: '',
                quote_id: '',
                sku: ''
              }
            ],
            shipping: {address: {}, extension_attributes: {}, method: ''}
          }
        ]
      },
      id: 0,
      is_active: false,
      is_virtual: false,
      items: [{}],
      items_count: 0,
      items_qty: '',
      orig_order_id: 0,
      reserved_order_id: '',
      store_id: 0,
      updated_at: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"quote":{"billing_address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"converted_at":"","created_at":"","currency":{"base_currency_code":"","base_to_global_rate":"","base_to_quote_rate":"","extension_attributes":{},"global_currency_code":"","quote_currency_code":"","store_currency_code":"","store_to_base_rate":"","store_to_quote_rate":""},"customer":{"addresses":[{"city":"","company":"","country_id":"","custom_attributes":[{}],"customer_id":0,"default_billing":false,"default_shipping":false,"extension_attributes":{},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":{"extension_attributes":{},"region":"","region_code":"","region_id":0},"region_id":0,"street":[],"suffix":"","telephone":"","vat_id":""}],"confirmation":"","created_at":"","created_in":"","custom_attributes":[{}],"default_billing":"","default_shipping":"","disable_auto_group_change":0,"dob":"","email":"","extension_attributes":{"amazon_id":"","company_attributes":{"company_id":0,"customer_id":0,"extension_attributes":{},"job_title":"","status":0,"telephone":""},"is_subscribed":false,"vertex_customer_code":""},"firstname":"","gender":0,"group_id":0,"id":0,"lastname":"","middlename":"","prefix":"","store_id":0,"suffix":"","taxvat":"","updated_at":"","website_id":0},"customer_is_guest":false,"customer_note":"","customer_note_notify":false,"customer_tax_class_id":0,"extension_attributes":{"amazon_order_reference_id":"","negotiable_quote":{"applied_rule_ids":"","base_negotiated_total_price":"","base_original_total_price":"","creator_id":0,"creator_type":0,"deleted_sku":"","email_notification_status":0,"expiration_period":"","extension_attributes":{},"has_unconfirmed_changes":false,"is_address_draft":false,"is_customer_price_changed":false,"is_regular_quote":false,"is_shipping_tax_changed":false,"negotiated_price_type":0,"negotiated_price_value":"","negotiated_total_price":"","notifications":0,"original_total_price":"","quote_id":0,"quote_name":"","shipping_price":"","status":""},"shipping_assignments":[{"extension_attributes":{},"items":[{"extension_attributes":{"negotiable_quote_item":{"extension_attributes":{},"item_id":0,"original_discount_amount":"","original_price":"","original_tax_amount":""}},"item_id":0,"name":"","price":"","product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty":"","quote_id":"","sku":""}],"shipping":{"address":{},"extension_attributes":{},"method":""}}]},"id":0,"is_active":false,"is_virtual":false,"items":[{}],"items_count":0,"items_qty":"","orig_order_id":0,"reserved_order_id":"","store_id":0,"updated_at":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "quote": {\n    "billing_address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "converted_at": "",\n    "created_at": "",\n    "currency": {\n      "base_currency_code": "",\n      "base_to_global_rate": "",\n      "base_to_quote_rate": "",\n      "extension_attributes": {},\n      "global_currency_code": "",\n      "quote_currency_code": "",\n      "store_currency_code": "",\n      "store_to_base_rate": "",\n      "store_to_quote_rate": ""\n    },\n    "customer": {\n      "addresses": [\n        {\n          "city": "",\n          "company": "",\n          "country_id": "",\n          "custom_attributes": [\n            {}\n          ],\n          "customer_id": 0,\n          "default_billing": false,\n          "default_shipping": false,\n          "extension_attributes": {},\n          "fax": "",\n          "firstname": "",\n          "id": 0,\n          "lastname": "",\n          "middlename": "",\n          "postcode": "",\n          "prefix": "",\n          "region": {\n            "extension_attributes": {},\n            "region": "",\n            "region_code": "",\n            "region_id": 0\n          },\n          "region_id": 0,\n          "street": [],\n          "suffix": "",\n          "telephone": "",\n          "vat_id": ""\n        }\n      ],\n      "confirmation": "",\n      "created_at": "",\n      "created_in": "",\n      "custom_attributes": [\n        {}\n      ],\n      "default_billing": "",\n      "default_shipping": "",\n      "disable_auto_group_change": 0,\n      "dob": "",\n      "email": "",\n      "extension_attributes": {\n        "amazon_id": "",\n        "company_attributes": {\n          "company_id": 0,\n          "customer_id": 0,\n          "extension_attributes": {},\n          "job_title": "",\n          "status": 0,\n          "telephone": ""\n        },\n        "is_subscribed": false,\n        "vertex_customer_code": ""\n      },\n      "firstname": "",\n      "gender": 0,\n      "group_id": 0,\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "prefix": "",\n      "store_id": 0,\n      "suffix": "",\n      "taxvat": "",\n      "updated_at": "",\n      "website_id": 0\n    },\n    "customer_is_guest": false,\n    "customer_note": "",\n    "customer_note_notify": false,\n    "customer_tax_class_id": 0,\n    "extension_attributes": {\n      "amazon_order_reference_id": "",\n      "negotiable_quote": {\n        "applied_rule_ids": "",\n        "base_negotiated_total_price": "",\n        "base_original_total_price": "",\n        "creator_id": 0,\n        "creator_type": 0,\n        "deleted_sku": "",\n        "email_notification_status": 0,\n        "expiration_period": "",\n        "extension_attributes": {},\n        "has_unconfirmed_changes": false,\n        "is_address_draft": false,\n        "is_customer_price_changed": false,\n        "is_regular_quote": false,\n        "is_shipping_tax_changed": false,\n        "negotiated_price_type": 0,\n        "negotiated_price_value": "",\n        "negotiated_total_price": "",\n        "notifications": 0,\n        "original_total_price": "",\n        "quote_id": 0,\n        "quote_name": "",\n        "shipping_price": "",\n        "status": ""\n      },\n      "shipping_assignments": [\n        {\n          "extension_attributes": {},\n          "items": [\n            {\n              "extension_attributes": {\n                "negotiable_quote_item": {\n                  "extension_attributes": {},\n                  "item_id": 0,\n                  "original_discount_amount": "",\n                  "original_price": "",\n                  "original_tax_amount": ""\n                }\n              },\n              "item_id": 0,\n              "name": "",\n              "price": "",\n              "product_option": {\n                "extension_attributes": {\n                  "bundle_options": [\n                    {\n                      "extension_attributes": {},\n                      "option_id": 0,\n                      "option_qty": 0,\n                      "option_selections": []\n                    }\n                  ],\n                  "configurable_item_options": [\n                    {\n                      "extension_attributes": {},\n                      "option_id": "",\n                      "option_value": 0\n                    }\n                  ],\n                  "custom_options": [\n                    {\n                      "extension_attributes": {\n                        "file_info": {\n                          "base64_encoded_data": "",\n                          "name": "",\n                          "type": ""\n                        }\n                      },\n                      "option_id": "",\n                      "option_value": ""\n                    }\n                  ],\n                  "downloadable_option": {\n                    "downloadable_links": []\n                  },\n                  "giftcard_item_option": {\n                    "custom_giftcard_amount": "",\n                    "extension_attributes": {},\n                    "giftcard_amount": "",\n                    "giftcard_message": "",\n                    "giftcard_recipient_email": "",\n                    "giftcard_recipient_name": "",\n                    "giftcard_sender_email": "",\n                    "giftcard_sender_name": ""\n                  }\n                }\n              },\n              "product_type": "",\n              "qty": "",\n              "quote_id": "",\n              "sku": ""\n            }\n          ],\n          "shipping": {\n            "address": {},\n            "extension_attributes": {},\n            "method": ""\n          }\n        }\n      ]\n    },\n    "id": 0,\n    "is_active": false,\n    "is_virtual": false,\n    "items": [\n      {}\n    ],\n    "items_count": 0,\n    "items_qty": "",\n    "orig_order_id": 0,\n    "reserved_order_id": "",\n    "store_id": 0,\n    "updated_at": ""\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  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  quote: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    converted_at: '',
    created_at: '',
    currency: {
      base_currency_code: '',
      base_to_global_rate: '',
      base_to_quote_rate: '',
      extension_attributes: {},
      global_currency_code: '',
      quote_currency_code: '',
      store_currency_code: '',
      store_to_base_rate: '',
      store_to_quote_rate: ''
    },
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [{}],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [{}],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_id: 0
    },
    customer_is_guest: false,
    customer_note: '',
    customer_note_notify: false,
    customer_tax_class_id: 0,
    extension_attributes: {
      amazon_order_reference_id: '',
      negotiable_quote: {
        applied_rule_ids: '',
        base_negotiated_total_price: '',
        base_original_total_price: '',
        creator_id: 0,
        creator_type: 0,
        deleted_sku: '',
        email_notification_status: 0,
        expiration_period: '',
        extension_attributes: {},
        has_unconfirmed_changes: false,
        is_address_draft: false,
        is_customer_price_changed: false,
        is_regular_quote: false,
        is_shipping_tax_changed: false,
        negotiated_price_type: 0,
        negotiated_price_value: '',
        negotiated_total_price: '',
        notifications: 0,
        original_total_price: '',
        quote_id: 0,
        quote_name: '',
        shipping_price: '',
        status: ''
      },
      shipping_assignments: [
        {
          extension_attributes: {},
          items: [
            {
              extension_attributes: {
                negotiable_quote_item: {
                  extension_attributes: {},
                  item_id: 0,
                  original_discount_amount: '',
                  original_price: '',
                  original_tax_amount: ''
                }
              },
              item_id: 0,
              name: '',
              price: '',
              product_option: {
                extension_attributes: {
                  bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                  configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                  custom_options: [
                    {
                      extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                      option_id: '',
                      option_value: ''
                    }
                  ],
                  downloadable_option: {downloadable_links: []},
                  giftcard_item_option: {
                    custom_giftcard_amount: '',
                    extension_attributes: {},
                    giftcard_amount: '',
                    giftcard_message: '',
                    giftcard_recipient_email: '',
                    giftcard_recipient_name: '',
                    giftcard_sender_email: '',
                    giftcard_sender_name: ''
                  }
                }
              },
              product_type: '',
              qty: '',
              quote_id: '',
              sku: ''
            }
          ],
          shipping: {address: {}, extension_attributes: {}, method: ''}
        }
      ]
    },
    id: 0,
    is_active: false,
    is_virtual: false,
    items: [{}],
    items_count: 0,
    items_qty: '',
    orig_order_id: 0,
    reserved_order_id: '',
    store_id: 0,
    updated_at: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/mine',
  headers: {'content-type': 'application/json'},
  body: {
    quote: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      converted_at: '',
      created_at: '',
      currency: {
        base_currency_code: '',
        base_to_global_rate: '',
        base_to_quote_rate: '',
        extension_attributes: {},
        global_currency_code: '',
        quote_currency_code: '',
        store_currency_code: '',
        store_to_base_rate: '',
        store_to_quote_rate: ''
      },
      customer: {
        addresses: [
          {
            city: '',
            company: '',
            country_id: '',
            custom_attributes: [{}],
            customer_id: 0,
            default_billing: false,
            default_shipping: false,
            extension_attributes: {},
            fax: '',
            firstname: '',
            id: 0,
            lastname: '',
            middlename: '',
            postcode: '',
            prefix: '',
            region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
            region_id: 0,
            street: [],
            suffix: '',
            telephone: '',
            vat_id: ''
          }
        ],
        confirmation: '',
        created_at: '',
        created_in: '',
        custom_attributes: [{}],
        default_billing: '',
        default_shipping: '',
        disable_auto_group_change: 0,
        dob: '',
        email: '',
        extension_attributes: {
          amazon_id: '',
          company_attributes: {
            company_id: 0,
            customer_id: 0,
            extension_attributes: {},
            job_title: '',
            status: 0,
            telephone: ''
          },
          is_subscribed: false,
          vertex_customer_code: ''
        },
        firstname: '',
        gender: 0,
        group_id: 0,
        id: 0,
        lastname: '',
        middlename: '',
        prefix: '',
        store_id: 0,
        suffix: '',
        taxvat: '',
        updated_at: '',
        website_id: 0
      },
      customer_is_guest: false,
      customer_note: '',
      customer_note_notify: false,
      customer_tax_class_id: 0,
      extension_attributes: {
        amazon_order_reference_id: '',
        negotiable_quote: {
          applied_rule_ids: '',
          base_negotiated_total_price: '',
          base_original_total_price: '',
          creator_id: 0,
          creator_type: 0,
          deleted_sku: '',
          email_notification_status: 0,
          expiration_period: '',
          extension_attributes: {},
          has_unconfirmed_changes: false,
          is_address_draft: false,
          is_customer_price_changed: false,
          is_regular_quote: false,
          is_shipping_tax_changed: false,
          negotiated_price_type: 0,
          negotiated_price_value: '',
          negotiated_total_price: '',
          notifications: 0,
          original_total_price: '',
          quote_id: 0,
          quote_name: '',
          shipping_price: '',
          status: ''
        },
        shipping_assignments: [
          {
            extension_attributes: {},
            items: [
              {
                extension_attributes: {
                  negotiable_quote_item: {
                    extension_attributes: {},
                    item_id: 0,
                    original_discount_amount: '',
                    original_price: '',
                    original_tax_amount: ''
                  }
                },
                item_id: 0,
                name: '',
                price: '',
                product_option: {
                  extension_attributes: {
                    bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                    configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                    custom_options: [
                      {
                        extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                        option_id: '',
                        option_value: ''
                      }
                    ],
                    downloadable_option: {downloadable_links: []},
                    giftcard_item_option: {
                      custom_giftcard_amount: '',
                      extension_attributes: {},
                      giftcard_amount: '',
                      giftcard_message: '',
                      giftcard_recipient_email: '',
                      giftcard_recipient_name: '',
                      giftcard_sender_email: '',
                      giftcard_sender_name: ''
                    }
                  }
                },
                product_type: '',
                qty: '',
                quote_id: '',
                sku: ''
              }
            ],
            shipping: {address: {}, extension_attributes: {}, method: ''}
          }
        ]
      },
      id: 0,
      is_active: false,
      is_virtual: false,
      items: [{}],
      items_count: 0,
      items_qty: '',
      orig_order_id: 0,
      reserved_order_id: '',
      store_id: 0,
      updated_at: ''
    }
  },
  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}}/V1/carts/mine');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  quote: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    converted_at: '',
    created_at: '',
    currency: {
      base_currency_code: '',
      base_to_global_rate: '',
      base_to_quote_rate: '',
      extension_attributes: {},
      global_currency_code: '',
      quote_currency_code: '',
      store_currency_code: '',
      store_to_base_rate: '',
      store_to_quote_rate: ''
    },
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [
            {}
          ],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {
            extension_attributes: {},
            region: '',
            region_code: '',
            region_id: 0
          },
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [
        {}
      ],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_id: 0
    },
    customer_is_guest: false,
    customer_note: '',
    customer_note_notify: false,
    customer_tax_class_id: 0,
    extension_attributes: {
      amazon_order_reference_id: '',
      negotiable_quote: {
        applied_rule_ids: '',
        base_negotiated_total_price: '',
        base_original_total_price: '',
        creator_id: 0,
        creator_type: 0,
        deleted_sku: '',
        email_notification_status: 0,
        expiration_period: '',
        extension_attributes: {},
        has_unconfirmed_changes: false,
        is_address_draft: false,
        is_customer_price_changed: false,
        is_regular_quote: false,
        is_shipping_tax_changed: false,
        negotiated_price_type: 0,
        negotiated_price_value: '',
        negotiated_total_price: '',
        notifications: 0,
        original_total_price: '',
        quote_id: 0,
        quote_name: '',
        shipping_price: '',
        status: ''
      },
      shipping_assignments: [
        {
          extension_attributes: {},
          items: [
            {
              extension_attributes: {
                negotiable_quote_item: {
                  extension_attributes: {},
                  item_id: 0,
                  original_discount_amount: '',
                  original_price: '',
                  original_tax_amount: ''
                }
              },
              item_id: 0,
              name: '',
              price: '',
              product_option: {
                extension_attributes: {
                  bundle_options: [
                    {
                      extension_attributes: {},
                      option_id: 0,
                      option_qty: 0,
                      option_selections: []
                    }
                  ],
                  configurable_item_options: [
                    {
                      extension_attributes: {},
                      option_id: '',
                      option_value: 0
                    }
                  ],
                  custom_options: [
                    {
                      extension_attributes: {
                        file_info: {
                          base64_encoded_data: '',
                          name: '',
                          type: ''
                        }
                      },
                      option_id: '',
                      option_value: ''
                    }
                  ],
                  downloadable_option: {
                    downloadable_links: []
                  },
                  giftcard_item_option: {
                    custom_giftcard_amount: '',
                    extension_attributes: {},
                    giftcard_amount: '',
                    giftcard_message: '',
                    giftcard_recipient_email: '',
                    giftcard_recipient_name: '',
                    giftcard_sender_email: '',
                    giftcard_sender_name: ''
                  }
                }
              },
              product_type: '',
              qty: '',
              quote_id: '',
              sku: ''
            }
          ],
          shipping: {
            address: {},
            extension_attributes: {},
            method: ''
          }
        }
      ]
    },
    id: 0,
    is_active: false,
    is_virtual: false,
    items: [
      {}
    ],
    items_count: 0,
    items_qty: '',
    orig_order_id: 0,
    reserved_order_id: '',
    store_id: 0,
    updated_at: ''
  }
});

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}}/V1/carts/mine',
  headers: {'content-type': 'application/json'},
  data: {
    quote: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      converted_at: '',
      created_at: '',
      currency: {
        base_currency_code: '',
        base_to_global_rate: '',
        base_to_quote_rate: '',
        extension_attributes: {},
        global_currency_code: '',
        quote_currency_code: '',
        store_currency_code: '',
        store_to_base_rate: '',
        store_to_quote_rate: ''
      },
      customer: {
        addresses: [
          {
            city: '',
            company: '',
            country_id: '',
            custom_attributes: [{}],
            customer_id: 0,
            default_billing: false,
            default_shipping: false,
            extension_attributes: {},
            fax: '',
            firstname: '',
            id: 0,
            lastname: '',
            middlename: '',
            postcode: '',
            prefix: '',
            region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
            region_id: 0,
            street: [],
            suffix: '',
            telephone: '',
            vat_id: ''
          }
        ],
        confirmation: '',
        created_at: '',
        created_in: '',
        custom_attributes: [{}],
        default_billing: '',
        default_shipping: '',
        disable_auto_group_change: 0,
        dob: '',
        email: '',
        extension_attributes: {
          amazon_id: '',
          company_attributes: {
            company_id: 0,
            customer_id: 0,
            extension_attributes: {},
            job_title: '',
            status: 0,
            telephone: ''
          },
          is_subscribed: false,
          vertex_customer_code: ''
        },
        firstname: '',
        gender: 0,
        group_id: 0,
        id: 0,
        lastname: '',
        middlename: '',
        prefix: '',
        store_id: 0,
        suffix: '',
        taxvat: '',
        updated_at: '',
        website_id: 0
      },
      customer_is_guest: false,
      customer_note: '',
      customer_note_notify: false,
      customer_tax_class_id: 0,
      extension_attributes: {
        amazon_order_reference_id: '',
        negotiable_quote: {
          applied_rule_ids: '',
          base_negotiated_total_price: '',
          base_original_total_price: '',
          creator_id: 0,
          creator_type: 0,
          deleted_sku: '',
          email_notification_status: 0,
          expiration_period: '',
          extension_attributes: {},
          has_unconfirmed_changes: false,
          is_address_draft: false,
          is_customer_price_changed: false,
          is_regular_quote: false,
          is_shipping_tax_changed: false,
          negotiated_price_type: 0,
          negotiated_price_value: '',
          negotiated_total_price: '',
          notifications: 0,
          original_total_price: '',
          quote_id: 0,
          quote_name: '',
          shipping_price: '',
          status: ''
        },
        shipping_assignments: [
          {
            extension_attributes: {},
            items: [
              {
                extension_attributes: {
                  negotiable_quote_item: {
                    extension_attributes: {},
                    item_id: 0,
                    original_discount_amount: '',
                    original_price: '',
                    original_tax_amount: ''
                  }
                },
                item_id: 0,
                name: '',
                price: '',
                product_option: {
                  extension_attributes: {
                    bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                    configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                    custom_options: [
                      {
                        extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                        option_id: '',
                        option_value: ''
                      }
                    ],
                    downloadable_option: {downloadable_links: []},
                    giftcard_item_option: {
                      custom_giftcard_amount: '',
                      extension_attributes: {},
                      giftcard_amount: '',
                      giftcard_message: '',
                      giftcard_recipient_email: '',
                      giftcard_recipient_name: '',
                      giftcard_sender_email: '',
                      giftcard_sender_name: ''
                    }
                  }
                },
                product_type: '',
                qty: '',
                quote_id: '',
                sku: ''
              }
            ],
            shipping: {address: {}, extension_attributes: {}, method: ''}
          }
        ]
      },
      id: 0,
      is_active: false,
      is_virtual: false,
      items: [{}],
      items_count: 0,
      items_qty: '',
      orig_order_id: 0,
      reserved_order_id: '',
      store_id: 0,
      updated_at: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"quote":{"billing_address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"converted_at":"","created_at":"","currency":{"base_currency_code":"","base_to_global_rate":"","base_to_quote_rate":"","extension_attributes":{},"global_currency_code":"","quote_currency_code":"","store_currency_code":"","store_to_base_rate":"","store_to_quote_rate":""},"customer":{"addresses":[{"city":"","company":"","country_id":"","custom_attributes":[{}],"customer_id":0,"default_billing":false,"default_shipping":false,"extension_attributes":{},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":{"extension_attributes":{},"region":"","region_code":"","region_id":0},"region_id":0,"street":[],"suffix":"","telephone":"","vat_id":""}],"confirmation":"","created_at":"","created_in":"","custom_attributes":[{}],"default_billing":"","default_shipping":"","disable_auto_group_change":0,"dob":"","email":"","extension_attributes":{"amazon_id":"","company_attributes":{"company_id":0,"customer_id":0,"extension_attributes":{},"job_title":"","status":0,"telephone":""},"is_subscribed":false,"vertex_customer_code":""},"firstname":"","gender":0,"group_id":0,"id":0,"lastname":"","middlename":"","prefix":"","store_id":0,"suffix":"","taxvat":"","updated_at":"","website_id":0},"customer_is_guest":false,"customer_note":"","customer_note_notify":false,"customer_tax_class_id":0,"extension_attributes":{"amazon_order_reference_id":"","negotiable_quote":{"applied_rule_ids":"","base_negotiated_total_price":"","base_original_total_price":"","creator_id":0,"creator_type":0,"deleted_sku":"","email_notification_status":0,"expiration_period":"","extension_attributes":{},"has_unconfirmed_changes":false,"is_address_draft":false,"is_customer_price_changed":false,"is_regular_quote":false,"is_shipping_tax_changed":false,"negotiated_price_type":0,"negotiated_price_value":"","negotiated_total_price":"","notifications":0,"original_total_price":"","quote_id":0,"quote_name":"","shipping_price":"","status":""},"shipping_assignments":[{"extension_attributes":{},"items":[{"extension_attributes":{"negotiable_quote_item":{"extension_attributes":{},"item_id":0,"original_discount_amount":"","original_price":"","original_tax_amount":""}},"item_id":0,"name":"","price":"","product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty":"","quote_id":"","sku":""}],"shipping":{"address":{},"extension_attributes":{},"method":""}}]},"id":0,"is_active":false,"is_virtual":false,"items":[{}],"items_count":0,"items_qty":"","orig_order_id":0,"reserved_order_id":"","store_id":0,"updated_at":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"quote": @{ @"billing_address": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" }, @"converted_at": @"", @"created_at": @"", @"currency": @{ @"base_currency_code": @"", @"base_to_global_rate": @"", @"base_to_quote_rate": @"", @"extension_attributes": @{  }, @"global_currency_code": @"", @"quote_currency_code": @"", @"store_currency_code": @"", @"store_to_base_rate": @"", @"store_to_quote_rate": @"" }, @"customer": @{ @"addresses": @[ @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{  } ], @"customer_id": @0, @"default_billing": @NO, @"default_shipping": @NO, @"extension_attributes": @{  }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @{ @"extension_attributes": @{  }, @"region": @"", @"region_code": @"", @"region_id": @0 }, @"region_id": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" } ], @"confirmation": @"", @"created_at": @"", @"created_in": @"", @"custom_attributes": @[ @{  } ], @"default_billing": @"", @"default_shipping": @"", @"disable_auto_group_change": @0, @"dob": @"", @"email": @"", @"extension_attributes": @{ @"amazon_id": @"", @"company_attributes": @{ @"company_id": @0, @"customer_id": @0, @"extension_attributes": @{  }, @"job_title": @"", @"status": @0, @"telephone": @"" }, @"is_subscribed": @NO, @"vertex_customer_code": @"" }, @"firstname": @"", @"gender": @0, @"group_id": @0, @"id": @0, @"lastname": @"", @"middlename": @"", @"prefix": @"", @"store_id": @0, @"suffix": @"", @"taxvat": @"", @"updated_at": @"", @"website_id": @0 }, @"customer_is_guest": @NO, @"customer_note": @"", @"customer_note_notify": @NO, @"customer_tax_class_id": @0, @"extension_attributes": @{ @"amazon_order_reference_id": @"", @"negotiable_quote": @{ @"applied_rule_ids": @"", @"base_negotiated_total_price": @"", @"base_original_total_price": @"", @"creator_id": @0, @"creator_type": @0, @"deleted_sku": @"", @"email_notification_status": @0, @"expiration_period": @"", @"extension_attributes": @{  }, @"has_unconfirmed_changes": @NO, @"is_address_draft": @NO, @"is_customer_price_changed": @NO, @"is_regular_quote": @NO, @"is_shipping_tax_changed": @NO, @"negotiated_price_type": @0, @"negotiated_price_value": @"", @"negotiated_total_price": @"", @"notifications": @0, @"original_total_price": @"", @"quote_id": @0, @"quote_name": @"", @"shipping_price": @"", @"status": @"" }, @"shipping_assignments": @[ @{ @"extension_attributes": @{  }, @"items": @[ @{ @"extension_attributes": @{ @"negotiable_quote_item": @{ @"extension_attributes": @{  }, @"item_id": @0, @"original_discount_amount": @"", @"original_price": @"", @"original_tax_amount": @"" } }, @"item_id": @0, @"name": @"", @"price": @"", @"product_option": @{ @"extension_attributes": @{ @"bundle_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @0, @"option_qty": @0, @"option_selections": @[  ] } ], @"configurable_item_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @"", @"option_value": @0 } ], @"custom_options": @[ @{ @"extension_attributes": @{ @"file_info": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" } }, @"option_id": @"", @"option_value": @"" } ], @"downloadable_option": @{ @"downloadable_links": @[  ] }, @"giftcard_item_option": @{ @"custom_giftcard_amount": @"", @"extension_attributes": @{  }, @"giftcard_amount": @"", @"giftcard_message": @"", @"giftcard_recipient_email": @"", @"giftcard_recipient_name": @"", @"giftcard_sender_email": @"", @"giftcard_sender_name": @"" } } }, @"product_type": @"", @"qty": @"", @"quote_id": @"", @"sku": @"" } ], @"shipping": @{ @"address": @{  }, @"extension_attributes": @{  }, @"method": @"" } } ] }, @"id": @0, @"is_active": @NO, @"is_virtual": @NO, @"items": @[ @{  } ], @"items_count": @0, @"items_qty": @"", @"orig_order_id": @0, @"reserved_order_id": @"", @"store_id": @0, @"updated_at": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine"]
                                                       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}}/V1/carts/mine" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine",
  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([
    'quote' => [
        'billing_address' => [
                'city' => '',
                'company' => '',
                'country_id' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_address_id' => 0,
                'customer_id' => 0,
                'email' => '',
                'extension_attributes' => [
                                'checkout_fields' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'gift_registry_id' => 0
                ],
                'fax' => '',
                'firstname' => '',
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'postcode' => '',
                'prefix' => '',
                'region' => '',
                'region_code' => '',
                'region_id' => 0,
                'same_as_billing' => 0,
                'save_in_address_book' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => ''
        ],
        'converted_at' => '',
        'created_at' => '',
        'currency' => [
                'base_currency_code' => '',
                'base_to_global_rate' => '',
                'base_to_quote_rate' => '',
                'extension_attributes' => [
                                
                ],
                'global_currency_code' => '',
                'quote_currency_code' => '',
                'store_currency_code' => '',
                'store_to_base_rate' => '',
                'store_to_quote_rate' => ''
        ],
        'customer' => [
                'addresses' => [
                                [
                                                                'city' => '',
                                                                'company' => '',
                                                                'country_id' => '',
                                                                'custom_attributes' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'customer_id' => 0,
                                                                'default_billing' => null,
                                                                'default_shipping' => null,
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'fax' => '',
                                                                'firstname' => '',
                                                                'id' => 0,
                                                                'lastname' => '',
                                                                'middlename' => '',
                                                                'postcode' => '',
                                                                'prefix' => '',
                                                                'region' => [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'region' => '',
                                                                                                                                'region_code' => '',
                                                                                                                                'region_id' => 0
                                                                ],
                                                                'region_id' => 0,
                                                                'street' => [
                                                                                                                                
                                                                ],
                                                                'suffix' => '',
                                                                'telephone' => '',
                                                                'vat_id' => ''
                                ]
                ],
                'confirmation' => '',
                'created_at' => '',
                'created_in' => '',
                'custom_attributes' => [
                                [
                                                                
                                ]
                ],
                'default_billing' => '',
                'default_shipping' => '',
                'disable_auto_group_change' => 0,
                'dob' => '',
                'email' => '',
                'extension_attributes' => [
                                'amazon_id' => '',
                                'company_attributes' => [
                                                                'company_id' => 0,
                                                                'customer_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'job_title' => '',
                                                                'status' => 0,
                                                                'telephone' => ''
                                ],
                                'is_subscribed' => null,
                                'vertex_customer_code' => ''
                ],
                'firstname' => '',
                'gender' => 0,
                'group_id' => 0,
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'prefix' => '',
                'store_id' => 0,
                'suffix' => '',
                'taxvat' => '',
                'updated_at' => '',
                'website_id' => 0
        ],
        'customer_is_guest' => null,
        'customer_note' => '',
        'customer_note_notify' => null,
        'customer_tax_class_id' => 0,
        'extension_attributes' => [
                'amazon_order_reference_id' => '',
                'negotiable_quote' => [
                                'applied_rule_ids' => '',
                                'base_negotiated_total_price' => '',
                                'base_original_total_price' => '',
                                'creator_id' => 0,
                                'creator_type' => 0,
                                'deleted_sku' => '',
                                'email_notification_status' => 0,
                                'expiration_period' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'has_unconfirmed_changes' => null,
                                'is_address_draft' => null,
                                'is_customer_price_changed' => null,
                                'is_regular_quote' => null,
                                'is_shipping_tax_changed' => null,
                                'negotiated_price_type' => 0,
                                'negotiated_price_value' => '',
                                'negotiated_total_price' => '',
                                'notifications' => 0,
                                'original_total_price' => '',
                                'quote_id' => 0,
                                'quote_name' => '',
                                'shipping_price' => '',
                                'status' => ''
                ],
                'shipping_assignments' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'items' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'negotiable_quote_item' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'item_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_tax_amount' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'item_id' => 0,
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                'product_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'bundle_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_qty' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'configurable_item_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_links' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_item_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_message' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_name' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'product_type' => '',
                                                                                                                                                                                                                                                                'qty' => '',
                                                                                                                                                                                                                                                                'quote_id' => '',
                                                                                                                                                                                                                                                                'sku' => ''
                                                                                                                                ]
                                                                ],
                                                                'shipping' => [
                                                                                                                                'address' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'method' => ''
                                                                ]
                                ]
                ]
        ],
        'id' => 0,
        'is_active' => null,
        'is_virtual' => null,
        'items' => [
                [
                                
                ]
        ],
        'items_count' => 0,
        'items_qty' => '',
        'orig_order_id' => 0,
        'reserved_order_id' => '',
        'store_id' => 0,
        'updated_at' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/carts/mine', [
  'body' => '{
  "quote": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "converted_at": "",
    "created_at": "",
    "currency": {
      "base_currency_code": "",
      "base_to_global_rate": "",
      "base_to_quote_rate": "",
      "extension_attributes": {},
      "global_currency_code": "",
      "quote_currency_code": "",
      "store_currency_code": "",
      "store_to_base_rate": "",
      "store_to_quote_rate": ""
    },
    "customer": {
      "addresses": [
        {
          "city": "",
          "company": "",
          "country_id": "",
          "custom_attributes": [
            {}
          ],
          "customer_id": 0,
          "default_billing": false,
          "default_shipping": false,
          "extension_attributes": {},
          "fax": "",
          "firstname": "",
          "id": 0,
          "lastname": "",
          "middlename": "",
          "postcode": "",
          "prefix": "",
          "region": {
            "extension_attributes": {},
            "region": "",
            "region_code": "",
            "region_id": 0
          },
          "region_id": 0,
          "street": [],
          "suffix": "",
          "telephone": "",
          "vat_id": ""
        }
      ],
      "confirmation": "",
      "created_at": "",
      "created_in": "",
      "custom_attributes": [
        {}
      ],
      "default_billing": "",
      "default_shipping": "",
      "disable_auto_group_change": 0,
      "dob": "",
      "email": "",
      "extension_attributes": {
        "amazon_id": "",
        "company_attributes": {
          "company_id": 0,
          "customer_id": 0,
          "extension_attributes": {},
          "job_title": "",
          "status": 0,
          "telephone": ""
        },
        "is_subscribed": false,
        "vertex_customer_code": ""
      },
      "firstname": "",
      "gender": 0,
      "group_id": 0,
      "id": 0,
      "lastname": "",
      "middlename": "",
      "prefix": "",
      "store_id": 0,
      "suffix": "",
      "taxvat": "",
      "updated_at": "",
      "website_id": 0
    },
    "customer_is_guest": false,
    "customer_note": "",
    "customer_note_notify": false,
    "customer_tax_class_id": 0,
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "negotiable_quote": {
        "applied_rule_ids": "",
        "base_negotiated_total_price": "",
        "base_original_total_price": "",
        "creator_id": 0,
        "creator_type": 0,
        "deleted_sku": "",
        "email_notification_status": 0,
        "expiration_period": "",
        "extension_attributes": {},
        "has_unconfirmed_changes": false,
        "is_address_draft": false,
        "is_customer_price_changed": false,
        "is_regular_quote": false,
        "is_shipping_tax_changed": false,
        "negotiated_price_type": 0,
        "negotiated_price_value": "",
        "negotiated_total_price": "",
        "notifications": 0,
        "original_total_price": "",
        "quote_id": 0,
        "quote_name": "",
        "shipping_price": "",
        "status": ""
      },
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "extension_attributes": {
                "negotiable_quote_item": {
                  "extension_attributes": {},
                  "item_id": 0,
                  "original_discount_amount": "",
                  "original_price": "",
                  "original_tax_amount": ""
                }
              },
              "item_id": 0,
              "name": "",
              "price": "",
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty": "",
              "quote_id": "",
              "sku": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {},
            "method": ""
          }
        }
      ]
    },
    "id": 0,
    "is_active": false,
    "is_virtual": false,
    "items": [
      {}
    ],
    "items_count": 0,
    "items_qty": "",
    "orig_order_id": 0,
    "reserved_order_id": "",
    "store_id": 0,
    "updated_at": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'quote' => [
    'billing_address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'converted_at' => '',
    'created_at' => '',
    'currency' => [
        'base_currency_code' => '',
        'base_to_global_rate' => '',
        'base_to_quote_rate' => '',
        'extension_attributes' => [
                
        ],
        'global_currency_code' => '',
        'quote_currency_code' => '',
        'store_currency_code' => '',
        'store_to_base_rate' => '',
        'store_to_quote_rate' => ''
    ],
    'customer' => [
        'addresses' => [
                [
                                'city' => '',
                                'company' => '',
                                'country_id' => '',
                                'custom_attributes' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'customer_id' => 0,
                                'default_billing' => null,
                                'default_shipping' => null,
                                'extension_attributes' => [
                                                                
                                ],
                                'fax' => '',
                                'firstname' => '',
                                'id' => 0,
                                'lastname' => '',
                                'middlename' => '',
                                'postcode' => '',
                                'prefix' => '',
                                'region' => [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'region' => '',
                                                                'region_code' => '',
                                                                'region_id' => 0
                                ],
                                'region_id' => 0,
                                'street' => [
                                                                
                                ],
                                'suffix' => '',
                                'telephone' => '',
                                'vat_id' => ''
                ]
        ],
        'confirmation' => '',
        'created_at' => '',
        'created_in' => '',
        'custom_attributes' => [
                [
                                
                ]
        ],
        'default_billing' => '',
        'default_shipping' => '',
        'disable_auto_group_change' => 0,
        'dob' => '',
        'email' => '',
        'extension_attributes' => [
                'amazon_id' => '',
                'company_attributes' => [
                                'company_id' => 0,
                                'customer_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'job_title' => '',
                                'status' => 0,
                                'telephone' => ''
                ],
                'is_subscribed' => null,
                'vertex_customer_code' => ''
        ],
        'firstname' => '',
        'gender' => 0,
        'group_id' => 0,
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'prefix' => '',
        'store_id' => 0,
        'suffix' => '',
        'taxvat' => '',
        'updated_at' => '',
        'website_id' => 0
    ],
    'customer_is_guest' => null,
    'customer_note' => '',
    'customer_note_notify' => null,
    'customer_tax_class_id' => 0,
    'extension_attributes' => [
        'amazon_order_reference_id' => '',
        'negotiable_quote' => [
                'applied_rule_ids' => '',
                'base_negotiated_total_price' => '',
                'base_original_total_price' => '',
                'creator_id' => 0,
                'creator_type' => 0,
                'deleted_sku' => '',
                'email_notification_status' => 0,
                'expiration_period' => '',
                'extension_attributes' => [
                                
                ],
                'has_unconfirmed_changes' => null,
                'is_address_draft' => null,
                'is_customer_price_changed' => null,
                'is_regular_quote' => null,
                'is_shipping_tax_changed' => null,
                'negotiated_price_type' => 0,
                'negotiated_price_value' => '',
                'negotiated_total_price' => '',
                'notifications' => 0,
                'original_total_price' => '',
                'quote_id' => 0,
                'quote_name' => '',
                'shipping_price' => '',
                'status' => ''
        ],
        'shipping_assignments' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'items' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'negotiable_quote_item' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'item_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_tax_amount' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'item_id' => 0,
                                                                                                                                'name' => '',
                                                                                                                                'price' => '',
                                                                                                                                'product_option' => [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'bundle_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_qty' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'configurable_item_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_links' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_item_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_message' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_name' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'product_type' => '',
                                                                                                                                'qty' => '',
                                                                                                                                'quote_id' => '',
                                                                                                                                'sku' => ''
                                                                ]
                                ],
                                'shipping' => [
                                                                'address' => [
                                                                                                                                
                                                                ],
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'method' => ''
                                ]
                ]
        ]
    ],
    'id' => 0,
    'is_active' => null,
    'is_virtual' => null,
    'items' => [
        [
                
        ]
    ],
    'items_count' => 0,
    'items_qty' => '',
    'orig_order_id' => 0,
    'reserved_order_id' => '',
    'store_id' => 0,
    'updated_at' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'quote' => [
    'billing_address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'converted_at' => '',
    'created_at' => '',
    'currency' => [
        'base_currency_code' => '',
        'base_to_global_rate' => '',
        'base_to_quote_rate' => '',
        'extension_attributes' => [
                
        ],
        'global_currency_code' => '',
        'quote_currency_code' => '',
        'store_currency_code' => '',
        'store_to_base_rate' => '',
        'store_to_quote_rate' => ''
    ],
    'customer' => [
        'addresses' => [
                [
                                'city' => '',
                                'company' => '',
                                'country_id' => '',
                                'custom_attributes' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'customer_id' => 0,
                                'default_billing' => null,
                                'default_shipping' => null,
                                'extension_attributes' => [
                                                                
                                ],
                                'fax' => '',
                                'firstname' => '',
                                'id' => 0,
                                'lastname' => '',
                                'middlename' => '',
                                'postcode' => '',
                                'prefix' => '',
                                'region' => [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'region' => '',
                                                                'region_code' => '',
                                                                'region_id' => 0
                                ],
                                'region_id' => 0,
                                'street' => [
                                                                
                                ],
                                'suffix' => '',
                                'telephone' => '',
                                'vat_id' => ''
                ]
        ],
        'confirmation' => '',
        'created_at' => '',
        'created_in' => '',
        'custom_attributes' => [
                [
                                
                ]
        ],
        'default_billing' => '',
        'default_shipping' => '',
        'disable_auto_group_change' => 0,
        'dob' => '',
        'email' => '',
        'extension_attributes' => [
                'amazon_id' => '',
                'company_attributes' => [
                                'company_id' => 0,
                                'customer_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'job_title' => '',
                                'status' => 0,
                                'telephone' => ''
                ],
                'is_subscribed' => null,
                'vertex_customer_code' => ''
        ],
        'firstname' => '',
        'gender' => 0,
        'group_id' => 0,
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'prefix' => '',
        'store_id' => 0,
        'suffix' => '',
        'taxvat' => '',
        'updated_at' => '',
        'website_id' => 0
    ],
    'customer_is_guest' => null,
    'customer_note' => '',
    'customer_note_notify' => null,
    'customer_tax_class_id' => 0,
    'extension_attributes' => [
        'amazon_order_reference_id' => '',
        'negotiable_quote' => [
                'applied_rule_ids' => '',
                'base_negotiated_total_price' => '',
                'base_original_total_price' => '',
                'creator_id' => 0,
                'creator_type' => 0,
                'deleted_sku' => '',
                'email_notification_status' => 0,
                'expiration_period' => '',
                'extension_attributes' => [
                                
                ],
                'has_unconfirmed_changes' => null,
                'is_address_draft' => null,
                'is_customer_price_changed' => null,
                'is_regular_quote' => null,
                'is_shipping_tax_changed' => null,
                'negotiated_price_type' => 0,
                'negotiated_price_value' => '',
                'negotiated_total_price' => '',
                'notifications' => 0,
                'original_total_price' => '',
                'quote_id' => 0,
                'quote_name' => '',
                'shipping_price' => '',
                'status' => ''
        ],
        'shipping_assignments' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'items' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'negotiable_quote_item' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'item_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_tax_amount' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'item_id' => 0,
                                                                                                                                'name' => '',
                                                                                                                                'price' => '',
                                                                                                                                'product_option' => [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'bundle_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_qty' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'configurable_item_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_links' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_item_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_message' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_name' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'product_type' => '',
                                                                                                                                'qty' => '',
                                                                                                                                'quote_id' => '',
                                                                                                                                'sku' => ''
                                                                ]
                                ],
                                'shipping' => [
                                                                'address' => [
                                                                                                                                
                                                                ],
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'method' => ''
                                ]
                ]
        ]
    ],
    'id' => 0,
    'is_active' => null,
    'is_virtual' => null,
    'items' => [
        [
                
        ]
    ],
    'items_count' => 0,
    'items_qty' => '',
    'orig_order_id' => 0,
    'reserved_order_id' => '',
    'store_id' => 0,
    'updated_at' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "quote": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "converted_at": "",
    "created_at": "",
    "currency": {
      "base_currency_code": "",
      "base_to_global_rate": "",
      "base_to_quote_rate": "",
      "extension_attributes": {},
      "global_currency_code": "",
      "quote_currency_code": "",
      "store_currency_code": "",
      "store_to_base_rate": "",
      "store_to_quote_rate": ""
    },
    "customer": {
      "addresses": [
        {
          "city": "",
          "company": "",
          "country_id": "",
          "custom_attributes": [
            {}
          ],
          "customer_id": 0,
          "default_billing": false,
          "default_shipping": false,
          "extension_attributes": {},
          "fax": "",
          "firstname": "",
          "id": 0,
          "lastname": "",
          "middlename": "",
          "postcode": "",
          "prefix": "",
          "region": {
            "extension_attributes": {},
            "region": "",
            "region_code": "",
            "region_id": 0
          },
          "region_id": 0,
          "street": [],
          "suffix": "",
          "telephone": "",
          "vat_id": ""
        }
      ],
      "confirmation": "",
      "created_at": "",
      "created_in": "",
      "custom_attributes": [
        {}
      ],
      "default_billing": "",
      "default_shipping": "",
      "disable_auto_group_change": 0,
      "dob": "",
      "email": "",
      "extension_attributes": {
        "amazon_id": "",
        "company_attributes": {
          "company_id": 0,
          "customer_id": 0,
          "extension_attributes": {},
          "job_title": "",
          "status": 0,
          "telephone": ""
        },
        "is_subscribed": false,
        "vertex_customer_code": ""
      },
      "firstname": "",
      "gender": 0,
      "group_id": 0,
      "id": 0,
      "lastname": "",
      "middlename": "",
      "prefix": "",
      "store_id": 0,
      "suffix": "",
      "taxvat": "",
      "updated_at": "",
      "website_id": 0
    },
    "customer_is_guest": false,
    "customer_note": "",
    "customer_note_notify": false,
    "customer_tax_class_id": 0,
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "negotiable_quote": {
        "applied_rule_ids": "",
        "base_negotiated_total_price": "",
        "base_original_total_price": "",
        "creator_id": 0,
        "creator_type": 0,
        "deleted_sku": "",
        "email_notification_status": 0,
        "expiration_period": "",
        "extension_attributes": {},
        "has_unconfirmed_changes": false,
        "is_address_draft": false,
        "is_customer_price_changed": false,
        "is_regular_quote": false,
        "is_shipping_tax_changed": false,
        "negotiated_price_type": 0,
        "negotiated_price_value": "",
        "negotiated_total_price": "",
        "notifications": 0,
        "original_total_price": "",
        "quote_id": 0,
        "quote_name": "",
        "shipping_price": "",
        "status": ""
      },
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "extension_attributes": {
                "negotiable_quote_item": {
                  "extension_attributes": {},
                  "item_id": 0,
                  "original_discount_amount": "",
                  "original_price": "",
                  "original_tax_amount": ""
                }
              },
              "item_id": 0,
              "name": "",
              "price": "",
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty": "",
              "quote_id": "",
              "sku": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {},
            "method": ""
          }
        }
      ]
    },
    "id": 0,
    "is_active": false,
    "is_virtual": false,
    "items": [
      {}
    ],
    "items_count": 0,
    "items_qty": "",
    "orig_order_id": 0,
    "reserved_order_id": "",
    "store_id": 0,
    "updated_at": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "quote": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "converted_at": "",
    "created_at": "",
    "currency": {
      "base_currency_code": "",
      "base_to_global_rate": "",
      "base_to_quote_rate": "",
      "extension_attributes": {},
      "global_currency_code": "",
      "quote_currency_code": "",
      "store_currency_code": "",
      "store_to_base_rate": "",
      "store_to_quote_rate": ""
    },
    "customer": {
      "addresses": [
        {
          "city": "",
          "company": "",
          "country_id": "",
          "custom_attributes": [
            {}
          ],
          "customer_id": 0,
          "default_billing": false,
          "default_shipping": false,
          "extension_attributes": {},
          "fax": "",
          "firstname": "",
          "id": 0,
          "lastname": "",
          "middlename": "",
          "postcode": "",
          "prefix": "",
          "region": {
            "extension_attributes": {},
            "region": "",
            "region_code": "",
            "region_id": 0
          },
          "region_id": 0,
          "street": [],
          "suffix": "",
          "telephone": "",
          "vat_id": ""
        }
      ],
      "confirmation": "",
      "created_at": "",
      "created_in": "",
      "custom_attributes": [
        {}
      ],
      "default_billing": "",
      "default_shipping": "",
      "disable_auto_group_change": 0,
      "dob": "",
      "email": "",
      "extension_attributes": {
        "amazon_id": "",
        "company_attributes": {
          "company_id": 0,
          "customer_id": 0,
          "extension_attributes": {},
          "job_title": "",
          "status": 0,
          "telephone": ""
        },
        "is_subscribed": false,
        "vertex_customer_code": ""
      },
      "firstname": "",
      "gender": 0,
      "group_id": 0,
      "id": 0,
      "lastname": "",
      "middlename": "",
      "prefix": "",
      "store_id": 0,
      "suffix": "",
      "taxvat": "",
      "updated_at": "",
      "website_id": 0
    },
    "customer_is_guest": false,
    "customer_note": "",
    "customer_note_notify": false,
    "customer_tax_class_id": 0,
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "negotiable_quote": {
        "applied_rule_ids": "",
        "base_negotiated_total_price": "",
        "base_original_total_price": "",
        "creator_id": 0,
        "creator_type": 0,
        "deleted_sku": "",
        "email_notification_status": 0,
        "expiration_period": "",
        "extension_attributes": {},
        "has_unconfirmed_changes": false,
        "is_address_draft": false,
        "is_customer_price_changed": false,
        "is_regular_quote": false,
        "is_shipping_tax_changed": false,
        "negotiated_price_type": 0,
        "negotiated_price_value": "",
        "negotiated_total_price": "",
        "notifications": 0,
        "original_total_price": "",
        "quote_id": 0,
        "quote_name": "",
        "shipping_price": "",
        "status": ""
      },
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "extension_attributes": {
                "negotiable_quote_item": {
                  "extension_attributes": {},
                  "item_id": 0,
                  "original_discount_amount": "",
                  "original_price": "",
                  "original_tax_amount": ""
                }
              },
              "item_id": 0,
              "name": "",
              "price": "",
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty": "",
              "quote_id": "",
              "sku": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {},
            "method": ""
          }
        }
      ]
    },
    "id": 0,
    "is_active": false,
    "is_virtual": false,
    "items": [
      {}
    ],
    "items_count": 0,
    "items_qty": "",
    "orig_order_id": 0,
    "reserved_order_id": "",
    "store_id": 0,
    "updated_at": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/carts/mine", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine"

payload = { "quote": {
        "billing_address": {
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": [
                {
                    "attribute_code": "",
                    "value": ""
                }
            ],
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": {
                "checkout_fields": [{}],
                "gift_registry_id": 0
            },
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": [],
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        },
        "converted_at": "",
        "created_at": "",
        "currency": {
            "base_currency_code": "",
            "base_to_global_rate": "",
            "base_to_quote_rate": "",
            "extension_attributes": {},
            "global_currency_code": "",
            "quote_currency_code": "",
            "store_currency_code": "",
            "store_to_base_rate": "",
            "store_to_quote_rate": ""
        },
        "customer": {
            "addresses": [
                {
                    "city": "",
                    "company": "",
                    "country_id": "",
                    "custom_attributes": [{}],
                    "customer_id": 0,
                    "default_billing": False,
                    "default_shipping": False,
                    "extension_attributes": {},
                    "fax": "",
                    "firstname": "",
                    "id": 0,
                    "lastname": "",
                    "middlename": "",
                    "postcode": "",
                    "prefix": "",
                    "region": {
                        "extension_attributes": {},
                        "region": "",
                        "region_code": "",
                        "region_id": 0
                    },
                    "region_id": 0,
                    "street": [],
                    "suffix": "",
                    "telephone": "",
                    "vat_id": ""
                }
            ],
            "confirmation": "",
            "created_at": "",
            "created_in": "",
            "custom_attributes": [{}],
            "default_billing": "",
            "default_shipping": "",
            "disable_auto_group_change": 0,
            "dob": "",
            "email": "",
            "extension_attributes": {
                "amazon_id": "",
                "company_attributes": {
                    "company_id": 0,
                    "customer_id": 0,
                    "extension_attributes": {},
                    "job_title": "",
                    "status": 0,
                    "telephone": ""
                },
                "is_subscribed": False,
                "vertex_customer_code": ""
            },
            "firstname": "",
            "gender": 0,
            "group_id": 0,
            "id": 0,
            "lastname": "",
            "middlename": "",
            "prefix": "",
            "store_id": 0,
            "suffix": "",
            "taxvat": "",
            "updated_at": "",
            "website_id": 0
        },
        "customer_is_guest": False,
        "customer_note": "",
        "customer_note_notify": False,
        "customer_tax_class_id": 0,
        "extension_attributes": {
            "amazon_order_reference_id": "",
            "negotiable_quote": {
                "applied_rule_ids": "",
                "base_negotiated_total_price": "",
                "base_original_total_price": "",
                "creator_id": 0,
                "creator_type": 0,
                "deleted_sku": "",
                "email_notification_status": 0,
                "expiration_period": "",
                "extension_attributes": {},
                "has_unconfirmed_changes": False,
                "is_address_draft": False,
                "is_customer_price_changed": False,
                "is_regular_quote": False,
                "is_shipping_tax_changed": False,
                "negotiated_price_type": 0,
                "negotiated_price_value": "",
                "negotiated_total_price": "",
                "notifications": 0,
                "original_total_price": "",
                "quote_id": 0,
                "quote_name": "",
                "shipping_price": "",
                "status": ""
            },
            "shipping_assignments": [
                {
                    "extension_attributes": {},
                    "items": [
                        {
                            "extension_attributes": { "negotiable_quote_item": {
                                    "extension_attributes": {},
                                    "item_id": 0,
                                    "original_discount_amount": "",
                                    "original_price": "",
                                    "original_tax_amount": ""
                                } },
                            "item_id": 0,
                            "name": "",
                            "price": "",
                            "product_option": { "extension_attributes": {
                                    "bundle_options": [
                                        {
                                            "extension_attributes": {},
                                            "option_id": 0,
                                            "option_qty": 0,
                                            "option_selections": []
                                        }
                                    ],
                                    "configurable_item_options": [
                                        {
                                            "extension_attributes": {},
                                            "option_id": "",
                                            "option_value": 0
                                        }
                                    ],
                                    "custom_options": [
                                        {
                                            "extension_attributes": { "file_info": {
                                                    "base64_encoded_data": "",
                                                    "name": "",
                                                    "type": ""
                                                } },
                                            "option_id": "",
                                            "option_value": ""
                                        }
                                    ],
                                    "downloadable_option": { "downloadable_links": [] },
                                    "giftcard_item_option": {
                                        "custom_giftcard_amount": "",
                                        "extension_attributes": {},
                                        "giftcard_amount": "",
                                        "giftcard_message": "",
                                        "giftcard_recipient_email": "",
                                        "giftcard_recipient_name": "",
                                        "giftcard_sender_email": "",
                                        "giftcard_sender_name": ""
                                    }
                                } },
                            "product_type": "",
                            "qty": "",
                            "quote_id": "",
                            "sku": ""
                        }
                    ],
                    "shipping": {
                        "address": {},
                        "extension_attributes": {},
                        "method": ""
                    }
                }
            ]
        },
        "id": 0,
        "is_active": False,
        "is_virtual": False,
        "items": [{}],
        "items_count": 0,
        "items_qty": "",
        "orig_order_id": 0,
        "reserved_order_id": "",
        "store_id": 0,
        "updated_at": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine"

payload <- "{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\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/V1/carts/mine') do |req|
  req.body = "{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\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}}/V1/carts/mine";

    let payload = json!({"quote": json!({
            "billing_address": json!({
                "city": "",
                "company": "",
                "country_id": "",
                "custom_attributes": (
                    json!({
                        "attribute_code": "",
                        "value": ""
                    })
                ),
                "customer_address_id": 0,
                "customer_id": 0,
                "email": "",
                "extension_attributes": json!({
                    "checkout_fields": (json!({})),
                    "gift_registry_id": 0
                }),
                "fax": "",
                "firstname": "",
                "id": 0,
                "lastname": "",
                "middlename": "",
                "postcode": "",
                "prefix": "",
                "region": "",
                "region_code": "",
                "region_id": 0,
                "same_as_billing": 0,
                "save_in_address_book": 0,
                "street": (),
                "suffix": "",
                "telephone": "",
                "vat_id": ""
            }),
            "converted_at": "",
            "created_at": "",
            "currency": json!({
                "base_currency_code": "",
                "base_to_global_rate": "",
                "base_to_quote_rate": "",
                "extension_attributes": json!({}),
                "global_currency_code": "",
                "quote_currency_code": "",
                "store_currency_code": "",
                "store_to_base_rate": "",
                "store_to_quote_rate": ""
            }),
            "customer": json!({
                "addresses": (
                    json!({
                        "city": "",
                        "company": "",
                        "country_id": "",
                        "custom_attributes": (json!({})),
                        "customer_id": 0,
                        "default_billing": false,
                        "default_shipping": false,
                        "extension_attributes": json!({}),
                        "fax": "",
                        "firstname": "",
                        "id": 0,
                        "lastname": "",
                        "middlename": "",
                        "postcode": "",
                        "prefix": "",
                        "region": json!({
                            "extension_attributes": json!({}),
                            "region": "",
                            "region_code": "",
                            "region_id": 0
                        }),
                        "region_id": 0,
                        "street": (),
                        "suffix": "",
                        "telephone": "",
                        "vat_id": ""
                    })
                ),
                "confirmation": "",
                "created_at": "",
                "created_in": "",
                "custom_attributes": (json!({})),
                "default_billing": "",
                "default_shipping": "",
                "disable_auto_group_change": 0,
                "dob": "",
                "email": "",
                "extension_attributes": json!({
                    "amazon_id": "",
                    "company_attributes": json!({
                        "company_id": 0,
                        "customer_id": 0,
                        "extension_attributes": json!({}),
                        "job_title": "",
                        "status": 0,
                        "telephone": ""
                    }),
                    "is_subscribed": false,
                    "vertex_customer_code": ""
                }),
                "firstname": "",
                "gender": 0,
                "group_id": 0,
                "id": 0,
                "lastname": "",
                "middlename": "",
                "prefix": "",
                "store_id": 0,
                "suffix": "",
                "taxvat": "",
                "updated_at": "",
                "website_id": 0
            }),
            "customer_is_guest": false,
            "customer_note": "",
            "customer_note_notify": false,
            "customer_tax_class_id": 0,
            "extension_attributes": json!({
                "amazon_order_reference_id": "",
                "negotiable_quote": json!({
                    "applied_rule_ids": "",
                    "base_negotiated_total_price": "",
                    "base_original_total_price": "",
                    "creator_id": 0,
                    "creator_type": 0,
                    "deleted_sku": "",
                    "email_notification_status": 0,
                    "expiration_period": "",
                    "extension_attributes": json!({}),
                    "has_unconfirmed_changes": false,
                    "is_address_draft": false,
                    "is_customer_price_changed": false,
                    "is_regular_quote": false,
                    "is_shipping_tax_changed": false,
                    "negotiated_price_type": 0,
                    "negotiated_price_value": "",
                    "negotiated_total_price": "",
                    "notifications": 0,
                    "original_total_price": "",
                    "quote_id": 0,
                    "quote_name": "",
                    "shipping_price": "",
                    "status": ""
                }),
                "shipping_assignments": (
                    json!({
                        "extension_attributes": json!({}),
                        "items": (
                            json!({
                                "extension_attributes": json!({"negotiable_quote_item": json!({
                                        "extension_attributes": json!({}),
                                        "item_id": 0,
                                        "original_discount_amount": "",
                                        "original_price": "",
                                        "original_tax_amount": ""
                                    })}),
                                "item_id": 0,
                                "name": "",
                                "price": "",
                                "product_option": json!({"extension_attributes": json!({
                                        "bundle_options": (
                                            json!({
                                                "extension_attributes": json!({}),
                                                "option_id": 0,
                                                "option_qty": 0,
                                                "option_selections": ()
                                            })
                                        ),
                                        "configurable_item_options": (
                                            json!({
                                                "extension_attributes": json!({}),
                                                "option_id": "",
                                                "option_value": 0
                                            })
                                        ),
                                        "custom_options": (
                                            json!({
                                                "extension_attributes": json!({"file_info": json!({
                                                        "base64_encoded_data": "",
                                                        "name": "",
                                                        "type": ""
                                                    })}),
                                                "option_id": "",
                                                "option_value": ""
                                            })
                                        ),
                                        "downloadable_option": json!({"downloadable_links": ()}),
                                        "giftcard_item_option": json!({
                                            "custom_giftcard_amount": "",
                                            "extension_attributes": json!({}),
                                            "giftcard_amount": "",
                                            "giftcard_message": "",
                                            "giftcard_recipient_email": "",
                                            "giftcard_recipient_name": "",
                                            "giftcard_sender_email": "",
                                            "giftcard_sender_name": ""
                                        })
                                    })}),
                                "product_type": "",
                                "qty": "",
                                "quote_id": "",
                                "sku": ""
                            })
                        ),
                        "shipping": json!({
                            "address": json!({}),
                            "extension_attributes": json!({}),
                            "method": ""
                        })
                    })
                )
            }),
            "id": 0,
            "is_active": false,
            "is_virtual": false,
            "items": (json!({})),
            "items_count": 0,
            "items_qty": "",
            "orig_order_id": 0,
            "reserved_order_id": "",
            "store_id": 0,
            "updated_at": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/carts/mine \
  --header 'content-type: application/json' \
  --data '{
  "quote": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "converted_at": "",
    "created_at": "",
    "currency": {
      "base_currency_code": "",
      "base_to_global_rate": "",
      "base_to_quote_rate": "",
      "extension_attributes": {},
      "global_currency_code": "",
      "quote_currency_code": "",
      "store_currency_code": "",
      "store_to_base_rate": "",
      "store_to_quote_rate": ""
    },
    "customer": {
      "addresses": [
        {
          "city": "",
          "company": "",
          "country_id": "",
          "custom_attributes": [
            {}
          ],
          "customer_id": 0,
          "default_billing": false,
          "default_shipping": false,
          "extension_attributes": {},
          "fax": "",
          "firstname": "",
          "id": 0,
          "lastname": "",
          "middlename": "",
          "postcode": "",
          "prefix": "",
          "region": {
            "extension_attributes": {},
            "region": "",
            "region_code": "",
            "region_id": 0
          },
          "region_id": 0,
          "street": [],
          "suffix": "",
          "telephone": "",
          "vat_id": ""
        }
      ],
      "confirmation": "",
      "created_at": "",
      "created_in": "",
      "custom_attributes": [
        {}
      ],
      "default_billing": "",
      "default_shipping": "",
      "disable_auto_group_change": 0,
      "dob": "",
      "email": "",
      "extension_attributes": {
        "amazon_id": "",
        "company_attributes": {
          "company_id": 0,
          "customer_id": 0,
          "extension_attributes": {},
          "job_title": "",
          "status": 0,
          "telephone": ""
        },
        "is_subscribed": false,
        "vertex_customer_code": ""
      },
      "firstname": "",
      "gender": 0,
      "group_id": 0,
      "id": 0,
      "lastname": "",
      "middlename": "",
      "prefix": "",
      "store_id": 0,
      "suffix": "",
      "taxvat": "",
      "updated_at": "",
      "website_id": 0
    },
    "customer_is_guest": false,
    "customer_note": "",
    "customer_note_notify": false,
    "customer_tax_class_id": 0,
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "negotiable_quote": {
        "applied_rule_ids": "",
        "base_negotiated_total_price": "",
        "base_original_total_price": "",
        "creator_id": 0,
        "creator_type": 0,
        "deleted_sku": "",
        "email_notification_status": 0,
        "expiration_period": "",
        "extension_attributes": {},
        "has_unconfirmed_changes": false,
        "is_address_draft": false,
        "is_customer_price_changed": false,
        "is_regular_quote": false,
        "is_shipping_tax_changed": false,
        "negotiated_price_type": 0,
        "negotiated_price_value": "",
        "negotiated_total_price": "",
        "notifications": 0,
        "original_total_price": "",
        "quote_id": 0,
        "quote_name": "",
        "shipping_price": "",
        "status": ""
      },
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "extension_attributes": {
                "negotiable_quote_item": {
                  "extension_attributes": {},
                  "item_id": 0,
                  "original_discount_amount": "",
                  "original_price": "",
                  "original_tax_amount": ""
                }
              },
              "item_id": 0,
              "name": "",
              "price": "",
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty": "",
              "quote_id": "",
              "sku": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {},
            "method": ""
          }
        }
      ]
    },
    "id": 0,
    "is_active": false,
    "is_virtual": false,
    "items": [
      {}
    ],
    "items_count": 0,
    "items_qty": "",
    "orig_order_id": 0,
    "reserved_order_id": "",
    "store_id": 0,
    "updated_at": ""
  }
}'
echo '{
  "quote": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "converted_at": "",
    "created_at": "",
    "currency": {
      "base_currency_code": "",
      "base_to_global_rate": "",
      "base_to_quote_rate": "",
      "extension_attributes": {},
      "global_currency_code": "",
      "quote_currency_code": "",
      "store_currency_code": "",
      "store_to_base_rate": "",
      "store_to_quote_rate": ""
    },
    "customer": {
      "addresses": [
        {
          "city": "",
          "company": "",
          "country_id": "",
          "custom_attributes": [
            {}
          ],
          "customer_id": 0,
          "default_billing": false,
          "default_shipping": false,
          "extension_attributes": {},
          "fax": "",
          "firstname": "",
          "id": 0,
          "lastname": "",
          "middlename": "",
          "postcode": "",
          "prefix": "",
          "region": {
            "extension_attributes": {},
            "region": "",
            "region_code": "",
            "region_id": 0
          },
          "region_id": 0,
          "street": [],
          "suffix": "",
          "telephone": "",
          "vat_id": ""
        }
      ],
      "confirmation": "",
      "created_at": "",
      "created_in": "",
      "custom_attributes": [
        {}
      ],
      "default_billing": "",
      "default_shipping": "",
      "disable_auto_group_change": 0,
      "dob": "",
      "email": "",
      "extension_attributes": {
        "amazon_id": "",
        "company_attributes": {
          "company_id": 0,
          "customer_id": 0,
          "extension_attributes": {},
          "job_title": "",
          "status": 0,
          "telephone": ""
        },
        "is_subscribed": false,
        "vertex_customer_code": ""
      },
      "firstname": "",
      "gender": 0,
      "group_id": 0,
      "id": 0,
      "lastname": "",
      "middlename": "",
      "prefix": "",
      "store_id": 0,
      "suffix": "",
      "taxvat": "",
      "updated_at": "",
      "website_id": 0
    },
    "customer_is_guest": false,
    "customer_note": "",
    "customer_note_notify": false,
    "customer_tax_class_id": 0,
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "negotiable_quote": {
        "applied_rule_ids": "",
        "base_negotiated_total_price": "",
        "base_original_total_price": "",
        "creator_id": 0,
        "creator_type": 0,
        "deleted_sku": "",
        "email_notification_status": 0,
        "expiration_period": "",
        "extension_attributes": {},
        "has_unconfirmed_changes": false,
        "is_address_draft": false,
        "is_customer_price_changed": false,
        "is_regular_quote": false,
        "is_shipping_tax_changed": false,
        "negotiated_price_type": 0,
        "negotiated_price_value": "",
        "negotiated_total_price": "",
        "notifications": 0,
        "original_total_price": "",
        "quote_id": 0,
        "quote_name": "",
        "shipping_price": "",
        "status": ""
      },
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "extension_attributes": {
                "negotiable_quote_item": {
                  "extension_attributes": {},
                  "item_id": 0,
                  "original_discount_amount": "",
                  "original_price": "",
                  "original_tax_amount": ""
                }
              },
              "item_id": 0,
              "name": "",
              "price": "",
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty": "",
              "quote_id": "",
              "sku": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {},
            "method": ""
          }
        }
      ]
    },
    "id": 0,
    "is_active": false,
    "is_virtual": false,
    "items": [
      {}
    ],
    "items_count": 0,
    "items_qty": "",
    "orig_order_id": 0,
    "reserved_order_id": "",
    "store_id": 0,
    "updated_at": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/carts/mine \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "quote": {\n    "billing_address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "converted_at": "",\n    "created_at": "",\n    "currency": {\n      "base_currency_code": "",\n      "base_to_global_rate": "",\n      "base_to_quote_rate": "",\n      "extension_attributes": {},\n      "global_currency_code": "",\n      "quote_currency_code": "",\n      "store_currency_code": "",\n      "store_to_base_rate": "",\n      "store_to_quote_rate": ""\n    },\n    "customer": {\n      "addresses": [\n        {\n          "city": "",\n          "company": "",\n          "country_id": "",\n          "custom_attributes": [\n            {}\n          ],\n          "customer_id": 0,\n          "default_billing": false,\n          "default_shipping": false,\n          "extension_attributes": {},\n          "fax": "",\n          "firstname": "",\n          "id": 0,\n          "lastname": "",\n          "middlename": "",\n          "postcode": "",\n          "prefix": "",\n          "region": {\n            "extension_attributes": {},\n            "region": "",\n            "region_code": "",\n            "region_id": 0\n          },\n          "region_id": 0,\n          "street": [],\n          "suffix": "",\n          "telephone": "",\n          "vat_id": ""\n        }\n      ],\n      "confirmation": "",\n      "created_at": "",\n      "created_in": "",\n      "custom_attributes": [\n        {}\n      ],\n      "default_billing": "",\n      "default_shipping": "",\n      "disable_auto_group_change": 0,\n      "dob": "",\n      "email": "",\n      "extension_attributes": {\n        "amazon_id": "",\n        "company_attributes": {\n          "company_id": 0,\n          "customer_id": 0,\n          "extension_attributes": {},\n          "job_title": "",\n          "status": 0,\n          "telephone": ""\n        },\n        "is_subscribed": false,\n        "vertex_customer_code": ""\n      },\n      "firstname": "",\n      "gender": 0,\n      "group_id": 0,\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "prefix": "",\n      "store_id": 0,\n      "suffix": "",\n      "taxvat": "",\n      "updated_at": "",\n      "website_id": 0\n    },\n    "customer_is_guest": false,\n    "customer_note": "",\n    "customer_note_notify": false,\n    "customer_tax_class_id": 0,\n    "extension_attributes": {\n      "amazon_order_reference_id": "",\n      "negotiable_quote": {\n        "applied_rule_ids": "",\n        "base_negotiated_total_price": "",\n        "base_original_total_price": "",\n        "creator_id": 0,\n        "creator_type": 0,\n        "deleted_sku": "",\n        "email_notification_status": 0,\n        "expiration_period": "",\n        "extension_attributes": {},\n        "has_unconfirmed_changes": false,\n        "is_address_draft": false,\n        "is_customer_price_changed": false,\n        "is_regular_quote": false,\n        "is_shipping_tax_changed": false,\n        "negotiated_price_type": 0,\n        "negotiated_price_value": "",\n        "negotiated_total_price": "",\n        "notifications": 0,\n        "original_total_price": "",\n        "quote_id": 0,\n        "quote_name": "",\n        "shipping_price": "",\n        "status": ""\n      },\n      "shipping_assignments": [\n        {\n          "extension_attributes": {},\n          "items": [\n            {\n              "extension_attributes": {\n                "negotiable_quote_item": {\n                  "extension_attributes": {},\n                  "item_id": 0,\n                  "original_discount_amount": "",\n                  "original_price": "",\n                  "original_tax_amount": ""\n                }\n              },\n              "item_id": 0,\n              "name": "",\n              "price": "",\n              "product_option": {\n                "extension_attributes": {\n                  "bundle_options": [\n                    {\n                      "extension_attributes": {},\n                      "option_id": 0,\n                      "option_qty": 0,\n                      "option_selections": []\n                    }\n                  ],\n                  "configurable_item_options": [\n                    {\n                      "extension_attributes": {},\n                      "option_id": "",\n                      "option_value": 0\n                    }\n                  ],\n                  "custom_options": [\n                    {\n                      "extension_attributes": {\n                        "file_info": {\n                          "base64_encoded_data": "",\n                          "name": "",\n                          "type": ""\n                        }\n                      },\n                      "option_id": "",\n                      "option_value": ""\n                    }\n                  ],\n                  "downloadable_option": {\n                    "downloadable_links": []\n                  },\n                  "giftcard_item_option": {\n                    "custom_giftcard_amount": "",\n                    "extension_attributes": {},\n                    "giftcard_amount": "",\n                    "giftcard_message": "",\n                    "giftcard_recipient_email": "",\n                    "giftcard_recipient_name": "",\n                    "giftcard_sender_email": "",\n                    "giftcard_sender_name": ""\n                  }\n                }\n              },\n              "product_type": "",\n              "qty": "",\n              "quote_id": "",\n              "sku": ""\n            }\n          ],\n          "shipping": {\n            "address": {},\n            "extension_attributes": {},\n            "method": ""\n          }\n        }\n      ]\n    },\n    "id": 0,\n    "is_active": false,\n    "is_virtual": false,\n    "items": [\n      {}\n    ],\n    "items_count": 0,\n    "items_qty": "",\n    "orig_order_id": 0,\n    "reserved_order_id": "",\n    "store_id": 0,\n    "updated_at": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["quote": [
    "billing_address": [
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        [
          "attribute_code": "",
          "value": ""
        ]
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": [
        "checkout_fields": [[]],
        "gift_registry_id": 0
      ],
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    ],
    "converted_at": "",
    "created_at": "",
    "currency": [
      "base_currency_code": "",
      "base_to_global_rate": "",
      "base_to_quote_rate": "",
      "extension_attributes": [],
      "global_currency_code": "",
      "quote_currency_code": "",
      "store_currency_code": "",
      "store_to_base_rate": "",
      "store_to_quote_rate": ""
    ],
    "customer": [
      "addresses": [
        [
          "city": "",
          "company": "",
          "country_id": "",
          "custom_attributes": [[]],
          "customer_id": 0,
          "default_billing": false,
          "default_shipping": false,
          "extension_attributes": [],
          "fax": "",
          "firstname": "",
          "id": 0,
          "lastname": "",
          "middlename": "",
          "postcode": "",
          "prefix": "",
          "region": [
            "extension_attributes": [],
            "region": "",
            "region_code": "",
            "region_id": 0
          ],
          "region_id": 0,
          "street": [],
          "suffix": "",
          "telephone": "",
          "vat_id": ""
        ]
      ],
      "confirmation": "",
      "created_at": "",
      "created_in": "",
      "custom_attributes": [[]],
      "default_billing": "",
      "default_shipping": "",
      "disable_auto_group_change": 0,
      "dob": "",
      "email": "",
      "extension_attributes": [
        "amazon_id": "",
        "company_attributes": [
          "company_id": 0,
          "customer_id": 0,
          "extension_attributes": [],
          "job_title": "",
          "status": 0,
          "telephone": ""
        ],
        "is_subscribed": false,
        "vertex_customer_code": ""
      ],
      "firstname": "",
      "gender": 0,
      "group_id": 0,
      "id": 0,
      "lastname": "",
      "middlename": "",
      "prefix": "",
      "store_id": 0,
      "suffix": "",
      "taxvat": "",
      "updated_at": "",
      "website_id": 0
    ],
    "customer_is_guest": false,
    "customer_note": "",
    "customer_note_notify": false,
    "customer_tax_class_id": 0,
    "extension_attributes": [
      "amazon_order_reference_id": "",
      "negotiable_quote": [
        "applied_rule_ids": "",
        "base_negotiated_total_price": "",
        "base_original_total_price": "",
        "creator_id": 0,
        "creator_type": 0,
        "deleted_sku": "",
        "email_notification_status": 0,
        "expiration_period": "",
        "extension_attributes": [],
        "has_unconfirmed_changes": false,
        "is_address_draft": false,
        "is_customer_price_changed": false,
        "is_regular_quote": false,
        "is_shipping_tax_changed": false,
        "negotiated_price_type": 0,
        "negotiated_price_value": "",
        "negotiated_total_price": "",
        "notifications": 0,
        "original_total_price": "",
        "quote_id": 0,
        "quote_name": "",
        "shipping_price": "",
        "status": ""
      ],
      "shipping_assignments": [
        [
          "extension_attributes": [],
          "items": [
            [
              "extension_attributes": ["negotiable_quote_item": [
                  "extension_attributes": [],
                  "item_id": 0,
                  "original_discount_amount": "",
                  "original_price": "",
                  "original_tax_amount": ""
                ]],
              "item_id": 0,
              "name": "",
              "price": "",
              "product_option": ["extension_attributes": [
                  "bundle_options": [
                    [
                      "extension_attributes": [],
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    ]
                  ],
                  "configurable_item_options": [
                    [
                      "extension_attributes": [],
                      "option_id": "",
                      "option_value": 0
                    ]
                  ],
                  "custom_options": [
                    [
                      "extension_attributes": ["file_info": [
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        ]],
                      "option_id": "",
                      "option_value": ""
                    ]
                  ],
                  "downloadable_option": ["downloadable_links": []],
                  "giftcard_item_option": [
                    "custom_giftcard_amount": "",
                    "extension_attributes": [],
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  ]
                ]],
              "product_type": "",
              "qty": "",
              "quote_id": "",
              "sku": ""
            ]
          ],
          "shipping": [
            "address": [],
            "extension_attributes": [],
            "method": ""
          ]
        ]
      ]
    ],
    "id": 0,
    "is_active": false,
    "is_virtual": false,
    "items": [[]],
    "items_count": 0,
    "items_qty": "",
    "orig_order_id": 0,
    "reserved_order_id": "",
    "store_id": 0,
    "updated_at": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine")! 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 carts-mine
{{baseUrl}}/V1/carts/mine
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/mine")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/mine HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/mine")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/mine")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/mine');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/mine'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/mine'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/mine');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/mine'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/mine');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/mine")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/mine') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/mine
http GET {{baseUrl}}/V1/carts/mine
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/mine
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-mine-balance-apply
{{baseUrl}}/V1/carts/mine/balance/apply
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/balance/apply");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/mine/balance/apply")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/balance/apply"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/balance/apply"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/balance/apply");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/balance/apply"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/mine/balance/apply HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/mine/balance/apply")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/balance/apply"))
    .method("POST", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/balance/apply")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/mine/balance/apply")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/carts/mine/balance/apply');

xhr.send(data);
import axios from 'axios';

const options = {method: 'POST', url: '{{baseUrl}}/V1/carts/mine/balance/apply'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/balance/apply';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/balance/apply',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/balance/apply")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/balance/apply',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'POST', url: '{{baseUrl}}/V1/carts/mine/balance/apply'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/carts/mine/balance/apply');

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}}/V1/carts/mine/balance/apply'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/balance/apply';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/balance/apply"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/balance/apply" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/balance/apply",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/mine/balance/apply');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/balance/apply');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/balance/apply');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/balance/apply' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/balance/apply' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/V1/carts/mine/balance/apply")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/balance/apply"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/balance/apply"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/balance/apply")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/V1/carts/mine/balance/apply') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/balance/apply";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/mine/balance/apply
http POST {{baseUrl}}/V1/carts/mine/balance/apply
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/balance/apply
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/balance/apply")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-mine-balance-unapply
{{baseUrl}}/V1/carts/mine/balance/unapply
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/balance/unapply");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/mine/balance/unapply")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/balance/unapply"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/balance/unapply"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/balance/unapply");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/balance/unapply"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/mine/balance/unapply HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/mine/balance/unapply")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/balance/unapply"))
    .method("POST", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/balance/unapply")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/mine/balance/unapply")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/carts/mine/balance/unapply');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/balance/unapply'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/balance/unapply';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/balance/unapply',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/balance/unapply")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/balance/unapply',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/balance/unapply'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/carts/mine/balance/unapply');

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}}/V1/carts/mine/balance/unapply'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/balance/unapply';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/balance/unapply"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/balance/unapply" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/balance/unapply",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/mine/balance/unapply');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/balance/unapply');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/balance/unapply');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/balance/unapply' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/balance/unapply' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/V1/carts/mine/balance/unapply")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/balance/unapply"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/balance/unapply"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/balance/unapply")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/V1/carts/mine/balance/unapply') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/balance/unapply";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/mine/balance/unapply
http POST {{baseUrl}}/V1/carts/mine/balance/unapply
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/balance/unapply
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/balance/unapply")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-mine-billing-address (POST)
{{baseUrl}}/V1/carts/mine/billing-address
BODY json

{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/billing-address");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/mine/billing-address" {:content-type :json
                                                                          :form-params {:address {:city ""
                                                                                                  :company ""
                                                                                                  :country_id ""
                                                                                                  :custom_attributes [{:attribute_code ""
                                                                                                                       :value ""}]
                                                                                                  :customer_address_id 0
                                                                                                  :customer_id 0
                                                                                                  :email ""
                                                                                                  :extension_attributes {:checkout_fields [{}]
                                                                                                                         :gift_registry_id 0}
                                                                                                  :fax ""
                                                                                                  :firstname ""
                                                                                                  :id 0
                                                                                                  :lastname ""
                                                                                                  :middlename ""
                                                                                                  :postcode ""
                                                                                                  :prefix ""
                                                                                                  :region ""
                                                                                                  :region_code ""
                                                                                                  :region_id 0
                                                                                                  :same_as_billing 0
                                                                                                  :save_in_address_book 0
                                                                                                  :street []
                                                                                                  :suffix ""
                                                                                                  :telephone ""
                                                                                                  :vat_id ""}
                                                                                        :useForShipping false}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/billing-address"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": 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}}/V1/carts/mine/billing-address"),
    Content = new StringContent("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": 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}}/V1/carts/mine/billing-address");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/billing-address"

	payload := strings.NewReader("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/mine/billing-address HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 708

{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/mine/billing-address")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/billing-address"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": 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\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/billing-address")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/mine/billing-address")
  .header("content-type", "application/json")
  .body("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}")
  .asString();
const data = JSON.stringify({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  useForShipping: 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}}/V1/carts/mine/billing-address');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/billing-address',
  headers: {'content-type': 'application/json'},
  data: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    useForShipping: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/billing-address';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"useForShipping":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}}/V1/carts/mine/billing-address',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "useForShipping": 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\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/billing-address")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/billing-address',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  useForShipping: false
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/billing-address',
  headers: {'content-type': 'application/json'},
  body: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    useForShipping: 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}}/V1/carts/mine/billing-address');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  useForShipping: 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}}/V1/carts/mine/billing-address',
  headers: {'content-type': 'application/json'},
  data: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    useForShipping: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/billing-address';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"useForShipping":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" },
                              @"useForShipping": @NO };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/billing-address"]
                                                       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}}/V1/carts/mine/billing-address" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/billing-address",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'useForShipping' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/mine/billing-address', [
  'body' => '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/billing-address');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'useForShipping' => null
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'useForShipping' => null
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/billing-address');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/billing-address' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/billing-address' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/mine/billing-address", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/billing-address"

payload = {
    "address": {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "extension_attributes": {
            "checkout_fields": [{}],
            "gift_registry_id": 0
        },
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "same_as_billing": 0,
        "save_in_address_book": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
    },
    "useForShipping": False
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/billing-address"

payload <- "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/billing-address")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": 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/V1/carts/mine/billing-address') do |req|
  req.body = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/billing-address";

    let payload = json!({
        "address": json!({
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": json!({
                "checkout_fields": (json!({})),
                "gift_registry_id": 0
            }),
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": (),
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        }),
        "useForShipping": false
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/mine/billing-address \
  --header 'content-type: application/json' \
  --data '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}'
echo '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}' |  \
  http POST {{baseUrl}}/V1/carts/mine/billing-address \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "address": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "useForShipping": false\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/billing-address
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "address": [
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": [
      "checkout_fields": [[]],
      "gift_registry_id": 0
    ],
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  ],
  "useForShipping": false
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/billing-address")! 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 carts-mine-billing-address
{{baseUrl}}/V1/carts/mine/billing-address
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/billing-address");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/mine/billing-address")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/billing-address"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/billing-address"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/billing-address");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/billing-address"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/mine/billing-address HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/mine/billing-address")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/billing-address"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/billing-address")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/mine/billing-address")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/mine/billing-address');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/billing-address'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/billing-address';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/billing-address',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/billing-address")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/billing-address',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/billing-address'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/mine/billing-address');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/billing-address'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/billing-address';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/billing-address"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/billing-address" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/billing-address",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/mine/billing-address');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/billing-address');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/billing-address');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/billing-address' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/billing-address' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/mine/billing-address")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/billing-address"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/billing-address"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/billing-address")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/mine/billing-address') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/billing-address";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/mine/billing-address
http GET {{baseUrl}}/V1/carts/mine/billing-address
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/billing-address
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/billing-address")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET carts-mine-checkGiftCard-{giftCardCode}
{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode
QUERY PARAMS

giftCardCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/mine/checkGiftCard/:giftCardCode HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/checkGiftCard/:giftCardCode',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/mine/checkGiftCard/:giftCardCode")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/mine/checkGiftCard/:giftCardCode') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode
http GET {{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/checkGiftCard/:giftCardCode")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-mine-checkout-fields
{{baseUrl}}/V1/carts/mine/checkout-fields
BODY json

{
  "serviceSelection": [
    {
      "attribute_code": "",
      "value": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/checkout-fields");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/mine/checkout-fields" {:content-type :json
                                                                          :form-params {:serviceSelection [{:attribute_code ""
                                                                                                            :value ""}]}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/checkout-fields"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\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}}/V1/carts/mine/checkout-fields"),
    Content = new StringContent("{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\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}}/V1/carts/mine/checkout-fields");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/checkout-fields"

	payload := strings.NewReader("{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/mine/checkout-fields HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 89

{
  "serviceSelection": [
    {
      "attribute_code": "",
      "value": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/mine/checkout-fields")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/checkout-fields"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\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  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/checkout-fields")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/mine/checkout-fields")
  .header("content-type", "application/json")
  .body("{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  serviceSelection: [
    {
      attribute_code: '',
      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}}/V1/carts/mine/checkout-fields');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/checkout-fields',
  headers: {'content-type': 'application/json'},
  data: {serviceSelection: [{attribute_code: '', value: ''}]}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/checkout-fields';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"serviceSelection":[{"attribute_code":"","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}}/V1/carts/mine/checkout-fields',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "serviceSelection": [\n    {\n      "attribute_code": "",\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  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/checkout-fields")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/checkout-fields',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({serviceSelection: [{attribute_code: '', value: ''}]}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/checkout-fields',
  headers: {'content-type': 'application/json'},
  body: {serviceSelection: [{attribute_code: '', 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}}/V1/carts/mine/checkout-fields');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  serviceSelection: [
    {
      attribute_code: '',
      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}}/V1/carts/mine/checkout-fields',
  headers: {'content-type': 'application/json'},
  data: {serviceSelection: [{attribute_code: '', value: ''}]}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/checkout-fields';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"serviceSelection":[{"attribute_code":"","value":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"serviceSelection": @[ @{ @"attribute_code": @"", @"value": @"" } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/checkout-fields"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/checkout-fields" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/checkout-fields",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'serviceSelection' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/mine/checkout-fields', [
  'body' => '{
  "serviceSelection": [
    {
      "attribute_code": "",
      "value": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/checkout-fields');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'serviceSelection' => [
    [
        'attribute_code' => '',
        'value' => ''
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'serviceSelection' => [
    [
        'attribute_code' => '',
        'value' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/checkout-fields');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/checkout-fields' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "serviceSelection": [
    {
      "attribute_code": "",
      "value": ""
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/checkout-fields' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "serviceSelection": [
    {
      "attribute_code": "",
      "value": ""
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/mine/checkout-fields", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/checkout-fields"

payload = { "serviceSelection": [
        {
            "attribute_code": "",
            "value": ""
        }
    ] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/checkout-fields"

payload <- "{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/checkout-fields")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\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/V1/carts/mine/checkout-fields') do |req|
  req.body = "{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\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}}/V1/carts/mine/checkout-fields";

    let payload = json!({"serviceSelection": (
            json!({
                "attribute_code": "",
                "value": ""
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/mine/checkout-fields \
  --header 'content-type: application/json' \
  --data '{
  "serviceSelection": [
    {
      "attribute_code": "",
      "value": ""
    }
  ]
}'
echo '{
  "serviceSelection": [
    {
      "attribute_code": "",
      "value": ""
    }
  ]
}' |  \
  http POST {{baseUrl}}/V1/carts/mine/checkout-fields \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "serviceSelection": [\n    {\n      "attribute_code": "",\n      "value": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/checkout-fields
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["serviceSelection": [
    [
      "attribute_code": "",
      "value": ""
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/checkout-fields")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT carts-mine-collect-totals
{{baseUrl}}/V1/carts/mine/collect-totals
BODY json

{
  "additionalData": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "gift_messages": [
        {
          "customer_id": 0,
          "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": false,
            "wrapping_allow_gift_receipt": false,
            "wrapping_id": 0
          },
          "gift_message_id": 0,
          "message": "",
          "recipient": "",
          "sender": ""
        }
      ]
    }
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  },
  "shippingCarrierCode": "",
  "shippingMethodCode": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/collect-totals");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/carts/mine/collect-totals" {:content-type :json
                                                                        :form-params {:additionalData {:custom_attributes [{:attribute_code ""
                                                                                                                            :value ""}]
                                                                                                       :extension_attributes {:gift_messages [{:customer_id 0
                                                                                                                                               :extension_attributes {:entity_id ""
                                                                                                                                                                      :entity_type ""
                                                                                                                                                                      :wrapping_add_printed_card false
                                                                                                                                                                      :wrapping_allow_gift_receipt false
                                                                                                                                                                      :wrapping_id 0}
                                                                                                                                               :gift_message_id 0
                                                                                                                                               :message ""
                                                                                                                                               :recipient ""
                                                                                                                                               :sender ""}]}}
                                                                                      :paymentMethod {:additional_data []
                                                                                                      :extension_attributes {:agreement_ids []}
                                                                                                      :method ""
                                                                                                      :po_number ""}
                                                                                      :shippingCarrierCode ""
                                                                                      :shippingMethodCode ""}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/collect-totals"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\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}}/V1/carts/mine/collect-totals"),
    Content = new StringContent("{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\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}}/V1/carts/mine/collect-totals");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/collect-totals"

	payload := strings.NewReader("{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/carts/mine/collect-totals HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 800

{
  "additionalData": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "gift_messages": [
        {
          "customer_id": 0,
          "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": false,
            "wrapping_allow_gift_receipt": false,
            "wrapping_id": 0
          },
          "gift_message_id": 0,
          "message": "",
          "recipient": "",
          "sender": ""
        }
      ]
    }
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  },
  "shippingCarrierCode": "",
  "shippingMethodCode": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/carts/mine/collect-totals")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/collect-totals"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\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  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/collect-totals")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/carts/mine/collect-totals")
  .header("content-type", "application/json")
  .body("{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  additionalData: {
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    extension_attributes: {
      gift_messages: [
        {
          customer_id: 0,
          extension_attributes: {
            entity_id: '',
            entity_type: '',
            wrapping_add_printed_card: false,
            wrapping_allow_gift_receipt: false,
            wrapping_id: 0
          },
          gift_message_id: 0,
          message: '',
          recipient: '',
          sender: ''
        }
      ]
    }
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  },
  shippingCarrierCode: '',
  shippingMethodCode: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/carts/mine/collect-totals');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/mine/collect-totals',
  headers: {'content-type': 'application/json'},
  data: {
    additionalData: {
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {
        gift_messages: [
          {
            customer_id: 0,
            extension_attributes: {
              entity_id: '',
              entity_type: '',
              wrapping_add_printed_card: false,
              wrapping_allow_gift_receipt: false,
              wrapping_id: 0
            },
            gift_message_id: 0,
            message: '',
            recipient: '',
            sender: ''
          }
        ]
      }
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    },
    shippingCarrierCode: '',
    shippingMethodCode: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/collect-totals';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"additionalData":{"custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{"gift_messages":[{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""}]}},"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""},"shippingCarrierCode":"","shippingMethodCode":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/collect-totals',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "additionalData": {\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "extension_attributes": {\n      "gift_messages": [\n        {\n          "customer_id": 0,\n          "extension_attributes": {\n            "entity_id": "",\n            "entity_type": "",\n            "wrapping_add_printed_card": false,\n            "wrapping_allow_gift_receipt": false,\n            "wrapping_id": 0\n          },\n          "gift_message_id": 0,\n          "message": "",\n          "recipient": "",\n          "sender": ""\n        }\n      ]\n    }\n  },\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\n  },\n  "shippingCarrierCode": "",\n  "shippingMethodCode": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/collect-totals")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/collect-totals',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  additionalData: {
    custom_attributes: [{attribute_code: '', value: ''}],
    extension_attributes: {
      gift_messages: [
        {
          customer_id: 0,
          extension_attributes: {
            entity_id: '',
            entity_type: '',
            wrapping_add_printed_card: false,
            wrapping_allow_gift_receipt: false,
            wrapping_id: 0
          },
          gift_message_id: 0,
          message: '',
          recipient: '',
          sender: ''
        }
      ]
    }
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {agreement_ids: []},
    method: '',
    po_number: ''
  },
  shippingCarrierCode: '',
  shippingMethodCode: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/mine/collect-totals',
  headers: {'content-type': 'application/json'},
  body: {
    additionalData: {
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {
        gift_messages: [
          {
            customer_id: 0,
            extension_attributes: {
              entity_id: '',
              entity_type: '',
              wrapping_add_printed_card: false,
              wrapping_allow_gift_receipt: false,
              wrapping_id: 0
            },
            gift_message_id: 0,
            message: '',
            recipient: '',
            sender: ''
          }
        ]
      }
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    },
    shippingCarrierCode: '',
    shippingMethodCode: ''
  },
  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}}/V1/carts/mine/collect-totals');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  additionalData: {
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    extension_attributes: {
      gift_messages: [
        {
          customer_id: 0,
          extension_attributes: {
            entity_id: '',
            entity_type: '',
            wrapping_add_printed_card: false,
            wrapping_allow_gift_receipt: false,
            wrapping_id: 0
          },
          gift_message_id: 0,
          message: '',
          recipient: '',
          sender: ''
        }
      ]
    }
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  },
  shippingCarrierCode: '',
  shippingMethodCode: ''
});

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}}/V1/carts/mine/collect-totals',
  headers: {'content-type': 'application/json'},
  data: {
    additionalData: {
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {
        gift_messages: [
          {
            customer_id: 0,
            extension_attributes: {
              entity_id: '',
              entity_type: '',
              wrapping_add_printed_card: false,
              wrapping_allow_gift_receipt: false,
              wrapping_id: 0
            },
            gift_message_id: 0,
            message: '',
            recipient: '',
            sender: ''
          }
        ]
      }
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    },
    shippingCarrierCode: '',
    shippingMethodCode: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/collect-totals';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"additionalData":{"custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{"gift_messages":[{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""}]}},"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""},"shippingCarrierCode":"","shippingMethodCode":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"additionalData": @{ @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"extension_attributes": @{ @"gift_messages": @[ @{ @"customer_id": @0, @"extension_attributes": @{ @"entity_id": @"", @"entity_type": @"", @"wrapping_add_printed_card": @NO, @"wrapping_allow_gift_receipt": @NO, @"wrapping_id": @0 }, @"gift_message_id": @0, @"message": @"", @"recipient": @"", @"sender": @"" } ] } },
                              @"paymentMethod": @{ @"additional_data": @[  ], @"extension_attributes": @{ @"agreement_ids": @[  ] }, @"method": @"", @"po_number": @"" },
                              @"shippingCarrierCode": @"",
                              @"shippingMethodCode": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/collect-totals"]
                                                       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}}/V1/carts/mine/collect-totals" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/collect-totals",
  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([
    'additionalData' => [
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'extension_attributes' => [
                'gift_messages' => [
                                [
                                                                'customer_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                'entity_id' => '',
                                                                                                                                'entity_type' => '',
                                                                                                                                'wrapping_add_printed_card' => null,
                                                                                                                                'wrapping_allow_gift_receipt' => null,
                                                                                                                                'wrapping_id' => 0
                                                                ],
                                                                'gift_message_id' => 0,
                                                                'message' => '',
                                                                'recipient' => '',
                                                                'sender' => ''
                                ]
                ]
        ]
    ],
    'paymentMethod' => [
        'additional_data' => [
                
        ],
        'extension_attributes' => [
                'agreement_ids' => [
                                
                ]
        ],
        'method' => '',
        'po_number' => ''
    ],
    'shippingCarrierCode' => '',
    'shippingMethodCode' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/carts/mine/collect-totals', [
  'body' => '{
  "additionalData": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "gift_messages": [
        {
          "customer_id": 0,
          "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": false,
            "wrapping_allow_gift_receipt": false,
            "wrapping_id": 0
          },
          "gift_message_id": 0,
          "message": "",
          "recipient": "",
          "sender": ""
        }
      ]
    }
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  },
  "shippingCarrierCode": "",
  "shippingMethodCode": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/collect-totals');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'additionalData' => [
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'extension_attributes' => [
        'gift_messages' => [
                [
                                'customer_id' => 0,
                                'extension_attributes' => [
                                                                'entity_id' => '',
                                                                'entity_type' => '',
                                                                'wrapping_add_printed_card' => null,
                                                                'wrapping_allow_gift_receipt' => null,
                                                                'wrapping_id' => 0
                                ],
                                'gift_message_id' => 0,
                                'message' => '',
                                'recipient' => '',
                                'sender' => ''
                ]
        ]
    ]
  ],
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ],
  'shippingCarrierCode' => '',
  'shippingMethodCode' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'additionalData' => [
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'extension_attributes' => [
        'gift_messages' => [
                [
                                'customer_id' => 0,
                                'extension_attributes' => [
                                                                'entity_id' => '',
                                                                'entity_type' => '',
                                                                'wrapping_add_printed_card' => null,
                                                                'wrapping_allow_gift_receipt' => null,
                                                                'wrapping_id' => 0
                                ],
                                'gift_message_id' => 0,
                                'message' => '',
                                'recipient' => '',
                                'sender' => ''
                ]
        ]
    ]
  ],
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ],
  'shippingCarrierCode' => '',
  'shippingMethodCode' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/collect-totals');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/collect-totals' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "additionalData": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "gift_messages": [
        {
          "customer_id": 0,
          "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": false,
            "wrapping_allow_gift_receipt": false,
            "wrapping_id": 0
          },
          "gift_message_id": 0,
          "message": "",
          "recipient": "",
          "sender": ""
        }
      ]
    }
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  },
  "shippingCarrierCode": "",
  "shippingMethodCode": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/collect-totals' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "additionalData": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "gift_messages": [
        {
          "customer_id": 0,
          "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": false,
            "wrapping_allow_gift_receipt": false,
            "wrapping_id": 0
          },
          "gift_message_id": 0,
          "message": "",
          "recipient": "",
          "sender": ""
        }
      ]
    }
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  },
  "shippingCarrierCode": "",
  "shippingMethodCode": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/carts/mine/collect-totals", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/collect-totals"

payload = {
    "additionalData": {
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "extension_attributes": { "gift_messages": [
                {
                    "customer_id": 0,
                    "extension_attributes": {
                        "entity_id": "",
                        "entity_type": "",
                        "wrapping_add_printed_card": False,
                        "wrapping_allow_gift_receipt": False,
                        "wrapping_id": 0
                    },
                    "gift_message_id": 0,
                    "message": "",
                    "recipient": "",
                    "sender": ""
                }
            ] }
    },
    "paymentMethod": {
        "additional_data": [],
        "extension_attributes": { "agreement_ids": [] },
        "method": "",
        "po_number": ""
    },
    "shippingCarrierCode": "",
    "shippingMethodCode": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/collect-totals"

payload <- "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/collect-totals")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\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/V1/carts/mine/collect-totals') do |req|
  req.body = "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\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}}/V1/carts/mine/collect-totals";

    let payload = json!({
        "additionalData": json!({
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "extension_attributes": json!({"gift_messages": (
                    json!({
                        "customer_id": 0,
                        "extension_attributes": json!({
                            "entity_id": "",
                            "entity_type": "",
                            "wrapping_add_printed_card": false,
                            "wrapping_allow_gift_receipt": false,
                            "wrapping_id": 0
                        }),
                        "gift_message_id": 0,
                        "message": "",
                        "recipient": "",
                        "sender": ""
                    })
                )})
        }),
        "paymentMethod": json!({
            "additional_data": (),
            "extension_attributes": json!({"agreement_ids": ()}),
            "method": "",
            "po_number": ""
        }),
        "shippingCarrierCode": "",
        "shippingMethodCode": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/carts/mine/collect-totals \
  --header 'content-type: application/json' \
  --data '{
  "additionalData": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "gift_messages": [
        {
          "customer_id": 0,
          "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": false,
            "wrapping_allow_gift_receipt": false,
            "wrapping_id": 0
          },
          "gift_message_id": 0,
          "message": "",
          "recipient": "",
          "sender": ""
        }
      ]
    }
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  },
  "shippingCarrierCode": "",
  "shippingMethodCode": ""
}'
echo '{
  "additionalData": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "gift_messages": [
        {
          "customer_id": 0,
          "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": false,
            "wrapping_allow_gift_receipt": false,
            "wrapping_id": 0
          },
          "gift_message_id": 0,
          "message": "",
          "recipient": "",
          "sender": ""
        }
      ]
    }
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  },
  "shippingCarrierCode": "",
  "shippingMethodCode": ""
}' |  \
  http PUT {{baseUrl}}/V1/carts/mine/collect-totals \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "additionalData": {\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "extension_attributes": {\n      "gift_messages": [\n        {\n          "customer_id": 0,\n          "extension_attributes": {\n            "entity_id": "",\n            "entity_type": "",\n            "wrapping_add_printed_card": false,\n            "wrapping_allow_gift_receipt": false,\n            "wrapping_id": 0\n          },\n          "gift_message_id": 0,\n          "message": "",\n          "recipient": "",\n          "sender": ""\n        }\n      ]\n    }\n  },\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\n  },\n  "shippingCarrierCode": "",\n  "shippingMethodCode": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/collect-totals
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "additionalData": [
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "extension_attributes": ["gift_messages": [
        [
          "customer_id": 0,
          "extension_attributes": [
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": false,
            "wrapping_allow_gift_receipt": false,
            "wrapping_id": 0
          ],
          "gift_message_id": 0,
          "message": "",
          "recipient": "",
          "sender": ""
        ]
      ]]
  ],
  "paymentMethod": [
    "additional_data": [],
    "extension_attributes": ["agreement_ids": []],
    "method": "",
    "po_number": ""
  ],
  "shippingCarrierCode": "",
  "shippingMethodCode": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/collect-totals")! 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 carts-mine-collection-point-search-request (PUT)
{{baseUrl}}/V1/carts/mine/collection-point/search-request
BODY json

{
  "countryId": "",
  "postcode": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/collection-point/search-request");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/carts/mine/collection-point/search-request" {:content-type :json
                                                                                         :form-params {:countryId ""
                                                                                                       :postcode ""}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/collection-point/search-request"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\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}}/V1/carts/mine/collection-point/search-request"),
    Content = new StringContent("{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\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}}/V1/carts/mine/collection-point/search-request");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/collection-point/search-request"

	payload := strings.NewReader("{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/carts/mine/collection-point/search-request HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 39

{
  "countryId": "",
  "postcode": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/carts/mine/collection-point/search-request")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/collection-point/search-request"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\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  \"countryId\": \"\",\n  \"postcode\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/collection-point/search-request")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/carts/mine/collection-point/search-request")
  .header("content-type", "application/json")
  .body("{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  countryId: '',
  postcode: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/carts/mine/collection-point/search-request');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/mine/collection-point/search-request',
  headers: {'content-type': 'application/json'},
  data: {countryId: '', postcode: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/collection-point/search-request';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"countryId":"","postcode":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/collection-point/search-request',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "countryId": "",\n  "postcode": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/collection-point/search-request")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/collection-point/search-request',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({countryId: '', postcode: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/mine/collection-point/search-request',
  headers: {'content-type': 'application/json'},
  body: {countryId: '', postcode: ''},
  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}}/V1/carts/mine/collection-point/search-request');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  countryId: '',
  postcode: ''
});

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}}/V1/carts/mine/collection-point/search-request',
  headers: {'content-type': 'application/json'},
  data: {countryId: '', postcode: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/collection-point/search-request';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"countryId":"","postcode":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"countryId": @"",
                              @"postcode": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/collection-point/search-request"]
                                                       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}}/V1/carts/mine/collection-point/search-request" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/collection-point/search-request",
  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([
    'countryId' => '',
    'postcode' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/carts/mine/collection-point/search-request', [
  'body' => '{
  "countryId": "",
  "postcode": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/collection-point/search-request');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'countryId' => '',
  'postcode' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'countryId' => '',
  'postcode' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/collection-point/search-request');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/collection-point/search-request' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "countryId": "",
  "postcode": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/collection-point/search-request' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "countryId": "",
  "postcode": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/carts/mine/collection-point/search-request", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/collection-point/search-request"

payload = {
    "countryId": "",
    "postcode": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/collection-point/search-request"

payload <- "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/collection-point/search-request")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\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/V1/carts/mine/collection-point/search-request') do |req|
  req.body = "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\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}}/V1/carts/mine/collection-point/search-request";

    let payload = json!({
        "countryId": "",
        "postcode": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/carts/mine/collection-point/search-request \
  --header 'content-type: application/json' \
  --data '{
  "countryId": "",
  "postcode": ""
}'
echo '{
  "countryId": "",
  "postcode": ""
}' |  \
  http PUT {{baseUrl}}/V1/carts/mine/collection-point/search-request \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "countryId": "",\n  "postcode": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/collection-point/search-request
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "countryId": "",
  "postcode": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/collection-point/search-request")! 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()
DELETE carts-mine-collection-point-search-request
{{baseUrl}}/V1/carts/mine/collection-point/search-request
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/collection-point/search-request");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/carts/mine/collection-point/search-request")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/collection-point/search-request"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/collection-point/search-request"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/collection-point/search-request");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/collection-point/search-request"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/carts/mine/collection-point/search-request HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/carts/mine/collection-point/search-request")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/collection-point/search-request"))
    .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}}/V1/carts/mine/collection-point/search-request")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/carts/mine/collection-point/search-request")
  .asString();
const 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}}/V1/carts/mine/collection-point/search-request');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/carts/mine/collection-point/search-request'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/collection-point/search-request';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/collection-point/search-request',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/collection-point/search-request")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/collection-point/search-request',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/carts/mine/collection-point/search-request'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/carts/mine/collection-point/search-request');

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}}/V1/carts/mine/collection-point/search-request'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/collection-point/search-request';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/collection-point/search-request"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/collection-point/search-request" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/collection-point/search-request",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/carts/mine/collection-point/search-request');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/collection-point/search-request');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/collection-point/search-request');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/collection-point/search-request' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/collection-point/search-request' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/carts/mine/collection-point/search-request")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/collection-point/search-request"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/collection-point/search-request"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/collection-point/search-request")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/carts/mine/collection-point/search-request') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/collection-point/search-request";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/carts/mine/collection-point/search-request
http DELETE {{baseUrl}}/V1/carts/mine/collection-point/search-request
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/collection-point/search-request
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/collection-point/search-request")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET carts-mine-collection-point-search-result
{{baseUrl}}/V1/carts/mine/collection-point/search-result
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/collection-point/search-result");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/mine/collection-point/search-result")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/collection-point/search-result"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/collection-point/search-result"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/collection-point/search-result");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/collection-point/search-result"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/mine/collection-point/search-result HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/mine/collection-point/search-result")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/collection-point/search-result"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/collection-point/search-result")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/mine/collection-point/search-result")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/mine/collection-point/search-result');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/collection-point/search-result'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/collection-point/search-result';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/collection-point/search-result',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/collection-point/search-result")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/collection-point/search-result',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/collection-point/search-result'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/mine/collection-point/search-result');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/collection-point/search-result'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/collection-point/search-result';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/collection-point/search-result"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/collection-point/search-result" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/collection-point/search-result",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/mine/collection-point/search-result');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/collection-point/search-result');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/collection-point/search-result');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/collection-point/search-result' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/collection-point/search-result' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/mine/collection-point/search-result")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/collection-point/search-result"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/collection-point/search-result"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/collection-point/search-result")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/mine/collection-point/search-result') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/collection-point/search-result";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/mine/collection-point/search-result
http GET {{baseUrl}}/V1/carts/mine/collection-point/search-result
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/collection-point/search-result
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/collection-point/search-result")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-mine-collection-point-select
{{baseUrl}}/V1/carts/mine/collection-point/select
BODY json

{
  "entityId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/collection-point/select");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"entityId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/mine/collection-point/select" {:content-type :json
                                                                                  :form-params {:entityId 0}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/collection-point/select"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"entityId\": 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}}/V1/carts/mine/collection-point/select"),
    Content = new StringContent("{\n  \"entityId\": 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}}/V1/carts/mine/collection-point/select");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"entityId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/collection-point/select"

	payload := strings.NewReader("{\n  \"entityId\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/mine/collection-point/select HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "entityId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/mine/collection-point/select")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"entityId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/collection-point/select"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"entityId\": 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  \"entityId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/collection-point/select")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/mine/collection-point/select")
  .header("content-type", "application/json")
  .body("{\n  \"entityId\": 0\n}")
  .asString();
const data = JSON.stringify({
  entityId: 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}}/V1/carts/mine/collection-point/select');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/collection-point/select',
  headers: {'content-type': 'application/json'},
  data: {entityId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/collection-point/select';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entityId":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}}/V1/carts/mine/collection-point/select',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "entityId": 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  \"entityId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/collection-point/select")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/collection-point/select',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({entityId: 0}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/collection-point/select',
  headers: {'content-type': 'application/json'},
  body: {entityId: 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}}/V1/carts/mine/collection-point/select');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  entityId: 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}}/V1/carts/mine/collection-point/select',
  headers: {'content-type': 'application/json'},
  data: {entityId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/collection-point/select';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entityId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"entityId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/collection-point/select"]
                                                       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}}/V1/carts/mine/collection-point/select" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"entityId\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/collection-point/select",
  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([
    'entityId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/mine/collection-point/select', [
  'body' => '{
  "entityId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/collection-point/select');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'entityId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'entityId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/collection-point/select');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/collection-point/select' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entityId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/collection-point/select' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entityId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"entityId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/mine/collection-point/select", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/collection-point/select"

payload = { "entityId": 0 }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/collection-point/select"

payload <- "{\n  \"entityId\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/collection-point/select")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"entityId\": 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/V1/carts/mine/collection-point/select') do |req|
  req.body = "{\n  \"entityId\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/collection-point/select";

    let payload = json!({"entityId": 0});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/mine/collection-point/select \
  --header 'content-type: application/json' \
  --data '{
  "entityId": 0
}'
echo '{
  "entityId": 0
}' |  \
  http POST {{baseUrl}}/V1/carts/mine/collection-point/select \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "entityId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/collection-point/select
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["entityId": 0] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/collection-point/select")! 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 carts-mine-coupons (GET)
{{baseUrl}}/V1/carts/mine/coupons
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/coupons");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/mine/coupons")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/coupons"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/coupons"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/coupons");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/coupons"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/mine/coupons HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/mine/coupons")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/coupons"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/coupons")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/mine/coupons")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/mine/coupons');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/mine/coupons'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/coupons';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/coupons',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/coupons")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/coupons',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/mine/coupons'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/mine/coupons');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/mine/coupons'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/coupons';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/coupons"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/coupons" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/coupons",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/mine/coupons');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/coupons');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/coupons');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/coupons' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/coupons' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/mine/coupons")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/coupons"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/coupons"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/coupons")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/mine/coupons') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/coupons";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/mine/coupons
http GET {{baseUrl}}/V1/carts/mine/coupons
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/coupons
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/coupons")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE carts-mine-coupons
{{baseUrl}}/V1/carts/mine/coupons
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/coupons");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/carts/mine/coupons")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/coupons"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/coupons"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/coupons");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/coupons"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/carts/mine/coupons HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/carts/mine/coupons")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/coupons"))
    .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}}/V1/carts/mine/coupons")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/carts/mine/coupons")
  .asString();
const 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}}/V1/carts/mine/coupons');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/carts/mine/coupons'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/coupons';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/coupons',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/coupons")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/coupons',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/carts/mine/coupons'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/carts/mine/coupons');

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}}/V1/carts/mine/coupons'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/coupons';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/coupons"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/coupons" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/coupons",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/carts/mine/coupons');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/coupons');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/coupons');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/coupons' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/coupons' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/carts/mine/coupons")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/coupons"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/coupons"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/coupons")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/carts/mine/coupons') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/coupons";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/carts/mine/coupons
http DELETE {{baseUrl}}/V1/carts/mine/coupons
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/coupons
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/coupons")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT carts-mine-coupons-{couponCode}
{{baseUrl}}/V1/carts/mine/coupons/:couponCode
QUERY PARAMS

couponCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/coupons/:couponCode");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/carts/mine/coupons/:couponCode")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/coupons/:couponCode"

response = HTTP::Client.put url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/coupons/:couponCode"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/coupons/:couponCode");
var request = new RestRequest("", Method.Put);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/coupons/:couponCode"

	req, _ := http.NewRequest("PUT", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/carts/mine/coupons/:couponCode HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/carts/mine/coupons/:couponCode")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/coupons/:couponCode"))
    .method("PUT", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/coupons/:couponCode")
  .put(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/carts/mine/coupons/:couponCode")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/carts/mine/coupons/:couponCode');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/mine/coupons/:couponCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/coupons/:couponCode';
const options = {method: 'PUT'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/coupons/:couponCode',
  method: 'PUT',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/coupons/:couponCode")
  .put(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/coupons/:couponCode',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/mine/coupons/:couponCode'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/carts/mine/coupons/:couponCode');

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}}/V1/carts/mine/coupons/:couponCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/coupons/:couponCode';
const options = {method: 'PUT'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/coupons/:couponCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/coupons/:couponCode" in

Client.call `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/coupons/:couponCode",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/carts/mine/coupons/:couponCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/coupons/:couponCode');
$request->setMethod(HTTP_METH_PUT);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/coupons/:couponCode');
$request->setRequestMethod('PUT');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/coupons/:couponCode' -Method PUT 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/coupons/:couponCode' -Method PUT 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("PUT", "/baseUrl/V1/carts/mine/coupons/:couponCode")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/coupons/:couponCode"

response = requests.put(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/coupons/:couponCode"

response <- VERB("PUT", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/coupons/:couponCode")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/V1/carts/mine/coupons/:couponCode') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/coupons/:couponCode";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/carts/mine/coupons/:couponCode
http PUT {{baseUrl}}/V1/carts/mine/coupons/:couponCode
wget --quiet \
  --method PUT \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/coupons/:couponCode
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/coupons/:couponCode")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-mine-delivery-option
{{baseUrl}}/V1/carts/mine/delivery-option
BODY json

{
  "selectedOption": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/delivery-option");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"selectedOption\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/mine/delivery-option" {:content-type :json
                                                                          :form-params {:selectedOption ""}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/delivery-option"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"selectedOption\": \"\"\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}}/V1/carts/mine/delivery-option"),
    Content = new StringContent("{\n  \"selectedOption\": \"\"\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}}/V1/carts/mine/delivery-option");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"selectedOption\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/delivery-option"

	payload := strings.NewReader("{\n  \"selectedOption\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/mine/delivery-option HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 26

{
  "selectedOption": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/mine/delivery-option")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"selectedOption\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/delivery-option"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"selectedOption\": \"\"\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  \"selectedOption\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/delivery-option")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/mine/delivery-option")
  .header("content-type", "application/json")
  .body("{\n  \"selectedOption\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  selectedOption: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/carts/mine/delivery-option');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/delivery-option',
  headers: {'content-type': 'application/json'},
  data: {selectedOption: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/delivery-option';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"selectedOption":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/delivery-option',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "selectedOption": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"selectedOption\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/delivery-option")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/delivery-option',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({selectedOption: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/delivery-option',
  headers: {'content-type': 'application/json'},
  body: {selectedOption: ''},
  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}}/V1/carts/mine/delivery-option');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  selectedOption: ''
});

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}}/V1/carts/mine/delivery-option',
  headers: {'content-type': 'application/json'},
  data: {selectedOption: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/delivery-option';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"selectedOption":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"selectedOption": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/delivery-option"]
                                                       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}}/V1/carts/mine/delivery-option" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"selectedOption\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/delivery-option",
  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([
    'selectedOption' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/mine/delivery-option', [
  'body' => '{
  "selectedOption": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/delivery-option');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'selectedOption' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'selectedOption' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/delivery-option');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/delivery-option' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "selectedOption": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/delivery-option' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "selectedOption": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"selectedOption\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/mine/delivery-option", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/delivery-option"

payload = { "selectedOption": "" }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/delivery-option"

payload <- "{\n  \"selectedOption\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/delivery-option")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"selectedOption\": \"\"\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/V1/carts/mine/delivery-option') do |req|
  req.body = "{\n  \"selectedOption\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/delivery-option";

    let payload = json!({"selectedOption": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/mine/delivery-option \
  --header 'content-type: application/json' \
  --data '{
  "selectedOption": ""
}'
echo '{
  "selectedOption": ""
}' |  \
  http POST {{baseUrl}}/V1/carts/mine/delivery-option \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "selectedOption": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/delivery-option
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["selectedOption": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/delivery-option")! 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 carts-mine-estimate-shipping-methods
{{baseUrl}}/V1/carts/mine/estimate-shipping-methods
BODY json

{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods" {:content-type :json
                                                                                    :form-params {:address {:city ""
                                                                                                            :company ""
                                                                                                            :country_id ""
                                                                                                            :custom_attributes [{:attribute_code ""
                                                                                                                                 :value ""}]
                                                                                                            :customer_address_id 0
                                                                                                            :customer_id 0
                                                                                                            :email ""
                                                                                                            :extension_attributes {:checkout_fields [{}]
                                                                                                                                   :gift_registry_id 0}
                                                                                                            :fax ""
                                                                                                            :firstname ""
                                                                                                            :id 0
                                                                                                            :lastname ""
                                                                                                            :middlename ""
                                                                                                            :postcode ""
                                                                                                            :prefix ""
                                                                                                            :region ""
                                                                                                            :region_code ""
                                                                                                            :region_id 0
                                                                                                            :same_as_billing 0
                                                                                                            :save_in_address_book 0
                                                                                                            :street []
                                                                                                            :suffix ""
                                                                                                            :telephone ""
                                                                                                            :vat_id ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\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}}/V1/carts/mine/estimate-shipping-methods"),
    Content = new StringContent("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\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}}/V1/carts/mine/estimate-shipping-methods");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods"

	payload := strings.NewReader("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/mine/estimate-shipping-methods HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 681

{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/estimate-shipping-methods"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\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\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/estimate-shipping-methods")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/mine/estimate-shipping-methods")
  .header("content-type", "application/json")
  .body("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_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}}/V1/carts/mine/estimate-shipping-methods');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  data: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/estimate-shipping-methods';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_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}}/V1/carts/mine/estimate-shipping-methods',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\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\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/estimate-shipping-methods")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/estimate-shipping-methods',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  body: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_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}}/V1/carts/mine/estimate-shipping-methods');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_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}}/V1/carts/mine/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  data: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/estimate-shipping-methods';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/estimate-shipping-methods"]
                                                       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}}/V1/carts/mine/estimate-shipping-methods" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/mine/estimate-shipping-methods', [
  'body' => '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/estimate-shipping-methods');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/estimate-shipping-methods');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/estimate-shipping-methods' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/estimate-shipping-methods' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/mine/estimate-shipping-methods", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods"

payload = { "address": {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "extension_attributes": {
            "checkout_fields": [{}],
            "gift_registry_id": 0
        },
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "same_as_billing": 0,
        "save_in_address_book": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods"

payload <- "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/estimate-shipping-methods")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\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/V1/carts/mine/estimate-shipping-methods') do |req|
  req.body = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods";

    let payload = json!({"address": json!({
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": json!({
                "checkout_fields": (json!({})),
                "gift_registry_id": 0
            }),
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": (),
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/mine/estimate-shipping-methods \
  --header 'content-type: application/json' \
  --data '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}'
echo '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/carts/mine/estimate-shipping-methods \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "address": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/estimate-shipping-methods
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["address": [
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": [
      "checkout_fields": [[]],
      "gift_registry_id": 0
    ],
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods")! 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 carts-mine-estimate-shipping-methods-by-address-id
{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id
BODY json

{
  "addressId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"addressId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id" {:content-type :json
                                                                                                  :form-params {:addressId 0}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"addressId\": 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}}/V1/carts/mine/estimate-shipping-methods-by-address-id"),
    Content = new StringContent("{\n  \"addressId\": 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}}/V1/carts/mine/estimate-shipping-methods-by-address-id");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"addressId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id"

	payload := strings.NewReader("{\n  \"addressId\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/mine/estimate-shipping-methods-by-address-id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 20

{
  "addressId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"addressId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"addressId\": 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  \"addressId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id")
  .header("content-type", "application/json")
  .body("{\n  \"addressId\": 0\n}")
  .asString();
const data = JSON.stringify({
  addressId: 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}}/V1/carts/mine/estimate-shipping-methods-by-address-id');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id',
  headers: {'content-type': 'application/json'},
  data: {addressId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressId":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}}/V1/carts/mine/estimate-shipping-methods-by-address-id',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "addressId": 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  \"addressId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/estimate-shipping-methods-by-address-id',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({addressId: 0}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id',
  headers: {'content-type': 'application/json'},
  body: {addressId: 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}}/V1/carts/mine/estimate-shipping-methods-by-address-id');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  addressId: 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}}/V1/carts/mine/estimate-shipping-methods-by-address-id',
  headers: {'content-type': 'application/json'},
  data: {addressId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"addressId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"addressId\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'addressId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id', [
  'body' => '{
  "addressId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'addressId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'addressId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"addressId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/mine/estimate-shipping-methods-by-address-id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id"

payload = { "addressId": 0 }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id"

payload <- "{\n  \"addressId\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"addressId\": 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/V1/carts/mine/estimate-shipping-methods-by-address-id') do |req|
  req.body = "{\n  \"addressId\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id";

    let payload = json!({"addressId": 0});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id \
  --header 'content-type: application/json' \
  --data '{
  "addressId": 0
}'
echo '{
  "addressId": 0
}' |  \
  http POST {{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "addressId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["addressId": 0] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/estimate-shipping-methods-by-address-id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-mine-gift-message (POST)
{{baseUrl}}/V1/carts/mine/gift-message
BODY json

{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/gift-message");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/mine/gift-message" {:content-type :json
                                                                       :form-params {:giftMessage {:customer_id 0
                                                                                                   :extension_attributes {:entity_id ""
                                                                                                                          :entity_type ""
                                                                                                                          :wrapping_add_printed_card false
                                                                                                                          :wrapping_allow_gift_receipt false
                                                                                                                          :wrapping_id 0}
                                                                                                   :gift_message_id 0
                                                                                                   :message ""
                                                                                                   :recipient ""
                                                                                                   :sender ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/gift-message"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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}}/V1/carts/mine/gift-message"),
    Content = new StringContent("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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}}/V1/carts/mine/gift-message");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/gift-message"

	payload := strings.NewReader("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/mine/gift-message HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 325

{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/mine/gift-message")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/gift-message"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/gift-message")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/mine/gift-message")
  .header("content-type", "application/json")
  .body("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/carts/mine/gift-message');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/gift-message',
  headers: {'content-type': 'application/json'},
  data: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/gift-message';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftMessage":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/gift-message',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "giftMessage": {\n    "customer_id": 0,\n    "extension_attributes": {\n      "entity_id": "",\n      "entity_type": "",\n      "wrapping_add_printed_card": false,\n      "wrapping_allow_gift_receipt": false,\n      "wrapping_id": 0\n    },\n    "gift_message_id": 0,\n    "message": "",\n    "recipient": "",\n    "sender": ""\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  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/gift-message")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/gift-message',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/gift-message',
  headers: {'content-type': 'application/json'},
  body: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  },
  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}}/V1/carts/mine/gift-message');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
});

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}}/V1/carts/mine/gift-message',
  headers: {'content-type': 'application/json'},
  data: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/gift-message';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftMessage":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"giftMessage": @{ @"customer_id": @0, @"extension_attributes": @{ @"entity_id": @"", @"entity_type": @"", @"wrapping_add_printed_card": @NO, @"wrapping_allow_gift_receipt": @NO, @"wrapping_id": @0 }, @"gift_message_id": @0, @"message": @"", @"recipient": @"", @"sender": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/gift-message"]
                                                       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}}/V1/carts/mine/gift-message" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/gift-message",
  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([
    'giftMessage' => [
        'customer_id' => 0,
        'extension_attributes' => [
                'entity_id' => '',
                'entity_type' => '',
                'wrapping_add_printed_card' => null,
                'wrapping_allow_gift_receipt' => null,
                'wrapping_id' => 0
        ],
        'gift_message_id' => 0,
        'message' => '',
        'recipient' => '',
        'sender' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/mine/gift-message', [
  'body' => '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/gift-message');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'giftMessage' => [
    'customer_id' => 0,
    'extension_attributes' => [
        'entity_id' => '',
        'entity_type' => '',
        'wrapping_add_printed_card' => null,
        'wrapping_allow_gift_receipt' => null,
        'wrapping_id' => 0
    ],
    'gift_message_id' => 0,
    'message' => '',
    'recipient' => '',
    'sender' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'giftMessage' => [
    'customer_id' => 0,
    'extension_attributes' => [
        'entity_id' => '',
        'entity_type' => '',
        'wrapping_add_printed_card' => null,
        'wrapping_allow_gift_receipt' => null,
        'wrapping_id' => 0
    ],
    'gift_message_id' => 0,
    'message' => '',
    'recipient' => '',
    'sender' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/gift-message');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/gift-message' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/gift-message' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/mine/gift-message", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/gift-message"

payload = { "giftMessage": {
        "customer_id": 0,
        "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": False,
            "wrapping_allow_gift_receipt": False,
            "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/gift-message"

payload <- "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/gift-message")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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/V1/carts/mine/gift-message') do |req|
  req.body = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/gift-message";

    let payload = json!({"giftMessage": json!({
            "customer_id": 0,
            "extension_attributes": json!({
                "entity_id": "",
                "entity_type": "",
                "wrapping_add_printed_card": false,
                "wrapping_allow_gift_receipt": false,
                "wrapping_id": 0
            }),
            "gift_message_id": 0,
            "message": "",
            "recipient": "",
            "sender": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/mine/gift-message \
  --header 'content-type: application/json' \
  --data '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
echo '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/carts/mine/gift-message \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "giftMessage": {\n    "customer_id": 0,\n    "extension_attributes": {\n      "entity_id": "",\n      "entity_type": "",\n      "wrapping_add_printed_card": false,\n      "wrapping_allow_gift_receipt": false,\n      "wrapping_id": 0\n    },\n    "gift_message_id": 0,\n    "message": "",\n    "recipient": "",\n    "sender": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/gift-message
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["giftMessage": [
    "customer_id": 0,
    "extension_attributes": [
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    ],
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/gift-message")! 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 carts-mine-gift-message
{{baseUrl}}/V1/carts/mine/gift-message
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/gift-message");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/mine/gift-message")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/gift-message"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/gift-message"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/gift-message");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/gift-message"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/mine/gift-message HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/mine/gift-message")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/gift-message"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/gift-message")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/mine/gift-message")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/mine/gift-message');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/mine/gift-message'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/gift-message';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/gift-message',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/gift-message")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/gift-message',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/mine/gift-message'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/mine/gift-message');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/mine/gift-message'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/gift-message';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/gift-message"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/gift-message" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/gift-message",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/mine/gift-message');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/gift-message');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/gift-message');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/gift-message' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/gift-message' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/mine/gift-message")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/gift-message"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/gift-message"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/gift-message")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/mine/gift-message') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/gift-message";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/mine/gift-message
http GET {{baseUrl}}/V1/carts/mine/gift-message
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/gift-message
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/gift-message")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-mine-gift-message-{itemId} (POST)
{{baseUrl}}/V1/carts/mine/gift-message/:itemId
QUERY PARAMS

itemId
BODY json

{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/gift-message/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/mine/gift-message/:itemId" {:content-type :json
                                                                               :form-params {:giftMessage {:customer_id 0
                                                                                                           :extension_attributes {:entity_id ""
                                                                                                                                  :entity_type ""
                                                                                                                                  :wrapping_add_printed_card false
                                                                                                                                  :wrapping_allow_gift_receipt false
                                                                                                                                  :wrapping_id 0}
                                                                                                           :gift_message_id 0
                                                                                                           :message ""
                                                                                                           :recipient ""
                                                                                                           :sender ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/gift-message/:itemId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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}}/V1/carts/mine/gift-message/:itemId"),
    Content = new StringContent("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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}}/V1/carts/mine/gift-message/:itemId");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/gift-message/:itemId"

	payload := strings.NewReader("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/mine/gift-message/:itemId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 325

{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/mine/gift-message/:itemId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/gift-message/:itemId"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/gift-message/:itemId")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/mine/gift-message/:itemId")
  .header("content-type", "application/json")
  .body("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/carts/mine/gift-message/:itemId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/gift-message/:itemId',
  headers: {'content-type': 'application/json'},
  data: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/gift-message/:itemId';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftMessage":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/gift-message/:itemId',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "giftMessage": {\n    "customer_id": 0,\n    "extension_attributes": {\n      "entity_id": "",\n      "entity_type": "",\n      "wrapping_add_printed_card": false,\n      "wrapping_allow_gift_receipt": false,\n      "wrapping_id": 0\n    },\n    "gift_message_id": 0,\n    "message": "",\n    "recipient": "",\n    "sender": ""\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  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/gift-message/:itemId")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/gift-message/:itemId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/gift-message/:itemId',
  headers: {'content-type': 'application/json'},
  body: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  },
  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}}/V1/carts/mine/gift-message/:itemId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
});

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}}/V1/carts/mine/gift-message/:itemId',
  headers: {'content-type': 'application/json'},
  data: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/gift-message/:itemId';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftMessage":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"giftMessage": @{ @"customer_id": @0, @"extension_attributes": @{ @"entity_id": @"", @"entity_type": @"", @"wrapping_add_printed_card": @NO, @"wrapping_allow_gift_receipt": @NO, @"wrapping_id": @0 }, @"gift_message_id": @0, @"message": @"", @"recipient": @"", @"sender": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/gift-message/:itemId"]
                                                       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}}/V1/carts/mine/gift-message/:itemId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/gift-message/:itemId",
  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([
    'giftMessage' => [
        'customer_id' => 0,
        'extension_attributes' => [
                'entity_id' => '',
                'entity_type' => '',
                'wrapping_add_printed_card' => null,
                'wrapping_allow_gift_receipt' => null,
                'wrapping_id' => 0
        ],
        'gift_message_id' => 0,
        'message' => '',
        'recipient' => '',
        'sender' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/mine/gift-message/:itemId', [
  'body' => '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/gift-message/:itemId');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'giftMessage' => [
    'customer_id' => 0,
    'extension_attributes' => [
        'entity_id' => '',
        'entity_type' => '',
        'wrapping_add_printed_card' => null,
        'wrapping_allow_gift_receipt' => null,
        'wrapping_id' => 0
    ],
    'gift_message_id' => 0,
    'message' => '',
    'recipient' => '',
    'sender' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'giftMessage' => [
    'customer_id' => 0,
    'extension_attributes' => [
        'entity_id' => '',
        'entity_type' => '',
        'wrapping_add_printed_card' => null,
        'wrapping_allow_gift_receipt' => null,
        'wrapping_id' => 0
    ],
    'gift_message_id' => 0,
    'message' => '',
    'recipient' => '',
    'sender' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/gift-message/:itemId');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/gift-message/:itemId' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/gift-message/:itemId' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/mine/gift-message/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/gift-message/:itemId"

payload = { "giftMessage": {
        "customer_id": 0,
        "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": False,
            "wrapping_allow_gift_receipt": False,
            "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/gift-message/:itemId"

payload <- "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/gift-message/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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/V1/carts/mine/gift-message/:itemId') do |req|
  req.body = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/gift-message/:itemId";

    let payload = json!({"giftMessage": json!({
            "customer_id": 0,
            "extension_attributes": json!({
                "entity_id": "",
                "entity_type": "",
                "wrapping_add_printed_card": false,
                "wrapping_allow_gift_receipt": false,
                "wrapping_id": 0
            }),
            "gift_message_id": 0,
            "message": "",
            "recipient": "",
            "sender": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/mine/gift-message/:itemId \
  --header 'content-type: application/json' \
  --data '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
echo '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/carts/mine/gift-message/:itemId \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "giftMessage": {\n    "customer_id": 0,\n    "extension_attributes": {\n      "entity_id": "",\n      "entity_type": "",\n      "wrapping_add_printed_card": false,\n      "wrapping_allow_gift_receipt": false,\n      "wrapping_id": 0\n    },\n    "gift_message_id": 0,\n    "message": "",\n    "recipient": "",\n    "sender": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/gift-message/:itemId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["giftMessage": [
    "customer_id": 0,
    "extension_attributes": [
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    ],
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/gift-message/:itemId")! 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 carts-mine-gift-message-{itemId}
{{baseUrl}}/V1/carts/mine/gift-message/:itemId
QUERY PARAMS

itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/gift-message/:itemId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/mine/gift-message/:itemId")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/gift-message/:itemId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/gift-message/:itemId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/gift-message/:itemId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/gift-message/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/mine/gift-message/:itemId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/mine/gift-message/:itemId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/gift-message/:itemId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/gift-message/:itemId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/mine/gift-message/:itemId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/mine/gift-message/:itemId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/gift-message/:itemId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/gift-message/:itemId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/gift-message/:itemId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/gift-message/:itemId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/gift-message/:itemId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/gift-message/:itemId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/mine/gift-message/:itemId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/gift-message/:itemId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/gift-message/:itemId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/gift-message/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/gift-message/:itemId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/gift-message/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/mine/gift-message/:itemId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/gift-message/:itemId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/gift-message/:itemId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/gift-message/:itemId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/gift-message/:itemId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/mine/gift-message/:itemId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/gift-message/:itemId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/gift-message/:itemId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/gift-message/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/mine/gift-message/:itemId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/gift-message/:itemId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/mine/gift-message/:itemId
http GET {{baseUrl}}/V1/carts/mine/gift-message/:itemId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/gift-message/:itemId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/gift-message/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-mine-giftCards
{{baseUrl}}/V1/carts/mine/giftCards
BODY json

{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/giftCards");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/mine/giftCards" {:content-type :json
                                                                    :form-params {:giftCardAccountData {:base_gift_cards_amount ""
                                                                                                        :base_gift_cards_amount_used ""
                                                                                                        :extension_attributes {}
                                                                                                        :gift_cards []
                                                                                                        :gift_cards_amount ""
                                                                                                        :gift_cards_amount_used ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/giftCards"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\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}}/V1/carts/mine/giftCards"),
    Content = new StringContent("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\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}}/V1/carts/mine/giftCards");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/giftCards"

	payload := strings.NewReader("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/mine/giftCards HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 223

{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/mine/giftCards")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/giftCards"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\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  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/giftCards")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/mine/giftCards")
  .header("content-type", "application/json")
  .body("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  giftCardAccountData: {
    base_gift_cards_amount: '',
    base_gift_cards_amount_used: '',
    extension_attributes: {},
    gift_cards: [],
    gift_cards_amount: '',
    gift_cards_amount_used: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/carts/mine/giftCards');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/giftCards',
  headers: {'content-type': 'application/json'},
  data: {
    giftCardAccountData: {
      base_gift_cards_amount: '',
      base_gift_cards_amount_used: '',
      extension_attributes: {},
      gift_cards: [],
      gift_cards_amount: '',
      gift_cards_amount_used: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/giftCards';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftCardAccountData":{"base_gift_cards_amount":"","base_gift_cards_amount_used":"","extension_attributes":{},"gift_cards":[],"gift_cards_amount":"","gift_cards_amount_used":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/giftCards',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "giftCardAccountData": {\n    "base_gift_cards_amount": "",\n    "base_gift_cards_amount_used": "",\n    "extension_attributes": {},\n    "gift_cards": [],\n    "gift_cards_amount": "",\n    "gift_cards_amount_used": ""\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  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/giftCards")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/giftCards',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  giftCardAccountData: {
    base_gift_cards_amount: '',
    base_gift_cards_amount_used: '',
    extension_attributes: {},
    gift_cards: [],
    gift_cards_amount: '',
    gift_cards_amount_used: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/giftCards',
  headers: {'content-type': 'application/json'},
  body: {
    giftCardAccountData: {
      base_gift_cards_amount: '',
      base_gift_cards_amount_used: '',
      extension_attributes: {},
      gift_cards: [],
      gift_cards_amount: '',
      gift_cards_amount_used: ''
    }
  },
  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}}/V1/carts/mine/giftCards');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  giftCardAccountData: {
    base_gift_cards_amount: '',
    base_gift_cards_amount_used: '',
    extension_attributes: {},
    gift_cards: [],
    gift_cards_amount: '',
    gift_cards_amount_used: ''
  }
});

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}}/V1/carts/mine/giftCards',
  headers: {'content-type': 'application/json'},
  data: {
    giftCardAccountData: {
      base_gift_cards_amount: '',
      base_gift_cards_amount_used: '',
      extension_attributes: {},
      gift_cards: [],
      gift_cards_amount: '',
      gift_cards_amount_used: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/giftCards';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftCardAccountData":{"base_gift_cards_amount":"","base_gift_cards_amount_used":"","extension_attributes":{},"gift_cards":[],"gift_cards_amount":"","gift_cards_amount_used":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"giftCardAccountData": @{ @"base_gift_cards_amount": @"", @"base_gift_cards_amount_used": @"", @"extension_attributes": @{  }, @"gift_cards": @[  ], @"gift_cards_amount": @"", @"gift_cards_amount_used": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/giftCards"]
                                                       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}}/V1/carts/mine/giftCards" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/giftCards",
  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([
    'giftCardAccountData' => [
        'base_gift_cards_amount' => '',
        'base_gift_cards_amount_used' => '',
        'extension_attributes' => [
                
        ],
        'gift_cards' => [
                
        ],
        'gift_cards_amount' => '',
        'gift_cards_amount_used' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/mine/giftCards', [
  'body' => '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/giftCards');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'giftCardAccountData' => [
    'base_gift_cards_amount' => '',
    'base_gift_cards_amount_used' => '',
    'extension_attributes' => [
        
    ],
    'gift_cards' => [
        
    ],
    'gift_cards_amount' => '',
    'gift_cards_amount_used' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'giftCardAccountData' => [
    'base_gift_cards_amount' => '',
    'base_gift_cards_amount_used' => '',
    'extension_attributes' => [
        
    ],
    'gift_cards' => [
        
    ],
    'gift_cards_amount' => '',
    'gift_cards_amount_used' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/giftCards');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/giftCards' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/giftCards' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/mine/giftCards", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/giftCards"

payload = { "giftCardAccountData": {
        "base_gift_cards_amount": "",
        "base_gift_cards_amount_used": "",
        "extension_attributes": {},
        "gift_cards": [],
        "gift_cards_amount": "",
        "gift_cards_amount_used": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/giftCards"

payload <- "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/giftCards")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\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/V1/carts/mine/giftCards') do |req|
  req.body = "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/giftCards";

    let payload = json!({"giftCardAccountData": json!({
            "base_gift_cards_amount": "",
            "base_gift_cards_amount_used": "",
            "extension_attributes": json!({}),
            "gift_cards": (),
            "gift_cards_amount": "",
            "gift_cards_amount_used": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/mine/giftCards \
  --header 'content-type: application/json' \
  --data '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}'
echo '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/carts/mine/giftCards \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "giftCardAccountData": {\n    "base_gift_cards_amount": "",\n    "base_gift_cards_amount_used": "",\n    "extension_attributes": {},\n    "gift_cards": [],\n    "gift_cards_amount": "",\n    "gift_cards_amount_used": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/giftCards
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["giftCardAccountData": [
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": [],
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/giftCards")! 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 carts-mine-giftCards-{giftCardCode}
{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode
QUERY PARAMS

giftCardCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/carts/mine/giftCards/:giftCardCode HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode"))
    .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}}/V1/carts/mine/giftCards/:giftCardCode")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode")
  .asString();
const 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}}/V1/carts/mine/giftCards/:giftCardCode');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/giftCards/:giftCardCode',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode');

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}}/V1/carts/mine/giftCards/:giftCardCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/carts/mine/giftCards/:giftCardCode")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/carts/mine/giftCards/:giftCardCode') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode
http DELETE {{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/giftCards/:giftCardCode")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-mine-items (POST)
{{baseUrl}}/V1/carts/mine/items
BODY json

{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/items");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/mine/items" {:content-type :json
                                                                :form-params {:cartItem {:extension_attributes {:negotiable_quote_item {:extension_attributes {}
                                                                                                                                        :item_id 0
                                                                                                                                        :original_discount_amount ""
                                                                                                                                        :original_price ""
                                                                                                                                        :original_tax_amount ""}}
                                                                                         :item_id 0
                                                                                         :name ""
                                                                                         :price ""
                                                                                         :product_option {:extension_attributes {:bundle_options [{:extension_attributes {}
                                                                                                                                                   :option_id 0
                                                                                                                                                   :option_qty 0
                                                                                                                                                   :option_selections []}]
                                                                                                                                 :configurable_item_options [{:extension_attributes {}
                                                                                                                                                              :option_id ""
                                                                                                                                                              :option_value 0}]
                                                                                                                                 :custom_options [{:extension_attributes {:file_info {:base64_encoded_data ""
                                                                                                                                                                                      :name ""
                                                                                                                                                                                      :type ""}}
                                                                                                                                                   :option_id ""
                                                                                                                                                   :option_value ""}]
                                                                                                                                 :downloadable_option {:downloadable_links []}
                                                                                                                                 :giftcard_item_option {:custom_giftcard_amount ""
                                                                                                                                                        :extension_attributes {}
                                                                                                                                                        :giftcard_amount ""
                                                                                                                                                        :giftcard_message ""
                                                                                                                                                        :giftcard_recipient_email ""
                                                                                                                                                        :giftcard_recipient_name ""
                                                                                                                                                        :giftcard_sender_email ""
                                                                                                                                                        :giftcard_sender_name ""}}}
                                                                                         :product_type ""
                                                                                         :qty ""
                                                                                         :quote_id ""
                                                                                         :sku ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/items"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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}}/V1/carts/mine/items"),
    Content = new StringContent("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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}}/V1/carts/mine/items");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/items"

	payload := strings.NewReader("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/mine/items HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1573

{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/mine/items")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/items"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/items")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/mine/items")
  .header("content-type", "application/json")
  .body("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [
          {
            extension_attributes: {},
            option_id: 0,
            option_qty: 0,
            option_selections: []
          }
        ],
        configurable_item_options: [
          {
            extension_attributes: {},
            option_id: '',
            option_value: 0
          }
        ],
        custom_options: [
          {
            extension_attributes: {
              file_info: {
                base64_encoded_data: '',
                name: '',
                type: ''
              }
            },
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {
          downloadable_links: []
        },
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/carts/mine/items');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/items',
  headers: {'content-type': 'application/json'},
  data: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/items';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"cartItem":{"extension_attributes":{"negotiable_quote_item":{"extension_attributes":{},"item_id":0,"original_discount_amount":"","original_price":"","original_tax_amount":""}},"item_id":0,"name":"","price":"","product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty":"","quote_id":"","sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/items',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "cartItem": {\n    "extension_attributes": {\n      "negotiable_quote_item": {\n        "extension_attributes": {},\n        "item_id": 0,\n        "original_discount_amount": "",\n        "original_price": "",\n        "original_tax_amount": ""\n      }\n    },\n    "item_id": 0,\n    "name": "",\n    "price": "",\n    "product_option": {\n      "extension_attributes": {\n        "bundle_options": [\n          {\n            "extension_attributes": {},\n            "option_id": 0,\n            "option_qty": 0,\n            "option_selections": []\n          }\n        ],\n        "configurable_item_options": [\n          {\n            "extension_attributes": {},\n            "option_id": "",\n            "option_value": 0\n          }\n        ],\n        "custom_options": [\n          {\n            "extension_attributes": {\n              "file_info": {\n                "base64_encoded_data": "",\n                "name": "",\n                "type": ""\n              }\n            },\n            "option_id": "",\n            "option_value": ""\n          }\n        ],\n        "downloadable_option": {\n          "downloadable_links": []\n        },\n        "giftcard_item_option": {\n          "custom_giftcard_amount": "",\n          "extension_attributes": {},\n          "giftcard_amount": "",\n          "giftcard_message": "",\n          "giftcard_recipient_email": "",\n          "giftcard_recipient_name": "",\n          "giftcard_sender_email": "",\n          "giftcard_sender_name": ""\n        }\n      }\n    },\n    "product_type": "",\n    "qty": "",\n    "quote_id": "",\n    "sku": ""\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  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/items")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/items',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
        configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
        custom_options: [
          {
            extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {downloadable_links: []},
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/items',
  headers: {'content-type': 'application/json'},
  body: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  },
  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}}/V1/carts/mine/items');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [
          {
            extension_attributes: {},
            option_id: 0,
            option_qty: 0,
            option_selections: []
          }
        ],
        configurable_item_options: [
          {
            extension_attributes: {},
            option_id: '',
            option_value: 0
          }
        ],
        custom_options: [
          {
            extension_attributes: {
              file_info: {
                base64_encoded_data: '',
                name: '',
                type: ''
              }
            },
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {
          downloadable_links: []
        },
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
});

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}}/V1/carts/mine/items',
  headers: {'content-type': 'application/json'},
  data: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/items';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"cartItem":{"extension_attributes":{"negotiable_quote_item":{"extension_attributes":{},"item_id":0,"original_discount_amount":"","original_price":"","original_tax_amount":""}},"item_id":0,"name":"","price":"","product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty":"","quote_id":"","sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"cartItem": @{ @"extension_attributes": @{ @"negotiable_quote_item": @{ @"extension_attributes": @{  }, @"item_id": @0, @"original_discount_amount": @"", @"original_price": @"", @"original_tax_amount": @"" } }, @"item_id": @0, @"name": @"", @"price": @"", @"product_option": @{ @"extension_attributes": @{ @"bundle_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @0, @"option_qty": @0, @"option_selections": @[  ] } ], @"configurable_item_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @"", @"option_value": @0 } ], @"custom_options": @[ @{ @"extension_attributes": @{ @"file_info": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" } }, @"option_id": @"", @"option_value": @"" } ], @"downloadable_option": @{ @"downloadable_links": @[  ] }, @"giftcard_item_option": @{ @"custom_giftcard_amount": @"", @"extension_attributes": @{  }, @"giftcard_amount": @"", @"giftcard_message": @"", @"giftcard_recipient_email": @"", @"giftcard_recipient_name": @"", @"giftcard_sender_email": @"", @"giftcard_sender_name": @"" } } }, @"product_type": @"", @"qty": @"", @"quote_id": @"", @"sku": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/items"]
                                                       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}}/V1/carts/mine/items" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/items",
  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([
    'cartItem' => [
        'extension_attributes' => [
                'negotiable_quote_item' => [
                                'extension_attributes' => [
                                                                
                                ],
                                'item_id' => 0,
                                'original_discount_amount' => '',
                                'original_price' => '',
                                'original_tax_amount' => ''
                ]
        ],
        'item_id' => 0,
        'name' => '',
        'price' => '',
        'product_option' => [
                'extension_attributes' => [
                                'bundle_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'option_id' => 0,
                                                                                                                                'option_qty' => 0,
                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'configurable_item_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'option_id' => '',
                                                                                                                                'option_value' => 0
                                                                ]
                                ],
                                'custom_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'option_id' => '',
                                                                                                                                'option_value' => ''
                                                                ]
                                ],
                                'downloadable_option' => [
                                                                'downloadable_links' => [
                                                                                                                                
                                                                ]
                                ],
                                'giftcard_item_option' => [
                                                                'custom_giftcard_amount' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'giftcard_amount' => '',
                                                                'giftcard_message' => '',
                                                                'giftcard_recipient_email' => '',
                                                                'giftcard_recipient_name' => '',
                                                                'giftcard_sender_email' => '',
                                                                'giftcard_sender_name' => ''
                                ]
                ]
        ],
        'product_type' => '',
        'qty' => '',
        'quote_id' => '',
        'sku' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/mine/items', [
  'body' => '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/items');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'cartItem' => [
    'extension_attributes' => [
        'negotiable_quote_item' => [
                'extension_attributes' => [
                                
                ],
                'item_id' => 0,
                'original_discount_amount' => '',
                'original_price' => '',
                'original_tax_amount' => ''
        ]
    ],
    'item_id' => 0,
    'name' => '',
    'price' => '',
    'product_option' => [
        'extension_attributes' => [
                'bundle_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'option_qty' => 0,
                                                                'option_selections' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'configurable_item_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => 0
                                ]
                ],
                'custom_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ]
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => ''
                                ]
                ],
                'downloadable_option' => [
                                'downloadable_links' => [
                                                                
                                ]
                ],
                'giftcard_item_option' => [
                                'custom_giftcard_amount' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'giftcard_amount' => '',
                                'giftcard_message' => '',
                                'giftcard_recipient_email' => '',
                                'giftcard_recipient_name' => '',
                                'giftcard_sender_email' => '',
                                'giftcard_sender_name' => ''
                ]
        ]
    ],
    'product_type' => '',
    'qty' => '',
    'quote_id' => '',
    'sku' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'cartItem' => [
    'extension_attributes' => [
        'negotiable_quote_item' => [
                'extension_attributes' => [
                                
                ],
                'item_id' => 0,
                'original_discount_amount' => '',
                'original_price' => '',
                'original_tax_amount' => ''
        ]
    ],
    'item_id' => 0,
    'name' => '',
    'price' => '',
    'product_option' => [
        'extension_attributes' => [
                'bundle_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'option_qty' => 0,
                                                                'option_selections' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'configurable_item_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => 0
                                ]
                ],
                'custom_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ]
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => ''
                                ]
                ],
                'downloadable_option' => [
                                'downloadable_links' => [
                                                                
                                ]
                ],
                'giftcard_item_option' => [
                                'custom_giftcard_amount' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'giftcard_amount' => '',
                                'giftcard_message' => '',
                                'giftcard_recipient_email' => '',
                                'giftcard_recipient_name' => '',
                                'giftcard_sender_email' => '',
                                'giftcard_sender_name' => ''
                ]
        ]
    ],
    'product_type' => '',
    'qty' => '',
    'quote_id' => '',
    'sku' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/items');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/items' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/items' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/mine/items", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/items"

payload = { "cartItem": {
        "extension_attributes": { "negotiable_quote_item": {
                "extension_attributes": {},
                "item_id": 0,
                "original_discount_amount": "",
                "original_price": "",
                "original_tax_amount": ""
            } },
        "item_id": 0,
        "name": "",
        "price": "",
        "product_option": { "extension_attributes": {
                "bundle_options": [
                    {
                        "extension_attributes": {},
                        "option_id": 0,
                        "option_qty": 0,
                        "option_selections": []
                    }
                ],
                "configurable_item_options": [
                    {
                        "extension_attributes": {},
                        "option_id": "",
                        "option_value": 0
                    }
                ],
                "custom_options": [
                    {
                        "extension_attributes": { "file_info": {
                                "base64_encoded_data": "",
                                "name": "",
                                "type": ""
                            } },
                        "option_id": "",
                        "option_value": ""
                    }
                ],
                "downloadable_option": { "downloadable_links": [] },
                "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                }
            } },
        "product_type": "",
        "qty": "",
        "quote_id": "",
        "sku": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/items"

payload <- "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/items")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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/V1/carts/mine/items') do |req|
  req.body = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/items";

    let payload = json!({"cartItem": json!({
            "extension_attributes": json!({"negotiable_quote_item": json!({
                    "extension_attributes": json!({}),
                    "item_id": 0,
                    "original_discount_amount": "",
                    "original_price": "",
                    "original_tax_amount": ""
                })}),
            "item_id": 0,
            "name": "",
            "price": "",
            "product_option": json!({"extension_attributes": json!({
                    "bundle_options": (
                        json!({
                            "extension_attributes": json!({}),
                            "option_id": 0,
                            "option_qty": 0,
                            "option_selections": ()
                        })
                    ),
                    "configurable_item_options": (
                        json!({
                            "extension_attributes": json!({}),
                            "option_id": "",
                            "option_value": 0
                        })
                    ),
                    "custom_options": (
                        json!({
                            "extension_attributes": json!({"file_info": json!({
                                    "base64_encoded_data": "",
                                    "name": "",
                                    "type": ""
                                })}),
                            "option_id": "",
                            "option_value": ""
                        })
                    ),
                    "downloadable_option": json!({"downloadable_links": ()}),
                    "giftcard_item_option": json!({
                        "custom_giftcard_amount": "",
                        "extension_attributes": json!({}),
                        "giftcard_amount": "",
                        "giftcard_message": "",
                        "giftcard_recipient_email": "",
                        "giftcard_recipient_name": "",
                        "giftcard_sender_email": "",
                        "giftcard_sender_name": ""
                    })
                })}),
            "product_type": "",
            "qty": "",
            "quote_id": "",
            "sku": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/mine/items \
  --header 'content-type: application/json' \
  --data '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
echo '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/carts/mine/items \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "cartItem": {\n    "extension_attributes": {\n      "negotiable_quote_item": {\n        "extension_attributes": {},\n        "item_id": 0,\n        "original_discount_amount": "",\n        "original_price": "",\n        "original_tax_amount": ""\n      }\n    },\n    "item_id": 0,\n    "name": "",\n    "price": "",\n    "product_option": {\n      "extension_attributes": {\n        "bundle_options": [\n          {\n            "extension_attributes": {},\n            "option_id": 0,\n            "option_qty": 0,\n            "option_selections": []\n          }\n        ],\n        "configurable_item_options": [\n          {\n            "extension_attributes": {},\n            "option_id": "",\n            "option_value": 0\n          }\n        ],\n        "custom_options": [\n          {\n            "extension_attributes": {\n              "file_info": {\n                "base64_encoded_data": "",\n                "name": "",\n                "type": ""\n              }\n            },\n            "option_id": "",\n            "option_value": ""\n          }\n        ],\n        "downloadable_option": {\n          "downloadable_links": []\n        },\n        "giftcard_item_option": {\n          "custom_giftcard_amount": "",\n          "extension_attributes": {},\n          "giftcard_amount": "",\n          "giftcard_message": "",\n          "giftcard_recipient_email": "",\n          "giftcard_recipient_name": "",\n          "giftcard_sender_email": "",\n          "giftcard_sender_name": ""\n        }\n      }\n    },\n    "product_type": "",\n    "qty": "",\n    "quote_id": "",\n    "sku": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/items
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["cartItem": [
    "extension_attributes": ["negotiable_quote_item": [
        "extension_attributes": [],
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      ]],
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": ["extension_attributes": [
        "bundle_options": [
          [
            "extension_attributes": [],
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          ]
        ],
        "configurable_item_options": [
          [
            "extension_attributes": [],
            "option_id": "",
            "option_value": 0
          ]
        ],
        "custom_options": [
          [
            "extension_attributes": ["file_info": [
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              ]],
            "option_id": "",
            "option_value": ""
          ]
        ],
        "downloadable_option": ["downloadable_links": []],
        "giftcard_item_option": [
          "custom_giftcard_amount": "",
          "extension_attributes": [],
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        ]
      ]],
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/items")! 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 carts-mine-items
{{baseUrl}}/V1/carts/mine/items
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/items");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/mine/items")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/items"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/items"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/items");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/items"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/mine/items HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/mine/items")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/items"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/items")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/mine/items")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/mine/items');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/mine/items'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/items';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/items',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/items")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/items',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/mine/items'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/mine/items');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/mine/items'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/items';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/items"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/items" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/items",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/mine/items');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/items');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/items');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/items' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/items' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/mine/items")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/items"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/items"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/items")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/mine/items') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/items";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/mine/items
http GET {{baseUrl}}/V1/carts/mine/items
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/items
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/items")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT carts-mine-items-{itemId} (PUT)
{{baseUrl}}/V1/carts/mine/items/:itemId
QUERY PARAMS

itemId
BODY json

{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/items/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/carts/mine/items/:itemId" {:content-type :json
                                                                       :form-params {:cartItem {:extension_attributes {:negotiable_quote_item {:extension_attributes {}
                                                                                                                                               :item_id 0
                                                                                                                                               :original_discount_amount ""
                                                                                                                                               :original_price ""
                                                                                                                                               :original_tax_amount ""}}
                                                                                                :item_id 0
                                                                                                :name ""
                                                                                                :price ""
                                                                                                :product_option {:extension_attributes {:bundle_options [{:extension_attributes {}
                                                                                                                                                          :option_id 0
                                                                                                                                                          :option_qty 0
                                                                                                                                                          :option_selections []}]
                                                                                                                                        :configurable_item_options [{:extension_attributes {}
                                                                                                                                                                     :option_id ""
                                                                                                                                                                     :option_value 0}]
                                                                                                                                        :custom_options [{:extension_attributes {:file_info {:base64_encoded_data ""
                                                                                                                                                                                             :name ""
                                                                                                                                                                                             :type ""}}
                                                                                                                                                          :option_id ""
                                                                                                                                                          :option_value ""}]
                                                                                                                                        :downloadable_option {:downloadable_links []}
                                                                                                                                        :giftcard_item_option {:custom_giftcard_amount ""
                                                                                                                                                               :extension_attributes {}
                                                                                                                                                               :giftcard_amount ""
                                                                                                                                                               :giftcard_message ""
                                                                                                                                                               :giftcard_recipient_email ""
                                                                                                                                                               :giftcard_recipient_name ""
                                                                                                                                                               :giftcard_sender_email ""
                                                                                                                                                               :giftcard_sender_name ""}}}
                                                                                                :product_type ""
                                                                                                :qty ""
                                                                                                :quote_id ""
                                                                                                :sku ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/items/:itemId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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}}/V1/carts/mine/items/:itemId"),
    Content = new StringContent("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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}}/V1/carts/mine/items/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/items/:itemId"

	payload := strings.NewReader("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/carts/mine/items/:itemId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1573

{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/carts/mine/items/:itemId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/items/:itemId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/items/:itemId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/carts/mine/items/:itemId")
  .header("content-type", "application/json")
  .body("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [
          {
            extension_attributes: {},
            option_id: 0,
            option_qty: 0,
            option_selections: []
          }
        ],
        configurable_item_options: [
          {
            extension_attributes: {},
            option_id: '',
            option_value: 0
          }
        ],
        custom_options: [
          {
            extension_attributes: {
              file_info: {
                base64_encoded_data: '',
                name: '',
                type: ''
              }
            },
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {
          downloadable_links: []
        },
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/carts/mine/items/:itemId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/mine/items/:itemId',
  headers: {'content-type': 'application/json'},
  data: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/items/:itemId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"cartItem":{"extension_attributes":{"negotiable_quote_item":{"extension_attributes":{},"item_id":0,"original_discount_amount":"","original_price":"","original_tax_amount":""}},"item_id":0,"name":"","price":"","product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty":"","quote_id":"","sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/items/:itemId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "cartItem": {\n    "extension_attributes": {\n      "negotiable_quote_item": {\n        "extension_attributes": {},\n        "item_id": 0,\n        "original_discount_amount": "",\n        "original_price": "",\n        "original_tax_amount": ""\n      }\n    },\n    "item_id": 0,\n    "name": "",\n    "price": "",\n    "product_option": {\n      "extension_attributes": {\n        "bundle_options": [\n          {\n            "extension_attributes": {},\n            "option_id": 0,\n            "option_qty": 0,\n            "option_selections": []\n          }\n        ],\n        "configurable_item_options": [\n          {\n            "extension_attributes": {},\n            "option_id": "",\n            "option_value": 0\n          }\n        ],\n        "custom_options": [\n          {\n            "extension_attributes": {\n              "file_info": {\n                "base64_encoded_data": "",\n                "name": "",\n                "type": ""\n              }\n            },\n            "option_id": "",\n            "option_value": ""\n          }\n        ],\n        "downloadable_option": {\n          "downloadable_links": []\n        },\n        "giftcard_item_option": {\n          "custom_giftcard_amount": "",\n          "extension_attributes": {},\n          "giftcard_amount": "",\n          "giftcard_message": "",\n          "giftcard_recipient_email": "",\n          "giftcard_recipient_name": "",\n          "giftcard_sender_email": "",\n          "giftcard_sender_name": ""\n        }\n      }\n    },\n    "product_type": "",\n    "qty": "",\n    "quote_id": "",\n    "sku": ""\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  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/items/:itemId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/items/:itemId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
        configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
        custom_options: [
          {
            extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {downloadable_links: []},
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/mine/items/:itemId',
  headers: {'content-type': 'application/json'},
  body: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  },
  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}}/V1/carts/mine/items/:itemId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [
          {
            extension_attributes: {},
            option_id: 0,
            option_qty: 0,
            option_selections: []
          }
        ],
        configurable_item_options: [
          {
            extension_attributes: {},
            option_id: '',
            option_value: 0
          }
        ],
        custom_options: [
          {
            extension_attributes: {
              file_info: {
                base64_encoded_data: '',
                name: '',
                type: ''
              }
            },
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {
          downloadable_links: []
        },
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
});

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}}/V1/carts/mine/items/:itemId',
  headers: {'content-type': 'application/json'},
  data: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/items/:itemId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"cartItem":{"extension_attributes":{"negotiable_quote_item":{"extension_attributes":{},"item_id":0,"original_discount_amount":"","original_price":"","original_tax_amount":""}},"item_id":0,"name":"","price":"","product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty":"","quote_id":"","sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"cartItem": @{ @"extension_attributes": @{ @"negotiable_quote_item": @{ @"extension_attributes": @{  }, @"item_id": @0, @"original_discount_amount": @"", @"original_price": @"", @"original_tax_amount": @"" } }, @"item_id": @0, @"name": @"", @"price": @"", @"product_option": @{ @"extension_attributes": @{ @"bundle_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @0, @"option_qty": @0, @"option_selections": @[  ] } ], @"configurable_item_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @"", @"option_value": @0 } ], @"custom_options": @[ @{ @"extension_attributes": @{ @"file_info": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" } }, @"option_id": @"", @"option_value": @"" } ], @"downloadable_option": @{ @"downloadable_links": @[  ] }, @"giftcard_item_option": @{ @"custom_giftcard_amount": @"", @"extension_attributes": @{  }, @"giftcard_amount": @"", @"giftcard_message": @"", @"giftcard_recipient_email": @"", @"giftcard_recipient_name": @"", @"giftcard_sender_email": @"", @"giftcard_sender_name": @"" } } }, @"product_type": @"", @"qty": @"", @"quote_id": @"", @"sku": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/items/: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}}/V1/carts/mine/items/:itemId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/items/: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([
    'cartItem' => [
        'extension_attributes' => [
                'negotiable_quote_item' => [
                                'extension_attributes' => [
                                                                
                                ],
                                'item_id' => 0,
                                'original_discount_amount' => '',
                                'original_price' => '',
                                'original_tax_amount' => ''
                ]
        ],
        'item_id' => 0,
        'name' => '',
        'price' => '',
        'product_option' => [
                'extension_attributes' => [
                                'bundle_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'option_id' => 0,
                                                                                                                                'option_qty' => 0,
                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'configurable_item_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'option_id' => '',
                                                                                                                                'option_value' => 0
                                                                ]
                                ],
                                'custom_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'option_id' => '',
                                                                                                                                'option_value' => ''
                                                                ]
                                ],
                                'downloadable_option' => [
                                                                'downloadable_links' => [
                                                                                                                                
                                                                ]
                                ],
                                'giftcard_item_option' => [
                                                                'custom_giftcard_amount' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'giftcard_amount' => '',
                                                                'giftcard_message' => '',
                                                                'giftcard_recipient_email' => '',
                                                                'giftcard_recipient_name' => '',
                                                                'giftcard_sender_email' => '',
                                                                'giftcard_sender_name' => ''
                                ]
                ]
        ],
        'product_type' => '',
        'qty' => '',
        'quote_id' => '',
        'sku' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/carts/mine/items/:itemId', [
  'body' => '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/items/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'cartItem' => [
    'extension_attributes' => [
        'negotiable_quote_item' => [
                'extension_attributes' => [
                                
                ],
                'item_id' => 0,
                'original_discount_amount' => '',
                'original_price' => '',
                'original_tax_amount' => ''
        ]
    ],
    'item_id' => 0,
    'name' => '',
    'price' => '',
    'product_option' => [
        'extension_attributes' => [
                'bundle_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'option_qty' => 0,
                                                                'option_selections' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'configurable_item_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => 0
                                ]
                ],
                'custom_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ]
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => ''
                                ]
                ],
                'downloadable_option' => [
                                'downloadable_links' => [
                                                                
                                ]
                ],
                'giftcard_item_option' => [
                                'custom_giftcard_amount' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'giftcard_amount' => '',
                                'giftcard_message' => '',
                                'giftcard_recipient_email' => '',
                                'giftcard_recipient_name' => '',
                                'giftcard_sender_email' => '',
                                'giftcard_sender_name' => ''
                ]
        ]
    ],
    'product_type' => '',
    'qty' => '',
    'quote_id' => '',
    'sku' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'cartItem' => [
    'extension_attributes' => [
        'negotiable_quote_item' => [
                'extension_attributes' => [
                                
                ],
                'item_id' => 0,
                'original_discount_amount' => '',
                'original_price' => '',
                'original_tax_amount' => ''
        ]
    ],
    'item_id' => 0,
    'name' => '',
    'price' => '',
    'product_option' => [
        'extension_attributes' => [
                'bundle_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'option_qty' => 0,
                                                                'option_selections' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'configurable_item_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => 0
                                ]
                ],
                'custom_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ]
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => ''
                                ]
                ],
                'downloadable_option' => [
                                'downloadable_links' => [
                                                                
                                ]
                ],
                'giftcard_item_option' => [
                                'custom_giftcard_amount' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'giftcard_amount' => '',
                                'giftcard_message' => '',
                                'giftcard_recipient_email' => '',
                                'giftcard_recipient_name' => '',
                                'giftcard_sender_email' => '',
                                'giftcard_sender_name' => ''
                ]
        ]
    ],
    'product_type' => '',
    'qty' => '',
    'quote_id' => '',
    'sku' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/items/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/items/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/items/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/carts/mine/items/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/items/:itemId"

payload = { "cartItem": {
        "extension_attributes": { "negotiable_quote_item": {
                "extension_attributes": {},
                "item_id": 0,
                "original_discount_amount": "",
                "original_price": "",
                "original_tax_amount": ""
            } },
        "item_id": 0,
        "name": "",
        "price": "",
        "product_option": { "extension_attributes": {
                "bundle_options": [
                    {
                        "extension_attributes": {},
                        "option_id": 0,
                        "option_qty": 0,
                        "option_selections": []
                    }
                ],
                "configurable_item_options": [
                    {
                        "extension_attributes": {},
                        "option_id": "",
                        "option_value": 0
                    }
                ],
                "custom_options": [
                    {
                        "extension_attributes": { "file_info": {
                                "base64_encoded_data": "",
                                "name": "",
                                "type": ""
                            } },
                        "option_id": "",
                        "option_value": ""
                    }
                ],
                "downloadable_option": { "downloadable_links": [] },
                "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                }
            } },
        "product_type": "",
        "qty": "",
        "quote_id": "",
        "sku": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/items/:itemId"

payload <- "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/items/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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/V1/carts/mine/items/:itemId') do |req|
  req.body = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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}}/V1/carts/mine/items/:itemId";

    let payload = json!({"cartItem": json!({
            "extension_attributes": json!({"negotiable_quote_item": json!({
                    "extension_attributes": json!({}),
                    "item_id": 0,
                    "original_discount_amount": "",
                    "original_price": "",
                    "original_tax_amount": ""
                })}),
            "item_id": 0,
            "name": "",
            "price": "",
            "product_option": json!({"extension_attributes": json!({
                    "bundle_options": (
                        json!({
                            "extension_attributes": json!({}),
                            "option_id": 0,
                            "option_qty": 0,
                            "option_selections": ()
                        })
                    ),
                    "configurable_item_options": (
                        json!({
                            "extension_attributes": json!({}),
                            "option_id": "",
                            "option_value": 0
                        })
                    ),
                    "custom_options": (
                        json!({
                            "extension_attributes": json!({"file_info": json!({
                                    "base64_encoded_data": "",
                                    "name": "",
                                    "type": ""
                                })}),
                            "option_id": "",
                            "option_value": ""
                        })
                    ),
                    "downloadable_option": json!({"downloadable_links": ()}),
                    "giftcard_item_option": json!({
                        "custom_giftcard_amount": "",
                        "extension_attributes": json!({}),
                        "giftcard_amount": "",
                        "giftcard_message": "",
                        "giftcard_recipient_email": "",
                        "giftcard_recipient_name": "",
                        "giftcard_sender_email": "",
                        "giftcard_sender_name": ""
                    })
                })}),
            "product_type": "",
            "qty": "",
            "quote_id": "",
            "sku": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/carts/mine/items/:itemId \
  --header 'content-type: application/json' \
  --data '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
echo '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/carts/mine/items/:itemId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "cartItem": {\n    "extension_attributes": {\n      "negotiable_quote_item": {\n        "extension_attributes": {},\n        "item_id": 0,\n        "original_discount_amount": "",\n        "original_price": "",\n        "original_tax_amount": ""\n      }\n    },\n    "item_id": 0,\n    "name": "",\n    "price": "",\n    "product_option": {\n      "extension_attributes": {\n        "bundle_options": [\n          {\n            "extension_attributes": {},\n            "option_id": 0,\n            "option_qty": 0,\n            "option_selections": []\n          }\n        ],\n        "configurable_item_options": [\n          {\n            "extension_attributes": {},\n            "option_id": "",\n            "option_value": 0\n          }\n        ],\n        "custom_options": [\n          {\n            "extension_attributes": {\n              "file_info": {\n                "base64_encoded_data": "",\n                "name": "",\n                "type": ""\n              }\n            },\n            "option_id": "",\n            "option_value": ""\n          }\n        ],\n        "downloadable_option": {\n          "downloadable_links": []\n        },\n        "giftcard_item_option": {\n          "custom_giftcard_amount": "",\n          "extension_attributes": {},\n          "giftcard_amount": "",\n          "giftcard_message": "",\n          "giftcard_recipient_email": "",\n          "giftcard_recipient_name": "",\n          "giftcard_sender_email": "",\n          "giftcard_sender_name": ""\n        }\n      }\n    },\n    "product_type": "",\n    "qty": "",\n    "quote_id": "",\n    "sku": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/items/:itemId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["cartItem": [
    "extension_attributes": ["negotiable_quote_item": [
        "extension_attributes": [],
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      ]],
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": ["extension_attributes": [
        "bundle_options": [
          [
            "extension_attributes": [],
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          ]
        ],
        "configurable_item_options": [
          [
            "extension_attributes": [],
            "option_id": "",
            "option_value": 0
          ]
        ],
        "custom_options": [
          [
            "extension_attributes": ["file_info": [
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              ]],
            "option_id": "",
            "option_value": ""
          ]
        ],
        "downloadable_option": ["downloadable_links": []],
        "giftcard_item_option": [
          "custom_giftcard_amount": "",
          "extension_attributes": [],
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        ]
      ]],
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/items/: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()
DELETE carts-mine-items-{itemId}
{{baseUrl}}/V1/carts/mine/items/:itemId
QUERY PARAMS

itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/items/:itemId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/carts/mine/items/:itemId")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/items/:itemId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/items/:itemId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/items/:itemId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/items/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/carts/mine/items/:itemId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/carts/mine/items/:itemId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/items/:itemId"))
    .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}}/V1/carts/mine/items/:itemId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/carts/mine/items/:itemId")
  .asString();
const 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}}/V1/carts/mine/items/:itemId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/carts/mine/items/:itemId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/items/:itemId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/items/:itemId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/items/:itemId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/items/:itemId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/carts/mine/items/:itemId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/carts/mine/items/:itemId');

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}}/V1/carts/mine/items/:itemId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/items/:itemId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/items/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/items/:itemId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/items/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/carts/mine/items/:itemId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/items/:itemId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/items/:itemId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/items/:itemId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/items/:itemId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/carts/mine/items/:itemId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/items/:itemId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/items/:itemId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/items/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/carts/mine/items/:itemId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/items/:itemId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/carts/mine/items/:itemId
http DELETE {{baseUrl}}/V1/carts/mine/items/:itemId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/items/:itemId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/items/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT carts-mine-order
{{baseUrl}}/V1/carts/mine/order
BODY json

{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/order");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/carts/mine/order" {:content-type :json
                                                               :form-params {:paymentMethod {:additional_data []
                                                                                             :extension_attributes {:agreement_ids []}
                                                                                             :method ""
                                                                                             :po_number ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/order"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/carts/mine/order"),
    Content = new StringContent("{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/carts/mine/order");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/order"

	payload := strings.NewReader("{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/carts/mine/order HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 156

{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/carts/mine/order")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/order"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/order")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/carts/mine/order")
  .header("content-type", "application/json")
  .body("{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/carts/mine/order');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/mine/order',
  headers: {'content-type': 'application/json'},
  data: {
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/order';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/order',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\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  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/order")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/order',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  paymentMethod: {
    additional_data: [],
    extension_attributes: {agreement_ids: []},
    method: '',
    po_number: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/mine/order',
  headers: {'content-type': 'application/json'},
  body: {
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/carts/mine/order');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/mine/order',
  headers: {'content-type': 'application/json'},
  data: {
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/order';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"paymentMethod": @{ @"additional_data": @[  ], @"extension_attributes": @{ @"agreement_ids": @[  ] }, @"method": @"", @"po_number": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/order"]
                                                       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}}/V1/carts/mine/order" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/order",
  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([
    'paymentMethod' => [
        'additional_data' => [
                
        ],
        'extension_attributes' => [
                'agreement_ids' => [
                                
                ]
        ],
        'method' => '',
        'po_number' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/carts/mine/order', [
  'body' => '{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/order');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/order');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/order' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/order' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/carts/mine/order", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/order"

payload = { "paymentMethod": {
        "additional_data": [],
        "extension_attributes": { "agreement_ids": [] },
        "method": "",
        "po_number": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/order"

payload <- "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/order")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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/V1/carts/mine/order') do |req|
  req.body = "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/carts/mine/order";

    let payload = json!({"paymentMethod": json!({
            "additional_data": (),
            "extension_attributes": json!({"agreement_ids": ()}),
            "method": "",
            "po_number": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/carts/mine/order \
  --header 'content-type: application/json' \
  --data '{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
echo '{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/carts/mine/order \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/order
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["paymentMethod": [
    "additional_data": [],
    "extension_attributes": ["agreement_ids": []],
    "method": "",
    "po_number": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/order")! 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 carts-mine-payment-information (POST)
{{baseUrl}}/V1/carts/mine/payment-information
BODY json

{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/payment-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/mine/payment-information" {:content-type :json
                                                                              :form-params {:billingAddress {:city ""
                                                                                                             :company ""
                                                                                                             :country_id ""
                                                                                                             :custom_attributes [{:attribute_code ""
                                                                                                                                  :value ""}]
                                                                                                             :customer_address_id 0
                                                                                                             :customer_id 0
                                                                                                             :email ""
                                                                                                             :extension_attributes {:checkout_fields [{}]
                                                                                                                                    :gift_registry_id 0}
                                                                                                             :fax ""
                                                                                                             :firstname ""
                                                                                                             :id 0
                                                                                                             :lastname ""
                                                                                                             :middlename ""
                                                                                                             :postcode ""
                                                                                                             :prefix ""
                                                                                                             :region ""
                                                                                                             :region_code ""
                                                                                                             :region_id 0
                                                                                                             :same_as_billing 0
                                                                                                             :save_in_address_book 0
                                                                                                             :street []
                                                                                                             :suffix ""
                                                                                                             :telephone ""
                                                                                                             :vat_id ""}
                                                                                            :paymentMethod {:additional_data []
                                                                                                            :extension_attributes {:agreement_ids []}
                                                                                                            :method ""
                                                                                                            :po_number ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/payment-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/carts/mine/payment-information"),
    Content = new StringContent("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/carts/mine/payment-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/payment-information"

	payload := strings.NewReader("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/mine/payment-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 842

{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/mine/payment-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/payment-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/payment-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/mine/payment-information")
  .header("content-type", "application/json")
  .body("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/carts/mine/payment-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/payment-information',
  headers: {'content-type': 'application/json'},
  data: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/payment-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"billingAddress":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/payment-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "billingAddress": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\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  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/payment-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/payment-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {agreement_ids: []},
    method: '',
    po_number: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/payment-information',
  headers: {'content-type': 'application/json'},
  body: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/carts/mine/payment-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/payment-information',
  headers: {'content-type': 'application/json'},
  data: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/payment-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"billingAddress":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"billingAddress": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" },
                              @"paymentMethod": @{ @"additional_data": @[  ], @"extension_attributes": @{ @"agreement_ids": @[  ] }, @"method": @"", @"po_number": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/payment-information"]
                                                       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}}/V1/carts/mine/payment-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/payment-information",
  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([
    'billingAddress' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'paymentMethod' => [
        'additional_data' => [
                
        ],
        'extension_attributes' => [
                'agreement_ids' => [
                                
                ]
        ],
        'method' => '',
        'po_number' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/mine/payment-information', [
  'body' => '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/payment-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'billingAddress' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'billingAddress' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/payment-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/payment-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/payment-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/mine/payment-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/payment-information"

payload = {
    "billingAddress": {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "extension_attributes": {
            "checkout_fields": [{}],
            "gift_registry_id": 0
        },
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "same_as_billing": 0,
        "save_in_address_book": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
    },
    "paymentMethod": {
        "additional_data": [],
        "extension_attributes": { "agreement_ids": [] },
        "method": "",
        "po_number": ""
    }
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/payment-information"

payload <- "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/payment-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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/V1/carts/mine/payment-information') do |req|
  req.body = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/payment-information";

    let payload = json!({
        "billingAddress": json!({
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": json!({
                "checkout_fields": (json!({})),
                "gift_registry_id": 0
            }),
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": (),
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        }),
        "paymentMethod": json!({
            "additional_data": (),
            "extension_attributes": json!({"agreement_ids": ()}),
            "method": "",
            "po_number": ""
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/mine/payment-information \
  --header 'content-type: application/json' \
  --data '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
echo '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/carts/mine/payment-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "billingAddress": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/payment-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "billingAddress": [
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": [
      "checkout_fields": [[]],
      "gift_registry_id": 0
    ],
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  ],
  "paymentMethod": [
    "additional_data": [],
    "extension_attributes": ["agreement_ids": []],
    "method": "",
    "po_number": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/payment-information")! 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 carts-mine-payment-information
{{baseUrl}}/V1/carts/mine/payment-information
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/payment-information");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/mine/payment-information")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/payment-information"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/payment-information"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/payment-information");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/payment-information"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/mine/payment-information HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/mine/payment-information")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/payment-information"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/payment-information")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/mine/payment-information")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/mine/payment-information');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/payment-information'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/payment-information';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/payment-information',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/payment-information")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/payment-information',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/payment-information'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/mine/payment-information');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/payment-information'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/payment-information';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/payment-information"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/payment-information" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/payment-information",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/mine/payment-information');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/payment-information');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/payment-information');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/payment-information' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/payment-information' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/mine/payment-information")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/payment-information"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/payment-information"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/payment-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/mine/payment-information') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/payment-information";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/mine/payment-information
http GET {{baseUrl}}/V1/carts/mine/payment-information
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/payment-information
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/payment-information")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET carts-mine-payment-methods
{{baseUrl}}/V1/carts/mine/payment-methods
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/payment-methods");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/mine/payment-methods")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/payment-methods"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/payment-methods"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/payment-methods");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/payment-methods"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/mine/payment-methods HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/mine/payment-methods")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/payment-methods"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/payment-methods")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/mine/payment-methods")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/mine/payment-methods');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/payment-methods'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/payment-methods';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/payment-methods',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/payment-methods")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/payment-methods',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/payment-methods'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/mine/payment-methods');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/payment-methods'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/payment-methods';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/payment-methods"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/payment-methods" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/payment-methods",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/mine/payment-methods');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/payment-methods');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/payment-methods');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/payment-methods' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/payment-methods' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/mine/payment-methods")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/payment-methods"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/payment-methods"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/payment-methods")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/mine/payment-methods') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/payment-methods";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/mine/payment-methods
http GET {{baseUrl}}/V1/carts/mine/payment-methods
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/payment-methods
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/payment-methods")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT carts-mine-selected-payment-method (PUT)
{{baseUrl}}/V1/carts/mine/selected-payment-method
BODY json

{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/selected-payment-method");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/carts/mine/selected-payment-method" {:content-type :json
                                                                                 :form-params {:method {:additional_data []
                                                                                                        :extension_attributes {:agreement_ids []}
                                                                                                        :method ""
                                                                                                        :po_number ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/selected-payment-method"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/carts/mine/selected-payment-method"),
    Content = new StringContent("{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/carts/mine/selected-payment-method");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/selected-payment-method"

	payload := strings.NewReader("{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/carts/mine/selected-payment-method HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 149

{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/carts/mine/selected-payment-method")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/selected-payment-method"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/selected-payment-method")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/carts/mine/selected-payment-method")
  .header("content-type", "application/json")
  .body("{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  method: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/carts/mine/selected-payment-method');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/mine/selected-payment-method',
  headers: {'content-type': 'application/json'},
  data: {
    method: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/selected-payment-method';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"method":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/selected-payment-method',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "method": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\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  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/selected-payment-method")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/selected-payment-method',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  method: {
    additional_data: [],
    extension_attributes: {agreement_ids: []},
    method: '',
    po_number: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/mine/selected-payment-method',
  headers: {'content-type': 'application/json'},
  body: {
    method: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/carts/mine/selected-payment-method');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  method: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/carts/mine/selected-payment-method',
  headers: {'content-type': 'application/json'},
  data: {
    method: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/selected-payment-method';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"method":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"method": @{ @"additional_data": @[  ], @"extension_attributes": @{ @"agreement_ids": @[  ] }, @"method": @"", @"po_number": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/selected-payment-method"]
                                                       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}}/V1/carts/mine/selected-payment-method" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/selected-payment-method",
  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([
    'method' => [
        'additional_data' => [
                
        ],
        'extension_attributes' => [
                'agreement_ids' => [
                                
                ]
        ],
        'method' => '',
        'po_number' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/carts/mine/selected-payment-method', [
  'body' => '{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/selected-payment-method');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'method' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'method' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/selected-payment-method');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/selected-payment-method' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/selected-payment-method' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/carts/mine/selected-payment-method", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/selected-payment-method"

payload = { "method": {
        "additional_data": [],
        "extension_attributes": { "agreement_ids": [] },
        "method": "",
        "po_number": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/selected-payment-method"

payload <- "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/selected-payment-method")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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/V1/carts/mine/selected-payment-method') do |req|
  req.body = "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/carts/mine/selected-payment-method";

    let payload = json!({"method": json!({
            "additional_data": (),
            "extension_attributes": json!({"agreement_ids": ()}),
            "method": "",
            "po_number": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/carts/mine/selected-payment-method \
  --header 'content-type: application/json' \
  --data '{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
echo '{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/carts/mine/selected-payment-method \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "method": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/selected-payment-method
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["method": [
    "additional_data": [],
    "extension_attributes": ["agreement_ids": []],
    "method": "",
    "po_number": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/selected-payment-method")! 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 carts-mine-selected-payment-method
{{baseUrl}}/V1/carts/mine/selected-payment-method
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/selected-payment-method");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/mine/selected-payment-method")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/selected-payment-method"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/selected-payment-method"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/selected-payment-method");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/selected-payment-method"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/mine/selected-payment-method HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/mine/selected-payment-method")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/selected-payment-method"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/selected-payment-method")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/mine/selected-payment-method")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/mine/selected-payment-method');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/selected-payment-method'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/selected-payment-method';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/selected-payment-method',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/selected-payment-method")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/selected-payment-method',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/selected-payment-method'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/mine/selected-payment-method');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/selected-payment-method'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/selected-payment-method';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/selected-payment-method"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/selected-payment-method" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/selected-payment-method",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/mine/selected-payment-method');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/selected-payment-method');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/selected-payment-method');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/selected-payment-method' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/selected-payment-method' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/mine/selected-payment-method")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/selected-payment-method"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/selected-payment-method"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/selected-payment-method")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/mine/selected-payment-method') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/selected-payment-method";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/mine/selected-payment-method
http GET {{baseUrl}}/V1/carts/mine/selected-payment-method
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/selected-payment-method
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/selected-payment-method")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-mine-set-payment-information
{{baseUrl}}/V1/carts/mine/set-payment-information
BODY json

{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/set-payment-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/mine/set-payment-information" {:content-type :json
                                                                                  :form-params {:billingAddress {:city ""
                                                                                                                 :company ""
                                                                                                                 :country_id ""
                                                                                                                 :custom_attributes [{:attribute_code ""
                                                                                                                                      :value ""}]
                                                                                                                 :customer_address_id 0
                                                                                                                 :customer_id 0
                                                                                                                 :email ""
                                                                                                                 :extension_attributes {:checkout_fields [{}]
                                                                                                                                        :gift_registry_id 0}
                                                                                                                 :fax ""
                                                                                                                 :firstname ""
                                                                                                                 :id 0
                                                                                                                 :lastname ""
                                                                                                                 :middlename ""
                                                                                                                 :postcode ""
                                                                                                                 :prefix ""
                                                                                                                 :region ""
                                                                                                                 :region_code ""
                                                                                                                 :region_id 0
                                                                                                                 :same_as_billing 0
                                                                                                                 :save_in_address_book 0
                                                                                                                 :street []
                                                                                                                 :suffix ""
                                                                                                                 :telephone ""
                                                                                                                 :vat_id ""}
                                                                                                :paymentMethod {:additional_data []
                                                                                                                :extension_attributes {:agreement_ids []}
                                                                                                                :method ""
                                                                                                                :po_number ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/set-payment-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/carts/mine/set-payment-information"),
    Content = new StringContent("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/carts/mine/set-payment-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/set-payment-information"

	payload := strings.NewReader("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/mine/set-payment-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 842

{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/mine/set-payment-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/set-payment-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/set-payment-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/mine/set-payment-information")
  .header("content-type", "application/json")
  .body("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/carts/mine/set-payment-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/set-payment-information',
  headers: {'content-type': 'application/json'},
  data: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/set-payment-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"billingAddress":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/set-payment-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "billingAddress": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\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  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/set-payment-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/set-payment-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {agreement_ids: []},
    method: '',
    po_number: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/set-payment-information',
  headers: {'content-type': 'application/json'},
  body: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/carts/mine/set-payment-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/set-payment-information',
  headers: {'content-type': 'application/json'},
  data: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/set-payment-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"billingAddress":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"billingAddress": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" },
                              @"paymentMethod": @{ @"additional_data": @[  ], @"extension_attributes": @{ @"agreement_ids": @[  ] }, @"method": @"", @"po_number": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/set-payment-information"]
                                                       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}}/V1/carts/mine/set-payment-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/set-payment-information",
  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([
    'billingAddress' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'paymentMethod' => [
        'additional_data' => [
                
        ],
        'extension_attributes' => [
                'agreement_ids' => [
                                
                ]
        ],
        'method' => '',
        'po_number' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/mine/set-payment-information', [
  'body' => '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/set-payment-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'billingAddress' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'billingAddress' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/set-payment-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/set-payment-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/set-payment-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/mine/set-payment-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/set-payment-information"

payload = {
    "billingAddress": {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "extension_attributes": {
            "checkout_fields": [{}],
            "gift_registry_id": 0
        },
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "same_as_billing": 0,
        "save_in_address_book": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
    },
    "paymentMethod": {
        "additional_data": [],
        "extension_attributes": { "agreement_ids": [] },
        "method": "",
        "po_number": ""
    }
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/set-payment-information"

payload <- "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/set-payment-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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/V1/carts/mine/set-payment-information') do |req|
  req.body = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/set-payment-information";

    let payload = json!({
        "billingAddress": json!({
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": json!({
                "checkout_fields": (json!({})),
                "gift_registry_id": 0
            }),
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": (),
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        }),
        "paymentMethod": json!({
            "additional_data": (),
            "extension_attributes": json!({"agreement_ids": ()}),
            "method": "",
            "po_number": ""
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/mine/set-payment-information \
  --header 'content-type: application/json' \
  --data '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
echo '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/carts/mine/set-payment-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "billingAddress": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/set-payment-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "billingAddress": [
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": [
      "checkout_fields": [[]],
      "gift_registry_id": 0
    ],
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  ],
  "paymentMethod": [
    "additional_data": [],
    "extension_attributes": ["agreement_ids": []],
    "method": "",
    "po_number": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/set-payment-information")! 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 carts-mine-shipping-information
{{baseUrl}}/V1/carts/mine/shipping-information
BODY json

{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/shipping-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/mine/shipping-information" {:content-type :json
                                                                               :form-params {:addressInformation {:billing_address {:city ""
                                                                                                                                    :company ""
                                                                                                                                    :country_id ""
                                                                                                                                    :custom_attributes [{:attribute_code ""
                                                                                                                                                         :value ""}]
                                                                                                                                    :customer_address_id 0
                                                                                                                                    :customer_id 0
                                                                                                                                    :email ""
                                                                                                                                    :extension_attributes {:checkout_fields [{}]
                                                                                                                                                           :gift_registry_id 0}
                                                                                                                                    :fax ""
                                                                                                                                    :firstname ""
                                                                                                                                    :id 0
                                                                                                                                    :lastname ""
                                                                                                                                    :middlename ""
                                                                                                                                    :postcode ""
                                                                                                                                    :prefix ""
                                                                                                                                    :region ""
                                                                                                                                    :region_code ""
                                                                                                                                    :region_id 0
                                                                                                                                    :same_as_billing 0
                                                                                                                                    :save_in_address_book 0
                                                                                                                                    :street []
                                                                                                                                    :suffix ""
                                                                                                                                    :telephone ""
                                                                                                                                    :vat_id ""}
                                                                                                                  :custom_attributes [{}]
                                                                                                                  :extension_attributes {}
                                                                                                                  :shipping_address {}
                                                                                                                  :shipping_carrier_code ""
                                                                                                                  :shipping_method_code ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/shipping-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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}}/V1/carts/mine/shipping-information"),
    Content = new StringContent("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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}}/V1/carts/mine/shipping-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/shipping-information"

	payload := strings.NewReader("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/mine/shipping-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 959

{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/mine/shipping-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/shipping-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/shipping-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/mine/shipping-information")
  .header("content-type", "application/json")
  .body("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  addressInformation: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [
      {}
    ],
    extension_attributes: {},
    shipping_address: {},
    shipping_carrier_code: '',
    shipping_method_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}}/V1/carts/mine/shipping-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/shipping-information',
  headers: {'content-type': 'application/json'},
  data: {
    addressInformation: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_address: {},
      shipping_carrier_code: '',
      shipping_method_code: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/shipping-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressInformation":{"billing_address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"custom_attributes":[{}],"extension_attributes":{},"shipping_address":{},"shipping_carrier_code":"","shipping_method_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}}/V1/carts/mine/shipping-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "addressInformation": {\n    "billing_address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "custom_attributes": [\n      {}\n    ],\n    "extension_attributes": {},\n    "shipping_address": {},\n    "shipping_carrier_code": "",\n    "shipping_method_code": ""\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  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/shipping-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/shipping-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  addressInformation: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [{}],
    extension_attributes: {},
    shipping_address: {},
    shipping_carrier_code: '',
    shipping_method_code: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/shipping-information',
  headers: {'content-type': 'application/json'},
  body: {
    addressInformation: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_address: {},
      shipping_carrier_code: '',
      shipping_method_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}}/V1/carts/mine/shipping-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  addressInformation: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [
      {}
    ],
    extension_attributes: {},
    shipping_address: {},
    shipping_carrier_code: '',
    shipping_method_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}}/V1/carts/mine/shipping-information',
  headers: {'content-type': 'application/json'},
  data: {
    addressInformation: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_address: {},
      shipping_carrier_code: '',
      shipping_method_code: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/shipping-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressInformation":{"billing_address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"custom_attributes":[{}],"extension_attributes":{},"shipping_address":{},"shipping_carrier_code":"","shipping_method_code":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"addressInformation": @{ @"billing_address": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" }, @"custom_attributes": @[ @{  } ], @"extension_attributes": @{  }, @"shipping_address": @{  }, @"shipping_carrier_code": @"", @"shipping_method_code": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/shipping-information"]
                                                       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}}/V1/carts/mine/shipping-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/shipping-information",
  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([
    'addressInformation' => [
        'billing_address' => [
                'city' => '',
                'company' => '',
                'country_id' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_address_id' => 0,
                'customer_id' => 0,
                'email' => '',
                'extension_attributes' => [
                                'checkout_fields' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'gift_registry_id' => 0
                ],
                'fax' => '',
                'firstname' => '',
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'postcode' => '',
                'prefix' => '',
                'region' => '',
                'region_code' => '',
                'region_id' => 0,
                'same_as_billing' => 0,
                'save_in_address_book' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => ''
        ],
        'custom_attributes' => [
                [
                                
                ]
        ],
        'extension_attributes' => [
                
        ],
        'shipping_address' => [
                
        ],
        'shipping_carrier_code' => '',
        'shipping_method_code' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/mine/shipping-information', [
  'body' => '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/shipping-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'addressInformation' => [
    'billing_address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'extension_attributes' => [
        
    ],
    'shipping_address' => [
        
    ],
    'shipping_carrier_code' => '',
    'shipping_method_code' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'addressInformation' => [
    'billing_address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'extension_attributes' => [
        
    ],
    'shipping_address' => [
        
    ],
    'shipping_carrier_code' => '',
    'shipping_method_code' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/shipping-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/shipping-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/shipping-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/mine/shipping-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/shipping-information"

payload = { "addressInformation": {
        "billing_address": {
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": [
                {
                    "attribute_code": "",
                    "value": ""
                }
            ],
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": {
                "checkout_fields": [{}],
                "gift_registry_id": 0
            },
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": [],
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        },
        "custom_attributes": [{}],
        "extension_attributes": {},
        "shipping_address": {},
        "shipping_carrier_code": "",
        "shipping_method_code": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/shipping-information"

payload <- "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/shipping-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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/V1/carts/mine/shipping-information') do |req|
  req.body = "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/shipping-information";

    let payload = json!({"addressInformation": json!({
            "billing_address": json!({
                "city": "",
                "company": "",
                "country_id": "",
                "custom_attributes": (
                    json!({
                        "attribute_code": "",
                        "value": ""
                    })
                ),
                "customer_address_id": 0,
                "customer_id": 0,
                "email": "",
                "extension_attributes": json!({
                    "checkout_fields": (json!({})),
                    "gift_registry_id": 0
                }),
                "fax": "",
                "firstname": "",
                "id": 0,
                "lastname": "",
                "middlename": "",
                "postcode": "",
                "prefix": "",
                "region": "",
                "region_code": "",
                "region_id": 0,
                "same_as_billing": 0,
                "save_in_address_book": 0,
                "street": (),
                "suffix": "",
                "telephone": "",
                "vat_id": ""
            }),
            "custom_attributes": (json!({})),
            "extension_attributes": json!({}),
            "shipping_address": json!({}),
            "shipping_carrier_code": "",
            "shipping_method_code": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/mine/shipping-information \
  --header 'content-type: application/json' \
  --data '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
echo '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/carts/mine/shipping-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "addressInformation": {\n    "billing_address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "custom_attributes": [\n      {}\n    ],\n    "extension_attributes": {},\n    "shipping_address": {},\n    "shipping_carrier_code": "",\n    "shipping_method_code": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/shipping-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["addressInformation": [
    "billing_address": [
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        [
          "attribute_code": "",
          "value": ""
        ]
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": [
        "checkout_fields": [[]],
        "gift_registry_id": 0
      ],
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    ],
    "custom_attributes": [[]],
    "extension_attributes": [],
    "shipping_address": [],
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/shipping-information")! 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 carts-mine-shipping-methods
{{baseUrl}}/V1/carts/mine/shipping-methods
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/shipping-methods");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/mine/shipping-methods")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/shipping-methods"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/shipping-methods"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/shipping-methods");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/shipping-methods"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/mine/shipping-methods HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/mine/shipping-methods")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/shipping-methods"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/shipping-methods")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/mine/shipping-methods")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/mine/shipping-methods');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/shipping-methods'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/shipping-methods';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/shipping-methods',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/shipping-methods")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/shipping-methods',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/shipping-methods'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/mine/shipping-methods');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/carts/mine/shipping-methods'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/shipping-methods';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/shipping-methods"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/shipping-methods" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/shipping-methods",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/mine/shipping-methods');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/shipping-methods');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/shipping-methods');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/shipping-methods' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/shipping-methods' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/mine/shipping-methods")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/shipping-methods"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/shipping-methods"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/shipping-methods")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/mine/shipping-methods') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/shipping-methods";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/mine/shipping-methods
http GET {{baseUrl}}/V1/carts/mine/shipping-methods
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/shipping-methods
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/shipping-methods")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET carts-mine-totals
{{baseUrl}}/V1/carts/mine/totals
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/totals");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/mine/totals")
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/totals"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/mine/totals"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/mine/totals");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/totals"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/mine/totals HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/mine/totals")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/totals"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/totals")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/mine/totals")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/mine/totals');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/mine/totals'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/totals';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/mine/totals',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/totals")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/totals',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/mine/totals'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/mine/totals');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/mine/totals'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/totals';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/totals"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/mine/totals" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/totals",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/mine/totals');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/totals');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/mine/totals');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/totals' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/totals' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/mine/totals")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/totals"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/totals"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/totals")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/mine/totals') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/totals";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/mine/totals
http GET {{baseUrl}}/V1/carts/mine/totals
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/totals
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/totals")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST carts-mine-totals-information
{{baseUrl}}/V1/carts/mine/totals-information
BODY json

{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/carts/mine/totals-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/carts/mine/totals-information" {:content-type :json
                                                                             :form-params {:addressInformation {:address {:city ""
                                                                                                                          :company ""
                                                                                                                          :country_id ""
                                                                                                                          :custom_attributes [{:attribute_code ""
                                                                                                                                               :value ""}]
                                                                                                                          :customer_address_id 0
                                                                                                                          :customer_id 0
                                                                                                                          :email ""
                                                                                                                          :extension_attributes {:checkout_fields [{}]
                                                                                                                                                 :gift_registry_id 0}
                                                                                                                          :fax ""
                                                                                                                          :firstname ""
                                                                                                                          :id 0
                                                                                                                          :lastname ""
                                                                                                                          :middlename ""
                                                                                                                          :postcode ""
                                                                                                                          :prefix ""
                                                                                                                          :region ""
                                                                                                                          :region_code ""
                                                                                                                          :region_id 0
                                                                                                                          :same_as_billing 0
                                                                                                                          :save_in_address_book 0
                                                                                                                          :street []
                                                                                                                          :suffix ""
                                                                                                                          :telephone ""
                                                                                                                          :vat_id ""}
                                                                                                                :custom_attributes [{}]
                                                                                                                :extension_attributes {}
                                                                                                                :shipping_carrier_code ""
                                                                                                                :shipping_method_code ""}}})
require "http/client"

url = "{{baseUrl}}/V1/carts/mine/totals-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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}}/V1/carts/mine/totals-information"),
    Content = new StringContent("{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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}}/V1/carts/mine/totals-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/mine/totals-information"

	payload := strings.NewReader("{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/carts/mine/totals-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 923

{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/carts/mine/totals-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/mine/totals-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/totals-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/carts/mine/totals-information")
  .header("content-type", "application/json")
  .body("{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  addressInformation: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [
      {}
    ],
    extension_attributes: {},
    shipping_carrier_code: '',
    shipping_method_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}}/V1/carts/mine/totals-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/totals-information',
  headers: {'content-type': 'application/json'},
  data: {
    addressInformation: {
      address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_carrier_code: '',
      shipping_method_code: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/mine/totals-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressInformation":{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"custom_attributes":[{}],"extension_attributes":{},"shipping_carrier_code":"","shipping_method_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}}/V1/carts/mine/totals-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "addressInformation": {\n    "address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "custom_attributes": [\n      {}\n    ],\n    "extension_attributes": {},\n    "shipping_carrier_code": "",\n    "shipping_method_code": ""\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  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/mine/totals-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/mine/totals-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  addressInformation: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [{}],
    extension_attributes: {},
    shipping_carrier_code: '',
    shipping_method_code: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/carts/mine/totals-information',
  headers: {'content-type': 'application/json'},
  body: {
    addressInformation: {
      address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_carrier_code: '',
      shipping_method_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}}/V1/carts/mine/totals-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  addressInformation: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [
      {}
    ],
    extension_attributes: {},
    shipping_carrier_code: '',
    shipping_method_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}}/V1/carts/mine/totals-information',
  headers: {'content-type': 'application/json'},
  data: {
    addressInformation: {
      address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_carrier_code: '',
      shipping_method_code: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/mine/totals-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressInformation":{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"custom_attributes":[{}],"extension_attributes":{},"shipping_carrier_code":"","shipping_method_code":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"addressInformation": @{ @"address": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" }, @"custom_attributes": @[ @{  } ], @"extension_attributes": @{  }, @"shipping_carrier_code": @"", @"shipping_method_code": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/mine/totals-information"]
                                                       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}}/V1/carts/mine/totals-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/mine/totals-information",
  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([
    'addressInformation' => [
        'address' => [
                'city' => '',
                'company' => '',
                'country_id' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_address_id' => 0,
                'customer_id' => 0,
                'email' => '',
                'extension_attributes' => [
                                'checkout_fields' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'gift_registry_id' => 0
                ],
                'fax' => '',
                'firstname' => '',
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'postcode' => '',
                'prefix' => '',
                'region' => '',
                'region_code' => '',
                'region_id' => 0,
                'same_as_billing' => 0,
                'save_in_address_book' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => ''
        ],
        'custom_attributes' => [
                [
                                
                ]
        ],
        'extension_attributes' => [
                
        ],
        'shipping_carrier_code' => '',
        'shipping_method_code' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/carts/mine/totals-information', [
  'body' => '{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/mine/totals-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'addressInformation' => [
    'address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'extension_attributes' => [
        
    ],
    'shipping_carrier_code' => '',
    'shipping_method_code' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'addressInformation' => [
    'address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'extension_attributes' => [
        
    ],
    'shipping_carrier_code' => '',
    'shipping_method_code' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/carts/mine/totals-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/mine/totals-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/mine/totals-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/carts/mine/totals-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/mine/totals-information"

payload = { "addressInformation": {
        "address": {
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": [
                {
                    "attribute_code": "",
                    "value": ""
                }
            ],
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": {
                "checkout_fields": [{}],
                "gift_registry_id": 0
            },
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": [],
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        },
        "custom_attributes": [{}],
        "extension_attributes": {},
        "shipping_carrier_code": "",
        "shipping_method_code": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/mine/totals-information"

payload <- "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/mine/totals-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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/V1/carts/mine/totals-information') do |req|
  req.body = "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/mine/totals-information";

    let payload = json!({"addressInformation": json!({
            "address": json!({
                "city": "",
                "company": "",
                "country_id": "",
                "custom_attributes": (
                    json!({
                        "attribute_code": "",
                        "value": ""
                    })
                ),
                "customer_address_id": 0,
                "customer_id": 0,
                "email": "",
                "extension_attributes": json!({
                    "checkout_fields": (json!({})),
                    "gift_registry_id": 0
                }),
                "fax": "",
                "firstname": "",
                "id": 0,
                "lastname": "",
                "middlename": "",
                "postcode": "",
                "prefix": "",
                "region": "",
                "region_code": "",
                "region_id": 0,
                "same_as_billing": 0,
                "save_in_address_book": 0,
                "street": (),
                "suffix": "",
                "telephone": "",
                "vat_id": ""
            }),
            "custom_attributes": (json!({})),
            "extension_attributes": json!({}),
            "shipping_carrier_code": "",
            "shipping_method_code": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/carts/mine/totals-information \
  --header 'content-type: application/json' \
  --data '{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
echo '{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/carts/mine/totals-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "addressInformation": {\n    "address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "custom_attributes": [\n      {}\n    ],\n    "extension_attributes": {},\n    "shipping_carrier_code": "",\n    "shipping_method_code": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/carts/mine/totals-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["addressInformation": [
    "address": [
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        [
          "attribute_code": "",
          "value": ""
        ]
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": [
        "checkout_fields": [[]],
        "gift_registry_id": 0
      ],
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    ],
    "custom_attributes": [[]],
    "extension_attributes": [],
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/mine/totals-information")! 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}}/V1/carts/search");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/carts/search")
require "http/client"

url = "{{baseUrl}}/V1/carts/search"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/carts/search"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/carts/search");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/carts/search"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/carts/search HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/carts/search")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/carts/search"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/carts/search")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/carts/search")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/carts/search');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/carts/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/carts/search',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/carts/search")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/carts/search',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/search'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/carts/search');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/carts/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/carts/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/carts/search"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/carts/search" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/carts/search",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/carts/search');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/carts/search');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/carts/search');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/carts/search' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/carts/search' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/carts/search")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/carts/search"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/carts/search"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/carts/search")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/carts/search') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/carts/search";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/carts/search
http GET {{baseUrl}}/V1/carts/search
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/carts/search
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/carts/search")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST categories (POST)
{{baseUrl}}/V1/categories
BODY json

{
  "category": {
    "available_sort_by": [],
    "children": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {},
    "id": 0,
    "include_in_menu": false,
    "is_active": false,
    "level": 0,
    "name": "",
    "parent_id": 0,
    "path": "",
    "position": 0,
    "updated_at": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/categories");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/categories" {:content-type :json
                                                          :form-params {:category {:available_sort_by []
                                                                                   :children ""
                                                                                   :created_at ""
                                                                                   :custom_attributes [{:attribute_code ""
                                                                                                        :value ""}]
                                                                                   :extension_attributes {}
                                                                                   :id 0
                                                                                   :include_in_menu false
                                                                                   :is_active false
                                                                                   :level 0
                                                                                   :name ""
                                                                                   :parent_id 0
                                                                                   :path ""
                                                                                   :position 0
                                                                                   :updated_at ""}}})
require "http/client"

url = "{{baseUrl}}/V1/categories"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\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}}/V1/categories"),
    Content = new StringContent("{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\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}}/V1/categories");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/categories"

	payload := strings.NewReader("{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/categories HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 401

{
  "category": {
    "available_sort_by": [],
    "children": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {},
    "id": 0,
    "include_in_menu": false,
    "is_active": false,
    "level": 0,
    "name": "",
    "parent_id": 0,
    "path": "",
    "position": 0,
    "updated_at": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/categories")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/categories"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\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  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/categories")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/categories")
  .header("content-type", "application/json")
  .body("{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  category: {
    available_sort_by: [],
    children: '',
    created_at: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    extension_attributes: {},
    id: 0,
    include_in_menu: false,
    is_active: false,
    level: 0,
    name: '',
    parent_id: 0,
    path: '',
    position: 0,
    updated_at: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/categories');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/categories',
  headers: {'content-type': 'application/json'},
  data: {
    category: {
      available_sort_by: [],
      children: '',
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {},
      id: 0,
      include_in_menu: false,
      is_active: false,
      level: 0,
      name: '',
      parent_id: 0,
      path: '',
      position: 0,
      updated_at: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/categories';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"category":{"available_sort_by":[],"children":"","created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{},"id":0,"include_in_menu":false,"is_active":false,"level":0,"name":"","parent_id":0,"path":"","position":0,"updated_at":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/categories',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "category": {\n    "available_sort_by": [],\n    "children": "",\n    "created_at": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "extension_attributes": {},\n    "id": 0,\n    "include_in_menu": false,\n    "is_active": false,\n    "level": 0,\n    "name": "",\n    "parent_id": 0,\n    "path": "",\n    "position": 0,\n    "updated_at": ""\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  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/categories")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/categories',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  category: {
    available_sort_by: [],
    children: '',
    created_at: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    extension_attributes: {},
    id: 0,
    include_in_menu: false,
    is_active: false,
    level: 0,
    name: '',
    parent_id: 0,
    path: '',
    position: 0,
    updated_at: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/categories',
  headers: {'content-type': 'application/json'},
  body: {
    category: {
      available_sort_by: [],
      children: '',
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {},
      id: 0,
      include_in_menu: false,
      is_active: false,
      level: 0,
      name: '',
      parent_id: 0,
      path: '',
      position: 0,
      updated_at: ''
    }
  },
  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}}/V1/categories');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  category: {
    available_sort_by: [],
    children: '',
    created_at: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    extension_attributes: {},
    id: 0,
    include_in_menu: false,
    is_active: false,
    level: 0,
    name: '',
    parent_id: 0,
    path: '',
    position: 0,
    updated_at: ''
  }
});

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}}/V1/categories',
  headers: {'content-type': 'application/json'},
  data: {
    category: {
      available_sort_by: [],
      children: '',
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {},
      id: 0,
      include_in_menu: false,
      is_active: false,
      level: 0,
      name: '',
      parent_id: 0,
      path: '',
      position: 0,
      updated_at: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/categories';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"category":{"available_sort_by":[],"children":"","created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{},"id":0,"include_in_menu":false,"is_active":false,"level":0,"name":"","parent_id":0,"path":"","position":0,"updated_at":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"category": @{ @"available_sort_by": @[  ], @"children": @"", @"created_at": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"extension_attributes": @{  }, @"id": @0, @"include_in_menu": @NO, @"is_active": @NO, @"level": @0, @"name": @"", @"parent_id": @0, @"path": @"", @"position": @0, @"updated_at": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/categories"]
                                                       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}}/V1/categories" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/categories",
  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([
    'category' => [
        'available_sort_by' => [
                
        ],
        'children' => '',
        'created_at' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'include_in_menu' => null,
        'is_active' => null,
        'level' => 0,
        'name' => '',
        'parent_id' => 0,
        'path' => '',
        'position' => 0,
        'updated_at' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/categories', [
  'body' => '{
  "category": {
    "available_sort_by": [],
    "children": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {},
    "id": 0,
    "include_in_menu": false,
    "is_active": false,
    "level": 0,
    "name": "",
    "parent_id": 0,
    "path": "",
    "position": 0,
    "updated_at": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/categories');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'category' => [
    'available_sort_by' => [
        
    ],
    'children' => '',
    'created_at' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'include_in_menu' => null,
    'is_active' => null,
    'level' => 0,
    'name' => '',
    'parent_id' => 0,
    'path' => '',
    'position' => 0,
    'updated_at' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'category' => [
    'available_sort_by' => [
        
    ],
    'children' => '',
    'created_at' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'include_in_menu' => null,
    'is_active' => null,
    'level' => 0,
    'name' => '',
    'parent_id' => 0,
    'path' => '',
    'position' => 0,
    'updated_at' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/categories');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/categories' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "category": {
    "available_sort_by": [],
    "children": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {},
    "id": 0,
    "include_in_menu": false,
    "is_active": false,
    "level": 0,
    "name": "",
    "parent_id": 0,
    "path": "",
    "position": 0,
    "updated_at": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/categories' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "category": {
    "available_sort_by": [],
    "children": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {},
    "id": 0,
    "include_in_menu": false,
    "is_active": false,
    "level": 0,
    "name": "",
    "parent_id": 0,
    "path": "",
    "position": 0,
    "updated_at": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/categories", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/categories"

payload = { "category": {
        "available_sort_by": [],
        "children": "",
        "created_at": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "extension_attributes": {},
        "id": 0,
        "include_in_menu": False,
        "is_active": False,
        "level": 0,
        "name": "",
        "parent_id": 0,
        "path": "",
        "position": 0,
        "updated_at": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/categories"

payload <- "{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/categories")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\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/V1/categories') do |req|
  req.body = "{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/categories";

    let payload = json!({"category": json!({
            "available_sort_by": (),
            "children": "",
            "created_at": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "extension_attributes": json!({}),
            "id": 0,
            "include_in_menu": false,
            "is_active": false,
            "level": 0,
            "name": "",
            "parent_id": 0,
            "path": "",
            "position": 0,
            "updated_at": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/categories \
  --header 'content-type: application/json' \
  --data '{
  "category": {
    "available_sort_by": [],
    "children": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {},
    "id": 0,
    "include_in_menu": false,
    "is_active": false,
    "level": 0,
    "name": "",
    "parent_id": 0,
    "path": "",
    "position": 0,
    "updated_at": ""
  }
}'
echo '{
  "category": {
    "available_sort_by": [],
    "children": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {},
    "id": 0,
    "include_in_menu": false,
    "is_active": false,
    "level": 0,
    "name": "",
    "parent_id": 0,
    "path": "",
    "position": 0,
    "updated_at": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/categories \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "category": {\n    "available_sort_by": [],\n    "children": "",\n    "created_at": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "extension_attributes": {},\n    "id": 0,\n    "include_in_menu": false,\n    "is_active": false,\n    "level": 0,\n    "name": "",\n    "parent_id": 0,\n    "path": "",\n    "position": 0,\n    "updated_at": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/categories
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["category": [
    "available_sort_by": [],
    "children": "",
    "created_at": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "extension_attributes": [],
    "id": 0,
    "include_in_menu": false,
    "is_active": false,
    "level": 0,
    "name": "",
    "parent_id": 0,
    "path": "",
    "position": 0,
    "updated_at": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/categories")! 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 categories
{{baseUrl}}/V1/categories
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/categories");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/categories")
require "http/client"

url = "{{baseUrl}}/V1/categories"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/categories"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/categories");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/categories"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/categories HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/categories")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/categories"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/categories")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/categories")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/categories');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/categories'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/categories';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/categories',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/categories")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/categories',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/categories'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/categories');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/categories'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/categories';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/categories"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/categories" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/categories",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/categories');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/categories');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/categories');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/categories' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/categories' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/categories")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/categories"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/categories"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/categories")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/categories') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/categories";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/categories
http GET {{baseUrl}}/V1/categories
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/categories
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/categories")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET categories-{categoryId} (GET)
{{baseUrl}}/V1/categories/:categoryId
QUERY PARAMS

categoryId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/categories/:categoryId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/categories/:categoryId")
require "http/client"

url = "{{baseUrl}}/V1/categories/:categoryId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/categories/:categoryId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/categories/:categoryId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/categories/:categoryId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/categories/:categoryId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/categories/:categoryId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/categories/:categoryId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/categories/:categoryId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/categories/:categoryId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/categories/:categoryId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/categories/:categoryId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/categories/:categoryId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/categories/:categoryId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/categories/:categoryId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/categories/:categoryId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/categories/:categoryId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/categories/:categoryId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/categories/:categoryId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/categories/:categoryId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/categories/:categoryId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/categories/:categoryId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/categories/:categoryId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/categories/:categoryId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/categories/:categoryId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/categories/:categoryId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/categories/:categoryId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/categories/:categoryId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/categories/:categoryId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/categories/:categoryId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/categories/:categoryId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/categories/:categoryId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/categories/:categoryId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/categories/:categoryId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/categories/:categoryId
http GET {{baseUrl}}/V1/categories/:categoryId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/categories/:categoryId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/categories/:categoryId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE categories-{categoryId}
{{baseUrl}}/V1/categories/:categoryId
QUERY PARAMS

categoryId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/categories/:categoryId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/categories/:categoryId")
require "http/client"

url = "{{baseUrl}}/V1/categories/:categoryId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/categories/:categoryId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/categories/:categoryId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/categories/:categoryId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/categories/:categoryId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/categories/:categoryId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/categories/:categoryId"))
    .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}}/V1/categories/:categoryId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/categories/:categoryId")
  .asString();
const 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}}/V1/categories/:categoryId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/categories/:categoryId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/categories/:categoryId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/categories/:categoryId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/categories/:categoryId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/categories/:categoryId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/categories/:categoryId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/categories/:categoryId');

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}}/V1/categories/:categoryId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/categories/:categoryId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/categories/:categoryId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/categories/:categoryId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/categories/:categoryId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/categories/:categoryId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/categories/:categoryId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/categories/:categoryId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/categories/:categoryId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/categories/:categoryId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/categories/:categoryId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/categories/:categoryId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/categories/:categoryId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/categories/:categoryId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/categories/:categoryId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/categories/:categoryId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/categories/:categoryId
http DELETE {{baseUrl}}/V1/categories/:categoryId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/categories/:categoryId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/categories/:categoryId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT categories-{categoryId}-move
{{baseUrl}}/V1/categories/:categoryId/move
QUERY PARAMS

categoryId
BODY json

{
  "afterId": 0,
  "parentId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/categories/:categoryId/move");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"afterId\": 0,\n  \"parentId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/categories/:categoryId/move" {:content-type :json
                                                                          :form-params {:afterId 0
                                                                                        :parentId 0}})
require "http/client"

url = "{{baseUrl}}/V1/categories/:categoryId/move"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"afterId\": 0,\n  \"parentId\": 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}}/V1/categories/:categoryId/move"),
    Content = new StringContent("{\n  \"afterId\": 0,\n  \"parentId\": 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}}/V1/categories/:categoryId/move");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"afterId\": 0,\n  \"parentId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/categories/:categoryId/move"

	payload := strings.NewReader("{\n  \"afterId\": 0,\n  \"parentId\": 0\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/categories/:categoryId/move HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 35

{
  "afterId": 0,
  "parentId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/categories/:categoryId/move")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"afterId\": 0,\n  \"parentId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/categories/:categoryId/move"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"afterId\": 0,\n  \"parentId\": 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  \"afterId\": 0,\n  \"parentId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/categories/:categoryId/move")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/categories/:categoryId/move")
  .header("content-type", "application/json")
  .body("{\n  \"afterId\": 0,\n  \"parentId\": 0\n}")
  .asString();
const data = JSON.stringify({
  afterId: 0,
  parentId: 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}}/V1/categories/:categoryId/move');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/categories/:categoryId/move',
  headers: {'content-type': 'application/json'},
  data: {afterId: 0, parentId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/categories/:categoryId/move';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"afterId":0,"parentId":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}}/V1/categories/:categoryId/move',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "afterId": 0,\n  "parentId": 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  \"afterId\": 0,\n  \"parentId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/categories/:categoryId/move")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/categories/:categoryId/move',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({afterId: 0, parentId: 0}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/categories/:categoryId/move',
  headers: {'content-type': 'application/json'},
  body: {afterId: 0, parentId: 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}}/V1/categories/:categoryId/move');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  afterId: 0,
  parentId: 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}}/V1/categories/:categoryId/move',
  headers: {'content-type': 'application/json'},
  data: {afterId: 0, parentId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/categories/:categoryId/move';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"afterId":0,"parentId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"afterId": @0,
                              @"parentId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/categories/:categoryId/move"]
                                                       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}}/V1/categories/:categoryId/move" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"afterId\": 0,\n  \"parentId\": 0\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/categories/:categoryId/move",
  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([
    'afterId' => 0,
    'parentId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/categories/:categoryId/move', [
  'body' => '{
  "afterId": 0,
  "parentId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/categories/:categoryId/move');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'afterId' => 0,
  'parentId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'afterId' => 0,
  'parentId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/categories/:categoryId/move');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/categories/:categoryId/move' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "afterId": 0,
  "parentId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/categories/:categoryId/move' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "afterId": 0,
  "parentId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"afterId\": 0,\n  \"parentId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/categories/:categoryId/move", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/categories/:categoryId/move"

payload = {
    "afterId": 0,
    "parentId": 0
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/categories/:categoryId/move"

payload <- "{\n  \"afterId\": 0,\n  \"parentId\": 0\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/categories/:categoryId/move")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"afterId\": 0,\n  \"parentId\": 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/V1/categories/:categoryId/move') do |req|
  req.body = "{\n  \"afterId\": 0,\n  \"parentId\": 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}}/V1/categories/:categoryId/move";

    let payload = json!({
        "afterId": 0,
        "parentId": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/categories/:categoryId/move \
  --header 'content-type: application/json' \
  --data '{
  "afterId": 0,
  "parentId": 0
}'
echo '{
  "afterId": 0,
  "parentId": 0
}' |  \
  http PUT {{baseUrl}}/V1/categories/:categoryId/move \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "afterId": 0,\n  "parentId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/categories/:categoryId/move
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "afterId": 0,
  "parentId": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/categories/:categoryId/move")! 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 categories-{categoryId}-products (POST)
{{baseUrl}}/V1/categories/:categoryId/products
QUERY PARAMS

categoryId
BODY json

{
  "productLink": {
    "category_id": "",
    "extension_attributes": {},
    "position": 0,
    "sku": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/categories/:categoryId/products");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/categories/:categoryId/products" {:content-type :json
                                                                               :form-params {:productLink {:category_id ""
                                                                                                           :extension_attributes {}
                                                                                                           :position 0
                                                                                                           :sku ""}}})
require "http/client"

url = "{{baseUrl}}/V1/categories/:categoryId/products"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\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}}/V1/categories/:categoryId/products"),
    Content = new StringContent("{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\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}}/V1/categories/:categoryId/products");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/categories/:categoryId/products"

	payload := strings.NewReader("{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/categories/:categoryId/products HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 114

{
  "productLink": {
    "category_id": "",
    "extension_attributes": {},
    "position": 0,
    "sku": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/categories/:categoryId/products")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/categories/:categoryId/products"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\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  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/categories/:categoryId/products")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/categories/:categoryId/products")
  .header("content-type", "application/json")
  .body("{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  productLink: {
    category_id: '',
    extension_attributes: {},
    position: 0,
    sku: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/categories/:categoryId/products');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/categories/:categoryId/products',
  headers: {'content-type': 'application/json'},
  data: {productLink: {category_id: '', extension_attributes: {}, position: 0, sku: ''}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/categories/:categoryId/products';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"productLink":{"category_id":"","extension_attributes":{},"position":0,"sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/categories/:categoryId/products',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "productLink": {\n    "category_id": "",\n    "extension_attributes": {},\n    "position": 0,\n    "sku": ""\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  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/categories/:categoryId/products")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/categories/:categoryId/products',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({productLink: {category_id: '', extension_attributes: {}, position: 0, sku: ''}}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/categories/:categoryId/products',
  headers: {'content-type': 'application/json'},
  body: {productLink: {category_id: '', extension_attributes: {}, position: 0, sku: ''}},
  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}}/V1/categories/:categoryId/products');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  productLink: {
    category_id: '',
    extension_attributes: {},
    position: 0,
    sku: ''
  }
});

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}}/V1/categories/:categoryId/products',
  headers: {'content-type': 'application/json'},
  data: {productLink: {category_id: '', extension_attributes: {}, position: 0, sku: ''}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/categories/:categoryId/products';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"productLink":{"category_id":"","extension_attributes":{},"position":0,"sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"productLink": @{ @"category_id": @"", @"extension_attributes": @{  }, @"position": @0, @"sku": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/categories/:categoryId/products"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/categories/:categoryId/products" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/categories/:categoryId/products",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'productLink' => [
        'category_id' => '',
        'extension_attributes' => [
                
        ],
        'position' => 0,
        'sku' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/categories/:categoryId/products', [
  'body' => '{
  "productLink": {
    "category_id": "",
    "extension_attributes": {},
    "position": 0,
    "sku": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/categories/:categoryId/products');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'productLink' => [
    'category_id' => '',
    'extension_attributes' => [
        
    ],
    'position' => 0,
    'sku' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'productLink' => [
    'category_id' => '',
    'extension_attributes' => [
        
    ],
    'position' => 0,
    'sku' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/categories/:categoryId/products');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/categories/:categoryId/products' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "productLink": {
    "category_id": "",
    "extension_attributes": {},
    "position": 0,
    "sku": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/categories/:categoryId/products' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "productLink": {
    "category_id": "",
    "extension_attributes": {},
    "position": 0,
    "sku": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/categories/:categoryId/products", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/categories/:categoryId/products"

payload = { "productLink": {
        "category_id": "",
        "extension_attributes": {},
        "position": 0,
        "sku": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/categories/:categoryId/products"

payload <- "{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/categories/:categoryId/products")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\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/V1/categories/:categoryId/products') do |req|
  req.body = "{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/categories/:categoryId/products";

    let payload = json!({"productLink": json!({
            "category_id": "",
            "extension_attributes": json!({}),
            "position": 0,
            "sku": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/categories/:categoryId/products \
  --header 'content-type: application/json' \
  --data '{
  "productLink": {
    "category_id": "",
    "extension_attributes": {},
    "position": 0,
    "sku": ""
  }
}'
echo '{
  "productLink": {
    "category_id": "",
    "extension_attributes": {},
    "position": 0,
    "sku": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/categories/:categoryId/products \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "productLink": {\n    "category_id": "",\n    "extension_attributes": {},\n    "position": 0,\n    "sku": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/categories/:categoryId/products
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["productLink": [
    "category_id": "",
    "extension_attributes": [],
    "position": 0,
    "sku": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/categories/:categoryId/products")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT categories-{categoryId}-products (PUT)
{{baseUrl}}/V1/categories/:categoryId/products
QUERY PARAMS

categoryId
BODY json

{
  "productLink": {
    "category_id": "",
    "extension_attributes": {},
    "position": 0,
    "sku": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/categories/:categoryId/products");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/categories/:categoryId/products" {:content-type :json
                                                                              :form-params {:productLink {:category_id ""
                                                                                                          :extension_attributes {}
                                                                                                          :position 0
                                                                                                          :sku ""}}})
require "http/client"

url = "{{baseUrl}}/V1/categories/:categoryId/products"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\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}}/V1/categories/:categoryId/products"),
    Content = new StringContent("{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\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}}/V1/categories/:categoryId/products");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/categories/:categoryId/products"

	payload := strings.NewReader("{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/categories/:categoryId/products HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 114

{
  "productLink": {
    "category_id": "",
    "extension_attributes": {},
    "position": 0,
    "sku": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/categories/:categoryId/products")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/categories/:categoryId/products"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\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  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/categories/:categoryId/products")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/categories/:categoryId/products")
  .header("content-type", "application/json")
  .body("{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  productLink: {
    category_id: '',
    extension_attributes: {},
    position: 0,
    sku: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/categories/:categoryId/products');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/categories/:categoryId/products',
  headers: {'content-type': 'application/json'},
  data: {productLink: {category_id: '', extension_attributes: {}, position: 0, sku: ''}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/categories/:categoryId/products';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"productLink":{"category_id":"","extension_attributes":{},"position":0,"sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/categories/:categoryId/products',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "productLink": {\n    "category_id": "",\n    "extension_attributes": {},\n    "position": 0,\n    "sku": ""\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  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/categories/:categoryId/products")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/categories/:categoryId/products',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({productLink: {category_id: '', extension_attributes: {}, position: 0, sku: ''}}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/categories/:categoryId/products',
  headers: {'content-type': 'application/json'},
  body: {productLink: {category_id: '', extension_attributes: {}, position: 0, sku: ''}},
  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}}/V1/categories/:categoryId/products');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  productLink: {
    category_id: '',
    extension_attributes: {},
    position: 0,
    sku: ''
  }
});

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}}/V1/categories/:categoryId/products',
  headers: {'content-type': 'application/json'},
  data: {productLink: {category_id: '', extension_attributes: {}, position: 0, sku: ''}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/categories/:categoryId/products';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"productLink":{"category_id":"","extension_attributes":{},"position":0,"sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"productLink": @{ @"category_id": @"", @"extension_attributes": @{  }, @"position": @0, @"sku": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/categories/:categoryId/products"]
                                                       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}}/V1/categories/:categoryId/products" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/categories/:categoryId/products",
  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([
    'productLink' => [
        'category_id' => '',
        'extension_attributes' => [
                
        ],
        'position' => 0,
        'sku' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/categories/:categoryId/products', [
  'body' => '{
  "productLink": {
    "category_id": "",
    "extension_attributes": {},
    "position": 0,
    "sku": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/categories/:categoryId/products');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'productLink' => [
    'category_id' => '',
    'extension_attributes' => [
        
    ],
    'position' => 0,
    'sku' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'productLink' => [
    'category_id' => '',
    'extension_attributes' => [
        
    ],
    'position' => 0,
    'sku' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/categories/:categoryId/products');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/categories/:categoryId/products' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "productLink": {
    "category_id": "",
    "extension_attributes": {},
    "position": 0,
    "sku": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/categories/:categoryId/products' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "productLink": {
    "category_id": "",
    "extension_attributes": {},
    "position": 0,
    "sku": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/categories/:categoryId/products", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/categories/:categoryId/products"

payload = { "productLink": {
        "category_id": "",
        "extension_attributes": {},
        "position": 0,
        "sku": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/categories/:categoryId/products"

payload <- "{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/categories/:categoryId/products")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\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/V1/categories/:categoryId/products') do |req|
  req.body = "{\n  \"productLink\": {\n    \"category_id\": \"\",\n    \"extension_attributes\": {},\n    \"position\": 0,\n    \"sku\": \"\"\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}}/V1/categories/:categoryId/products";

    let payload = json!({"productLink": json!({
            "category_id": "",
            "extension_attributes": json!({}),
            "position": 0,
            "sku": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/categories/:categoryId/products \
  --header 'content-type: application/json' \
  --data '{
  "productLink": {
    "category_id": "",
    "extension_attributes": {},
    "position": 0,
    "sku": ""
  }
}'
echo '{
  "productLink": {
    "category_id": "",
    "extension_attributes": {},
    "position": 0,
    "sku": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/categories/:categoryId/products \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "productLink": {\n    "category_id": "",\n    "extension_attributes": {},\n    "position": 0,\n    "sku": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/categories/:categoryId/products
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["productLink": [
    "category_id": "",
    "extension_attributes": [],
    "position": 0,
    "sku": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/categories/:categoryId/products")! 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 categories-{categoryId}-products
{{baseUrl}}/V1/categories/:categoryId/products
QUERY PARAMS

categoryId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/categories/:categoryId/products");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/categories/:categoryId/products")
require "http/client"

url = "{{baseUrl}}/V1/categories/:categoryId/products"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/categories/:categoryId/products"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/categories/:categoryId/products");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/categories/:categoryId/products"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/categories/:categoryId/products HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/categories/:categoryId/products")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/categories/:categoryId/products"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/categories/:categoryId/products")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/categories/:categoryId/products")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/categories/:categoryId/products');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/categories/:categoryId/products'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/categories/:categoryId/products';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/categories/:categoryId/products',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/categories/:categoryId/products")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/categories/:categoryId/products',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/categories/:categoryId/products'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/categories/:categoryId/products');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/categories/:categoryId/products'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/categories/:categoryId/products';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/categories/:categoryId/products"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/categories/:categoryId/products" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/categories/:categoryId/products",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/categories/:categoryId/products');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/categories/:categoryId/products');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/categories/:categoryId/products');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/categories/:categoryId/products' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/categories/:categoryId/products' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/categories/:categoryId/products")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/categories/:categoryId/products"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/categories/:categoryId/products"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/categories/:categoryId/products")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/categories/:categoryId/products') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/categories/:categoryId/products";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/categories/:categoryId/products
http GET {{baseUrl}}/V1/categories/:categoryId/products
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/categories/:categoryId/products
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/categories/:categoryId/products")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE categories-{categoryId}-products-{sku}
{{baseUrl}}/V1/categories/:categoryId/products/:sku
QUERY PARAMS

categoryId
sku
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/categories/:categoryId/products/:sku");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/categories/:categoryId/products/:sku")
require "http/client"

url = "{{baseUrl}}/V1/categories/:categoryId/products/:sku"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/categories/:categoryId/products/:sku"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/categories/:categoryId/products/:sku");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/categories/:categoryId/products/:sku"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/categories/:categoryId/products/:sku HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/categories/:categoryId/products/:sku")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/categories/:categoryId/products/:sku"))
    .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}}/V1/categories/:categoryId/products/:sku")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/categories/:categoryId/products/:sku")
  .asString();
const 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}}/V1/categories/:categoryId/products/:sku');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/categories/:categoryId/products/:sku'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/categories/:categoryId/products/:sku';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/categories/:categoryId/products/:sku',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/categories/:categoryId/products/:sku")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/categories/:categoryId/products/:sku',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/categories/:categoryId/products/:sku'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/categories/:categoryId/products/:sku');

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}}/V1/categories/:categoryId/products/:sku'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/categories/:categoryId/products/:sku';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/categories/:categoryId/products/:sku"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/categories/:categoryId/products/:sku" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/categories/:categoryId/products/:sku",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/categories/:categoryId/products/:sku');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/categories/:categoryId/products/:sku');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/categories/:categoryId/products/:sku');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/categories/:categoryId/products/:sku' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/categories/:categoryId/products/:sku' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/categories/:categoryId/products/:sku")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/categories/:categoryId/products/:sku"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/categories/:categoryId/products/:sku"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/categories/:categoryId/products/:sku")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/categories/:categoryId/products/:sku') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/categories/:categoryId/products/:sku";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/categories/:categoryId/products/:sku
http DELETE {{baseUrl}}/V1/categories/:categoryId/products/:sku
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/categories/:categoryId/products/:sku
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/categories/:categoryId/products/:sku")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT categories-{id}
{{baseUrl}}/V1/categories/:id
QUERY PARAMS

id
BODY json

{
  "category": {
    "available_sort_by": [],
    "children": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {},
    "id": 0,
    "include_in_menu": false,
    "is_active": false,
    "level": 0,
    "name": "",
    "parent_id": 0,
    "path": "",
    "position": 0,
    "updated_at": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/categories/:id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/categories/:id" {:content-type :json
                                                             :form-params {:category {:available_sort_by []
                                                                                      :children ""
                                                                                      :created_at ""
                                                                                      :custom_attributes [{:attribute_code ""
                                                                                                           :value ""}]
                                                                                      :extension_attributes {}
                                                                                      :id 0
                                                                                      :include_in_menu false
                                                                                      :is_active false
                                                                                      :level 0
                                                                                      :name ""
                                                                                      :parent_id 0
                                                                                      :path ""
                                                                                      :position 0
                                                                                      :updated_at ""}}})
require "http/client"

url = "{{baseUrl}}/V1/categories/:id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\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}}/V1/categories/:id"),
    Content = new StringContent("{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\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}}/V1/categories/:id");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/categories/:id"

	payload := strings.NewReader("{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/categories/:id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 401

{
  "category": {
    "available_sort_by": [],
    "children": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {},
    "id": 0,
    "include_in_menu": false,
    "is_active": false,
    "level": 0,
    "name": "",
    "parent_id": 0,
    "path": "",
    "position": 0,
    "updated_at": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/categories/:id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/categories/:id"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\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  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/categories/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/categories/:id")
  .header("content-type", "application/json")
  .body("{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  category: {
    available_sort_by: [],
    children: '',
    created_at: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    extension_attributes: {},
    id: 0,
    include_in_menu: false,
    is_active: false,
    level: 0,
    name: '',
    parent_id: 0,
    path: '',
    position: 0,
    updated_at: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/categories/:id');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/categories/:id',
  headers: {'content-type': 'application/json'},
  data: {
    category: {
      available_sort_by: [],
      children: '',
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {},
      id: 0,
      include_in_menu: false,
      is_active: false,
      level: 0,
      name: '',
      parent_id: 0,
      path: '',
      position: 0,
      updated_at: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/categories/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"category":{"available_sort_by":[],"children":"","created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{},"id":0,"include_in_menu":false,"is_active":false,"level":0,"name":"","parent_id":0,"path":"","position":0,"updated_at":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/categories/:id',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "category": {\n    "available_sort_by": [],\n    "children": "",\n    "created_at": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "extension_attributes": {},\n    "id": 0,\n    "include_in_menu": false,\n    "is_active": false,\n    "level": 0,\n    "name": "",\n    "parent_id": 0,\n    "path": "",\n    "position": 0,\n    "updated_at": ""\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  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/categories/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/categories/:id',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  category: {
    available_sort_by: [],
    children: '',
    created_at: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    extension_attributes: {},
    id: 0,
    include_in_menu: false,
    is_active: false,
    level: 0,
    name: '',
    parent_id: 0,
    path: '',
    position: 0,
    updated_at: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/categories/:id',
  headers: {'content-type': 'application/json'},
  body: {
    category: {
      available_sort_by: [],
      children: '',
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {},
      id: 0,
      include_in_menu: false,
      is_active: false,
      level: 0,
      name: '',
      parent_id: 0,
      path: '',
      position: 0,
      updated_at: ''
    }
  },
  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}}/V1/categories/:id');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  category: {
    available_sort_by: [],
    children: '',
    created_at: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    extension_attributes: {},
    id: 0,
    include_in_menu: false,
    is_active: false,
    level: 0,
    name: '',
    parent_id: 0,
    path: '',
    position: 0,
    updated_at: ''
  }
});

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}}/V1/categories/:id',
  headers: {'content-type': 'application/json'},
  data: {
    category: {
      available_sort_by: [],
      children: '',
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {},
      id: 0,
      include_in_menu: false,
      is_active: false,
      level: 0,
      name: '',
      parent_id: 0,
      path: '',
      position: 0,
      updated_at: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/categories/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"category":{"available_sort_by":[],"children":"","created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{},"id":0,"include_in_menu":false,"is_active":false,"level":0,"name":"","parent_id":0,"path":"","position":0,"updated_at":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"category": @{ @"available_sort_by": @[  ], @"children": @"", @"created_at": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"extension_attributes": @{  }, @"id": @0, @"include_in_menu": @NO, @"is_active": @NO, @"level": @0, @"name": @"", @"parent_id": @0, @"path": @"", @"position": @0, @"updated_at": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/categories/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/categories/:id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/categories/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'category' => [
        'available_sort_by' => [
                
        ],
        'children' => '',
        'created_at' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'include_in_menu' => null,
        'is_active' => null,
        'level' => 0,
        'name' => '',
        'parent_id' => 0,
        'path' => '',
        'position' => 0,
        'updated_at' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/categories/:id', [
  'body' => '{
  "category": {
    "available_sort_by": [],
    "children": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {},
    "id": 0,
    "include_in_menu": false,
    "is_active": false,
    "level": 0,
    "name": "",
    "parent_id": 0,
    "path": "",
    "position": 0,
    "updated_at": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/categories/:id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'category' => [
    'available_sort_by' => [
        
    ],
    'children' => '',
    'created_at' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'include_in_menu' => null,
    'is_active' => null,
    'level' => 0,
    'name' => '',
    'parent_id' => 0,
    'path' => '',
    'position' => 0,
    'updated_at' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'category' => [
    'available_sort_by' => [
        
    ],
    'children' => '',
    'created_at' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'include_in_menu' => null,
    'is_active' => null,
    'level' => 0,
    'name' => '',
    'parent_id' => 0,
    'path' => '',
    'position' => 0,
    'updated_at' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/categories/:id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/categories/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "category": {
    "available_sort_by": [],
    "children": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {},
    "id": 0,
    "include_in_menu": false,
    "is_active": false,
    "level": 0,
    "name": "",
    "parent_id": 0,
    "path": "",
    "position": 0,
    "updated_at": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/categories/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "category": {
    "available_sort_by": [],
    "children": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {},
    "id": 0,
    "include_in_menu": false,
    "is_active": false,
    "level": 0,
    "name": "",
    "parent_id": 0,
    "path": "",
    "position": 0,
    "updated_at": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/categories/:id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/categories/:id"

payload = { "category": {
        "available_sort_by": [],
        "children": "",
        "created_at": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "extension_attributes": {},
        "id": 0,
        "include_in_menu": False,
        "is_active": False,
        "level": 0,
        "name": "",
        "parent_id": 0,
        "path": "",
        "position": 0,
        "updated_at": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/categories/:id"

payload <- "{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/categories/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\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/V1/categories/:id') do |req|
  req.body = "{\n  \"category\": {\n    \"available_sort_by\": [],\n    \"children\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"include_in_menu\": false,\n    \"is_active\": false,\n    \"level\": 0,\n    \"name\": \"\",\n    \"parent_id\": 0,\n    \"path\": \"\",\n    \"position\": 0,\n    \"updated_at\": \"\"\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}}/V1/categories/:id";

    let payload = json!({"category": json!({
            "available_sort_by": (),
            "children": "",
            "created_at": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "extension_attributes": json!({}),
            "id": 0,
            "include_in_menu": false,
            "is_active": false,
            "level": 0,
            "name": "",
            "parent_id": 0,
            "path": "",
            "position": 0,
            "updated_at": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/categories/:id \
  --header 'content-type: application/json' \
  --data '{
  "category": {
    "available_sort_by": [],
    "children": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {},
    "id": 0,
    "include_in_menu": false,
    "is_active": false,
    "level": 0,
    "name": "",
    "parent_id": 0,
    "path": "",
    "position": 0,
    "updated_at": ""
  }
}'
echo '{
  "category": {
    "available_sort_by": [],
    "children": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {},
    "id": 0,
    "include_in_menu": false,
    "is_active": false,
    "level": 0,
    "name": "",
    "parent_id": 0,
    "path": "",
    "position": 0,
    "updated_at": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/categories/:id \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "category": {\n    "available_sort_by": [],\n    "children": "",\n    "created_at": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "extension_attributes": {},\n    "id": 0,\n    "include_in_menu": false,\n    "is_active": false,\n    "level": 0,\n    "name": "",\n    "parent_id": 0,\n    "path": "",\n    "position": 0,\n    "updated_at": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/categories/:id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["category": [
    "available_sort_by": [],
    "children": "",
    "created_at": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "extension_attributes": [],
    "id": 0,
    "include_in_menu": false,
    "is_active": false,
    "level": 0,
    "name": "",
    "parent_id": 0,
    "path": "",
    "position": 0,
    "updated_at": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/categories/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET categories-attributes
{{baseUrl}}/V1/categories/attributes
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/categories/attributes");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/categories/attributes")
require "http/client"

url = "{{baseUrl}}/V1/categories/attributes"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/categories/attributes"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/categories/attributes");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/categories/attributes"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/categories/attributes HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/categories/attributes")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/categories/attributes"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/categories/attributes")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/categories/attributes")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/categories/attributes');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/categories/attributes'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/categories/attributes';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/categories/attributes',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/categories/attributes")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/categories/attributes',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/categories/attributes'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/categories/attributes');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/categories/attributes'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/categories/attributes';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/categories/attributes"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/categories/attributes" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/categories/attributes",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/categories/attributes');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/categories/attributes');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/categories/attributes');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/categories/attributes' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/categories/attributes' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/categories/attributes")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/categories/attributes"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/categories/attributes"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/categories/attributes")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/categories/attributes') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/categories/attributes";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/categories/attributes
http GET {{baseUrl}}/V1/categories/attributes
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/categories/attributes
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/categories/attributes")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET categories-attributes-{attributeCode}
{{baseUrl}}/V1/categories/attributes/:attributeCode
QUERY PARAMS

attributeCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/categories/attributes/:attributeCode");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/categories/attributes/:attributeCode")
require "http/client"

url = "{{baseUrl}}/V1/categories/attributes/:attributeCode"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/categories/attributes/:attributeCode"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/categories/attributes/:attributeCode");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/categories/attributes/:attributeCode"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/categories/attributes/:attributeCode HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/categories/attributes/:attributeCode")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/categories/attributes/:attributeCode"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/categories/attributes/:attributeCode")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/categories/attributes/:attributeCode")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/categories/attributes/:attributeCode');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/categories/attributes/:attributeCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/categories/attributes/:attributeCode';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/categories/attributes/:attributeCode',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/categories/attributes/:attributeCode")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/categories/attributes/:attributeCode',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/categories/attributes/:attributeCode'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/categories/attributes/:attributeCode');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/categories/attributes/:attributeCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/categories/attributes/:attributeCode';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/categories/attributes/:attributeCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/categories/attributes/:attributeCode" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/categories/attributes/:attributeCode",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/categories/attributes/:attributeCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/categories/attributes/:attributeCode');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/categories/attributes/:attributeCode');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/categories/attributes/:attributeCode' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/categories/attributes/:attributeCode' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/categories/attributes/:attributeCode")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/categories/attributes/:attributeCode"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/categories/attributes/:attributeCode"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/categories/attributes/:attributeCode")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/categories/attributes/:attributeCode') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/categories/attributes/:attributeCode";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/categories/attributes/:attributeCode
http GET {{baseUrl}}/V1/categories/attributes/:attributeCode
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/categories/attributes/:attributeCode
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/categories/attributes/:attributeCode")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET categories-attributes-{attributeCode}-options
{{baseUrl}}/V1/categories/attributes/:attributeCode/options
QUERY PARAMS

attributeCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/categories/attributes/:attributeCode/options");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/categories/attributes/:attributeCode/options")
require "http/client"

url = "{{baseUrl}}/V1/categories/attributes/:attributeCode/options"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/categories/attributes/:attributeCode/options"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/categories/attributes/:attributeCode/options");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/categories/attributes/:attributeCode/options"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/categories/attributes/:attributeCode/options HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/categories/attributes/:attributeCode/options")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/categories/attributes/:attributeCode/options"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/categories/attributes/:attributeCode/options")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/categories/attributes/:attributeCode/options")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/categories/attributes/:attributeCode/options');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/categories/attributes/:attributeCode/options'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/categories/attributes/:attributeCode/options';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/categories/attributes/:attributeCode/options',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/categories/attributes/:attributeCode/options")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/categories/attributes/:attributeCode/options',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/categories/attributes/:attributeCode/options'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/categories/attributes/:attributeCode/options');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/categories/attributes/:attributeCode/options'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/categories/attributes/:attributeCode/options';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/categories/attributes/:attributeCode/options"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/categories/attributes/:attributeCode/options" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/categories/attributes/:attributeCode/options",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/categories/attributes/:attributeCode/options');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/categories/attributes/:attributeCode/options');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/categories/attributes/:attributeCode/options');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/categories/attributes/:attributeCode/options' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/categories/attributes/:attributeCode/options' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/categories/attributes/:attributeCode/options")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/categories/attributes/:attributeCode/options"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/categories/attributes/:attributeCode/options"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/categories/attributes/:attributeCode/options")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/categories/attributes/:attributeCode/options') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/categories/attributes/:attributeCode/options";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/categories/attributes/:attributeCode/options
http GET {{baseUrl}}/V1/categories/attributes/:attributeCode/options
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/categories/attributes/:attributeCode/options
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/categories/attributes/:attributeCode/options")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET categories-list
{{baseUrl}}/V1/categories/list
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/categories/list");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/categories/list")
require "http/client"

url = "{{baseUrl}}/V1/categories/list"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/categories/list"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/categories/list");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/categories/list"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/categories/list HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/categories/list")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/categories/list"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/categories/list")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/categories/list")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/categories/list');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/categories/list'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/categories/list';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/categories/list',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/categories/list")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/categories/list',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/categories/list'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/categories/list');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/categories/list'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/categories/list';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/categories/list"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/categories/list" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/categories/list",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/categories/list');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/categories/list');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/categories/list');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/categories/list' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/categories/list' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/categories/list")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/categories/list"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/categories/list"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/categories/list")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/categories/list') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/categories/list";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/categories/list
http GET {{baseUrl}}/V1/categories/list
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/categories/list
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/categories/list")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST cmsBlock
{{baseUrl}}/V1/cmsBlock
BODY json

{
  "block": {
    "active": false,
    "content": "",
    "creation_time": "",
    "id": 0,
    "identifier": "",
    "title": "",
    "update_time": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/cmsBlock");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/cmsBlock" {:content-type :json
                                                        :form-params {:block {:active false
                                                                              :content ""
                                                                              :creation_time ""
                                                                              :id 0
                                                                              :identifier ""
                                                                              :title ""
                                                                              :update_time ""}}})
require "http/client"

url = "{{baseUrl}}/V1/cmsBlock"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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}}/V1/cmsBlock"),
    Content = new StringContent("{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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}}/V1/cmsBlock");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/cmsBlock"

	payload := strings.NewReader("{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/cmsBlock HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 159

{
  "block": {
    "active": false,
    "content": "",
    "creation_time": "",
    "id": 0,
    "identifier": "",
    "title": "",
    "update_time": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/cmsBlock")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/cmsBlock"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/cmsBlock")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/cmsBlock")
  .header("content-type", "application/json")
  .body("{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  block: {
    active: false,
    content: '',
    creation_time: '',
    id: 0,
    identifier: '',
    title: '',
    update_time: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/cmsBlock');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/cmsBlock',
  headers: {'content-type': 'application/json'},
  data: {
    block: {
      active: false,
      content: '',
      creation_time: '',
      id: 0,
      identifier: '',
      title: '',
      update_time: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/cmsBlock';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"block":{"active":false,"content":"","creation_time":"","id":0,"identifier":"","title":"","update_time":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/cmsBlock',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "block": {\n    "active": false,\n    "content": "",\n    "creation_time": "",\n    "id": 0,\n    "identifier": "",\n    "title": "",\n    "update_time": ""\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  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/cmsBlock")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/cmsBlock',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  block: {
    active: false,
    content: '',
    creation_time: '',
    id: 0,
    identifier: '',
    title: '',
    update_time: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/cmsBlock',
  headers: {'content-type': 'application/json'},
  body: {
    block: {
      active: false,
      content: '',
      creation_time: '',
      id: 0,
      identifier: '',
      title: '',
      update_time: ''
    }
  },
  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}}/V1/cmsBlock');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  block: {
    active: false,
    content: '',
    creation_time: '',
    id: 0,
    identifier: '',
    title: '',
    update_time: ''
  }
});

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}}/V1/cmsBlock',
  headers: {'content-type': 'application/json'},
  data: {
    block: {
      active: false,
      content: '',
      creation_time: '',
      id: 0,
      identifier: '',
      title: '',
      update_time: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/cmsBlock';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"block":{"active":false,"content":"","creation_time":"","id":0,"identifier":"","title":"","update_time":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"block": @{ @"active": @NO, @"content": @"", @"creation_time": @"", @"id": @0, @"identifier": @"", @"title": @"", @"update_time": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/cmsBlock"]
                                                       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}}/V1/cmsBlock" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/cmsBlock",
  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([
    'block' => [
        'active' => null,
        'content' => '',
        'creation_time' => '',
        'id' => 0,
        'identifier' => '',
        'title' => '',
        'update_time' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/cmsBlock', [
  'body' => '{
  "block": {
    "active": false,
    "content": "",
    "creation_time": "",
    "id": 0,
    "identifier": "",
    "title": "",
    "update_time": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/cmsBlock');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'block' => [
    'active' => null,
    'content' => '',
    'creation_time' => '',
    'id' => 0,
    'identifier' => '',
    'title' => '',
    'update_time' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'block' => [
    'active' => null,
    'content' => '',
    'creation_time' => '',
    'id' => 0,
    'identifier' => '',
    'title' => '',
    'update_time' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/cmsBlock');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/cmsBlock' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "block": {
    "active": false,
    "content": "",
    "creation_time": "",
    "id": 0,
    "identifier": "",
    "title": "",
    "update_time": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/cmsBlock' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "block": {
    "active": false,
    "content": "",
    "creation_time": "",
    "id": 0,
    "identifier": "",
    "title": "",
    "update_time": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/cmsBlock", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/cmsBlock"

payload = { "block": {
        "active": False,
        "content": "",
        "creation_time": "",
        "id": 0,
        "identifier": "",
        "title": "",
        "update_time": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/cmsBlock"

payload <- "{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/cmsBlock")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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/V1/cmsBlock') do |req|
  req.body = "{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/cmsBlock";

    let payload = json!({"block": json!({
            "active": false,
            "content": "",
            "creation_time": "",
            "id": 0,
            "identifier": "",
            "title": "",
            "update_time": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/cmsBlock \
  --header 'content-type: application/json' \
  --data '{
  "block": {
    "active": false,
    "content": "",
    "creation_time": "",
    "id": 0,
    "identifier": "",
    "title": "",
    "update_time": ""
  }
}'
echo '{
  "block": {
    "active": false,
    "content": "",
    "creation_time": "",
    "id": 0,
    "identifier": "",
    "title": "",
    "update_time": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/cmsBlock \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "block": {\n    "active": false,\n    "content": "",\n    "creation_time": "",\n    "id": 0,\n    "identifier": "",\n    "title": "",\n    "update_time": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/cmsBlock
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["block": [
    "active": false,
    "content": "",
    "creation_time": "",
    "id": 0,
    "identifier": "",
    "title": "",
    "update_time": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/cmsBlock")! 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 cmsBlock-{blockId} (GET)
{{baseUrl}}/V1/cmsBlock/:blockId
QUERY PARAMS

blockId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/cmsBlock/:blockId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/cmsBlock/:blockId")
require "http/client"

url = "{{baseUrl}}/V1/cmsBlock/:blockId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/cmsBlock/:blockId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/cmsBlock/:blockId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/cmsBlock/:blockId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/cmsBlock/:blockId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/cmsBlock/:blockId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/cmsBlock/:blockId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/cmsBlock/:blockId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/cmsBlock/:blockId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/cmsBlock/:blockId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/cmsBlock/:blockId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/cmsBlock/:blockId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/cmsBlock/:blockId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/cmsBlock/:blockId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/cmsBlock/:blockId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/cmsBlock/:blockId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/cmsBlock/:blockId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/cmsBlock/:blockId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/cmsBlock/:blockId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/cmsBlock/:blockId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/cmsBlock/:blockId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/cmsBlock/:blockId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/cmsBlock/:blockId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/cmsBlock/:blockId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/cmsBlock/:blockId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/cmsBlock/:blockId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/cmsBlock/:blockId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/cmsBlock/:blockId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/cmsBlock/:blockId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/cmsBlock/:blockId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/cmsBlock/:blockId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/cmsBlock/:blockId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/cmsBlock/:blockId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/cmsBlock/:blockId
http GET {{baseUrl}}/V1/cmsBlock/:blockId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/cmsBlock/:blockId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/cmsBlock/:blockId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE cmsBlock-{blockId}
{{baseUrl}}/V1/cmsBlock/:blockId
QUERY PARAMS

blockId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/cmsBlock/:blockId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/cmsBlock/:blockId")
require "http/client"

url = "{{baseUrl}}/V1/cmsBlock/:blockId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/cmsBlock/:blockId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/cmsBlock/:blockId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/cmsBlock/:blockId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/cmsBlock/:blockId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/cmsBlock/:blockId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/cmsBlock/:blockId"))
    .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}}/V1/cmsBlock/:blockId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/cmsBlock/:blockId")
  .asString();
const 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}}/V1/cmsBlock/:blockId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/cmsBlock/:blockId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/cmsBlock/:blockId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/cmsBlock/:blockId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/cmsBlock/:blockId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/cmsBlock/:blockId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/cmsBlock/:blockId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/cmsBlock/:blockId');

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}}/V1/cmsBlock/:blockId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/cmsBlock/:blockId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/cmsBlock/:blockId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/cmsBlock/:blockId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/cmsBlock/:blockId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/cmsBlock/:blockId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/cmsBlock/:blockId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/cmsBlock/:blockId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/cmsBlock/:blockId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/cmsBlock/:blockId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/cmsBlock/:blockId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/cmsBlock/:blockId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/cmsBlock/:blockId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/cmsBlock/:blockId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/cmsBlock/:blockId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/cmsBlock/:blockId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/cmsBlock/:blockId
http DELETE {{baseUrl}}/V1/cmsBlock/:blockId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/cmsBlock/:blockId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/cmsBlock/:blockId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT cmsBlock-{id}
{{baseUrl}}/V1/cmsBlock/:id
QUERY PARAMS

id
BODY json

{
  "block": {
    "active": false,
    "content": "",
    "creation_time": "",
    "id": 0,
    "identifier": "",
    "title": "",
    "update_time": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/cmsBlock/:id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/cmsBlock/:id" {:content-type :json
                                                           :form-params {:block {:active false
                                                                                 :content ""
                                                                                 :creation_time ""
                                                                                 :id 0
                                                                                 :identifier ""
                                                                                 :title ""
                                                                                 :update_time ""}}})
require "http/client"

url = "{{baseUrl}}/V1/cmsBlock/:id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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}}/V1/cmsBlock/:id"),
    Content = new StringContent("{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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}}/V1/cmsBlock/:id");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/cmsBlock/:id"

	payload := strings.NewReader("{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/cmsBlock/:id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 159

{
  "block": {
    "active": false,
    "content": "",
    "creation_time": "",
    "id": 0,
    "identifier": "",
    "title": "",
    "update_time": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/cmsBlock/:id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/cmsBlock/:id"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/cmsBlock/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/cmsBlock/:id")
  .header("content-type", "application/json")
  .body("{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  block: {
    active: false,
    content: '',
    creation_time: '',
    id: 0,
    identifier: '',
    title: '',
    update_time: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/cmsBlock/:id');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/cmsBlock/:id',
  headers: {'content-type': 'application/json'},
  data: {
    block: {
      active: false,
      content: '',
      creation_time: '',
      id: 0,
      identifier: '',
      title: '',
      update_time: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/cmsBlock/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"block":{"active":false,"content":"","creation_time":"","id":0,"identifier":"","title":"","update_time":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/cmsBlock/:id',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "block": {\n    "active": false,\n    "content": "",\n    "creation_time": "",\n    "id": 0,\n    "identifier": "",\n    "title": "",\n    "update_time": ""\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  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/cmsBlock/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/cmsBlock/:id',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  block: {
    active: false,
    content: '',
    creation_time: '',
    id: 0,
    identifier: '',
    title: '',
    update_time: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/cmsBlock/:id',
  headers: {'content-type': 'application/json'},
  body: {
    block: {
      active: false,
      content: '',
      creation_time: '',
      id: 0,
      identifier: '',
      title: '',
      update_time: ''
    }
  },
  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}}/V1/cmsBlock/:id');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  block: {
    active: false,
    content: '',
    creation_time: '',
    id: 0,
    identifier: '',
    title: '',
    update_time: ''
  }
});

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}}/V1/cmsBlock/:id',
  headers: {'content-type': 'application/json'},
  data: {
    block: {
      active: false,
      content: '',
      creation_time: '',
      id: 0,
      identifier: '',
      title: '',
      update_time: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/cmsBlock/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"block":{"active":false,"content":"","creation_time":"","id":0,"identifier":"","title":"","update_time":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"block": @{ @"active": @NO, @"content": @"", @"creation_time": @"", @"id": @0, @"identifier": @"", @"title": @"", @"update_time": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/cmsBlock/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/cmsBlock/:id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/cmsBlock/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'block' => [
        'active' => null,
        'content' => '',
        'creation_time' => '',
        'id' => 0,
        'identifier' => '',
        'title' => '',
        'update_time' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/cmsBlock/:id', [
  'body' => '{
  "block": {
    "active": false,
    "content": "",
    "creation_time": "",
    "id": 0,
    "identifier": "",
    "title": "",
    "update_time": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/cmsBlock/:id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'block' => [
    'active' => null,
    'content' => '',
    'creation_time' => '',
    'id' => 0,
    'identifier' => '',
    'title' => '',
    'update_time' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'block' => [
    'active' => null,
    'content' => '',
    'creation_time' => '',
    'id' => 0,
    'identifier' => '',
    'title' => '',
    'update_time' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/cmsBlock/:id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/cmsBlock/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "block": {
    "active": false,
    "content": "",
    "creation_time": "",
    "id": 0,
    "identifier": "",
    "title": "",
    "update_time": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/cmsBlock/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "block": {
    "active": false,
    "content": "",
    "creation_time": "",
    "id": 0,
    "identifier": "",
    "title": "",
    "update_time": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/cmsBlock/:id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/cmsBlock/:id"

payload = { "block": {
        "active": False,
        "content": "",
        "creation_time": "",
        "id": 0,
        "identifier": "",
        "title": "",
        "update_time": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/cmsBlock/:id"

payload <- "{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/cmsBlock/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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/V1/cmsBlock/:id') do |req|
  req.body = "{\n  \"block\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"creation_time\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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}}/V1/cmsBlock/:id";

    let payload = json!({"block": json!({
            "active": false,
            "content": "",
            "creation_time": "",
            "id": 0,
            "identifier": "",
            "title": "",
            "update_time": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/cmsBlock/:id \
  --header 'content-type: application/json' \
  --data '{
  "block": {
    "active": false,
    "content": "",
    "creation_time": "",
    "id": 0,
    "identifier": "",
    "title": "",
    "update_time": ""
  }
}'
echo '{
  "block": {
    "active": false,
    "content": "",
    "creation_time": "",
    "id": 0,
    "identifier": "",
    "title": "",
    "update_time": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/cmsBlock/:id \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "block": {\n    "active": false,\n    "content": "",\n    "creation_time": "",\n    "id": 0,\n    "identifier": "",\n    "title": "",\n    "update_time": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/cmsBlock/:id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["block": [
    "active": false,
    "content": "",
    "creation_time": "",
    "id": 0,
    "identifier": "",
    "title": "",
    "update_time": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/cmsBlock/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/cmsBlock/search");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/cmsBlock/search")
require "http/client"

url = "{{baseUrl}}/V1/cmsBlock/search"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/cmsBlock/search"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/cmsBlock/search");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/cmsBlock/search"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/cmsBlock/search HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/cmsBlock/search")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/cmsBlock/search"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/cmsBlock/search")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/cmsBlock/search")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/cmsBlock/search');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/cmsBlock/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/cmsBlock/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/cmsBlock/search',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/cmsBlock/search")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/cmsBlock/search',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/cmsBlock/search'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/cmsBlock/search');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/cmsBlock/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/cmsBlock/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/cmsBlock/search"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/cmsBlock/search" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/cmsBlock/search",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/cmsBlock/search');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/cmsBlock/search');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/cmsBlock/search');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/cmsBlock/search' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/cmsBlock/search' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/cmsBlock/search")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/cmsBlock/search"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/cmsBlock/search"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/cmsBlock/search")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/cmsBlock/search') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/cmsBlock/search";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/cmsBlock/search
http GET {{baseUrl}}/V1/cmsBlock/search
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/cmsBlock/search
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/cmsBlock/search")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST cmsPage
{{baseUrl}}/V1/cmsPage
BODY json

{
  "page": {
    "active": false,
    "content": "",
    "content_heading": "",
    "creation_time": "",
    "custom_layout_update_xml": "",
    "custom_root_template": "",
    "custom_theme": "",
    "custom_theme_from": "",
    "custom_theme_to": "",
    "id": 0,
    "identifier": "",
    "layout_update_xml": "",
    "meta_description": "",
    "meta_keywords": "",
    "meta_title": "",
    "page_layout": "",
    "sort_order": "",
    "title": "",
    "update_time": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/cmsPage");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/cmsPage" {:content-type :json
                                                       :form-params {:page {:active false
                                                                            :content ""
                                                                            :content_heading ""
                                                                            :creation_time ""
                                                                            :custom_layout_update_xml ""
                                                                            :custom_root_template ""
                                                                            :custom_theme ""
                                                                            :custom_theme_from ""
                                                                            :custom_theme_to ""
                                                                            :id 0
                                                                            :identifier ""
                                                                            :layout_update_xml ""
                                                                            :meta_description ""
                                                                            :meta_keywords ""
                                                                            :meta_title ""
                                                                            :page_layout ""
                                                                            :sort_order ""
                                                                            :title ""
                                                                            :update_time ""}}})
require "http/client"

url = "{{baseUrl}}/V1/cmsPage"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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}}/V1/cmsPage"),
    Content = new StringContent("{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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}}/V1/cmsPage");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/cmsPage"

	payload := strings.NewReader("{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/cmsPage HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 482

{
  "page": {
    "active": false,
    "content": "",
    "content_heading": "",
    "creation_time": "",
    "custom_layout_update_xml": "",
    "custom_root_template": "",
    "custom_theme": "",
    "custom_theme_from": "",
    "custom_theme_to": "",
    "id": 0,
    "identifier": "",
    "layout_update_xml": "",
    "meta_description": "",
    "meta_keywords": "",
    "meta_title": "",
    "page_layout": "",
    "sort_order": "",
    "title": "",
    "update_time": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/cmsPage")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/cmsPage"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/cmsPage")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/cmsPage")
  .header("content-type", "application/json")
  .body("{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  page: {
    active: false,
    content: '',
    content_heading: '',
    creation_time: '',
    custom_layout_update_xml: '',
    custom_root_template: '',
    custom_theme: '',
    custom_theme_from: '',
    custom_theme_to: '',
    id: 0,
    identifier: '',
    layout_update_xml: '',
    meta_description: '',
    meta_keywords: '',
    meta_title: '',
    page_layout: '',
    sort_order: '',
    title: '',
    update_time: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/cmsPage');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/cmsPage',
  headers: {'content-type': 'application/json'},
  data: {
    page: {
      active: false,
      content: '',
      content_heading: '',
      creation_time: '',
      custom_layout_update_xml: '',
      custom_root_template: '',
      custom_theme: '',
      custom_theme_from: '',
      custom_theme_to: '',
      id: 0,
      identifier: '',
      layout_update_xml: '',
      meta_description: '',
      meta_keywords: '',
      meta_title: '',
      page_layout: '',
      sort_order: '',
      title: '',
      update_time: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/cmsPage';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"page":{"active":false,"content":"","content_heading":"","creation_time":"","custom_layout_update_xml":"","custom_root_template":"","custom_theme":"","custom_theme_from":"","custom_theme_to":"","id":0,"identifier":"","layout_update_xml":"","meta_description":"","meta_keywords":"","meta_title":"","page_layout":"","sort_order":"","title":"","update_time":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/cmsPage',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "page": {\n    "active": false,\n    "content": "",\n    "content_heading": "",\n    "creation_time": "",\n    "custom_layout_update_xml": "",\n    "custom_root_template": "",\n    "custom_theme": "",\n    "custom_theme_from": "",\n    "custom_theme_to": "",\n    "id": 0,\n    "identifier": "",\n    "layout_update_xml": "",\n    "meta_description": "",\n    "meta_keywords": "",\n    "meta_title": "",\n    "page_layout": "",\n    "sort_order": "",\n    "title": "",\n    "update_time": ""\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  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/cmsPage")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/cmsPage',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  page: {
    active: false,
    content: '',
    content_heading: '',
    creation_time: '',
    custom_layout_update_xml: '',
    custom_root_template: '',
    custom_theme: '',
    custom_theme_from: '',
    custom_theme_to: '',
    id: 0,
    identifier: '',
    layout_update_xml: '',
    meta_description: '',
    meta_keywords: '',
    meta_title: '',
    page_layout: '',
    sort_order: '',
    title: '',
    update_time: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/cmsPage',
  headers: {'content-type': 'application/json'},
  body: {
    page: {
      active: false,
      content: '',
      content_heading: '',
      creation_time: '',
      custom_layout_update_xml: '',
      custom_root_template: '',
      custom_theme: '',
      custom_theme_from: '',
      custom_theme_to: '',
      id: 0,
      identifier: '',
      layout_update_xml: '',
      meta_description: '',
      meta_keywords: '',
      meta_title: '',
      page_layout: '',
      sort_order: '',
      title: '',
      update_time: ''
    }
  },
  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}}/V1/cmsPage');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  page: {
    active: false,
    content: '',
    content_heading: '',
    creation_time: '',
    custom_layout_update_xml: '',
    custom_root_template: '',
    custom_theme: '',
    custom_theme_from: '',
    custom_theme_to: '',
    id: 0,
    identifier: '',
    layout_update_xml: '',
    meta_description: '',
    meta_keywords: '',
    meta_title: '',
    page_layout: '',
    sort_order: '',
    title: '',
    update_time: ''
  }
});

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}}/V1/cmsPage',
  headers: {'content-type': 'application/json'},
  data: {
    page: {
      active: false,
      content: '',
      content_heading: '',
      creation_time: '',
      custom_layout_update_xml: '',
      custom_root_template: '',
      custom_theme: '',
      custom_theme_from: '',
      custom_theme_to: '',
      id: 0,
      identifier: '',
      layout_update_xml: '',
      meta_description: '',
      meta_keywords: '',
      meta_title: '',
      page_layout: '',
      sort_order: '',
      title: '',
      update_time: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/cmsPage';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"page":{"active":false,"content":"","content_heading":"","creation_time":"","custom_layout_update_xml":"","custom_root_template":"","custom_theme":"","custom_theme_from":"","custom_theme_to":"","id":0,"identifier":"","layout_update_xml":"","meta_description":"","meta_keywords":"","meta_title":"","page_layout":"","sort_order":"","title":"","update_time":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"page": @{ @"active": @NO, @"content": @"", @"content_heading": @"", @"creation_time": @"", @"custom_layout_update_xml": @"", @"custom_root_template": @"", @"custom_theme": @"", @"custom_theme_from": @"", @"custom_theme_to": @"", @"id": @0, @"identifier": @"", @"layout_update_xml": @"", @"meta_description": @"", @"meta_keywords": @"", @"meta_title": @"", @"page_layout": @"", @"sort_order": @"", @"title": @"", @"update_time": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/cmsPage"]
                                                       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}}/V1/cmsPage" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/cmsPage",
  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([
    'page' => [
        'active' => null,
        'content' => '',
        'content_heading' => '',
        'creation_time' => '',
        'custom_layout_update_xml' => '',
        'custom_root_template' => '',
        'custom_theme' => '',
        'custom_theme_from' => '',
        'custom_theme_to' => '',
        'id' => 0,
        'identifier' => '',
        'layout_update_xml' => '',
        'meta_description' => '',
        'meta_keywords' => '',
        'meta_title' => '',
        'page_layout' => '',
        'sort_order' => '',
        'title' => '',
        'update_time' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/cmsPage', [
  'body' => '{
  "page": {
    "active": false,
    "content": "",
    "content_heading": "",
    "creation_time": "",
    "custom_layout_update_xml": "",
    "custom_root_template": "",
    "custom_theme": "",
    "custom_theme_from": "",
    "custom_theme_to": "",
    "id": 0,
    "identifier": "",
    "layout_update_xml": "",
    "meta_description": "",
    "meta_keywords": "",
    "meta_title": "",
    "page_layout": "",
    "sort_order": "",
    "title": "",
    "update_time": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/cmsPage');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'page' => [
    'active' => null,
    'content' => '',
    'content_heading' => '',
    'creation_time' => '',
    'custom_layout_update_xml' => '',
    'custom_root_template' => '',
    'custom_theme' => '',
    'custom_theme_from' => '',
    'custom_theme_to' => '',
    'id' => 0,
    'identifier' => '',
    'layout_update_xml' => '',
    'meta_description' => '',
    'meta_keywords' => '',
    'meta_title' => '',
    'page_layout' => '',
    'sort_order' => '',
    'title' => '',
    'update_time' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'page' => [
    'active' => null,
    'content' => '',
    'content_heading' => '',
    'creation_time' => '',
    'custom_layout_update_xml' => '',
    'custom_root_template' => '',
    'custom_theme' => '',
    'custom_theme_from' => '',
    'custom_theme_to' => '',
    'id' => 0,
    'identifier' => '',
    'layout_update_xml' => '',
    'meta_description' => '',
    'meta_keywords' => '',
    'meta_title' => '',
    'page_layout' => '',
    'sort_order' => '',
    'title' => '',
    'update_time' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/cmsPage');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/cmsPage' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "page": {
    "active": false,
    "content": "",
    "content_heading": "",
    "creation_time": "",
    "custom_layout_update_xml": "",
    "custom_root_template": "",
    "custom_theme": "",
    "custom_theme_from": "",
    "custom_theme_to": "",
    "id": 0,
    "identifier": "",
    "layout_update_xml": "",
    "meta_description": "",
    "meta_keywords": "",
    "meta_title": "",
    "page_layout": "",
    "sort_order": "",
    "title": "",
    "update_time": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/cmsPage' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "page": {
    "active": false,
    "content": "",
    "content_heading": "",
    "creation_time": "",
    "custom_layout_update_xml": "",
    "custom_root_template": "",
    "custom_theme": "",
    "custom_theme_from": "",
    "custom_theme_to": "",
    "id": 0,
    "identifier": "",
    "layout_update_xml": "",
    "meta_description": "",
    "meta_keywords": "",
    "meta_title": "",
    "page_layout": "",
    "sort_order": "",
    "title": "",
    "update_time": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/cmsPage", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/cmsPage"

payload = { "page": {
        "active": False,
        "content": "",
        "content_heading": "",
        "creation_time": "",
        "custom_layout_update_xml": "",
        "custom_root_template": "",
        "custom_theme": "",
        "custom_theme_from": "",
        "custom_theme_to": "",
        "id": 0,
        "identifier": "",
        "layout_update_xml": "",
        "meta_description": "",
        "meta_keywords": "",
        "meta_title": "",
        "page_layout": "",
        "sort_order": "",
        "title": "",
        "update_time": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/cmsPage"

payload <- "{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/cmsPage")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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/V1/cmsPage') do |req|
  req.body = "{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/cmsPage";

    let payload = json!({"page": json!({
            "active": false,
            "content": "",
            "content_heading": "",
            "creation_time": "",
            "custom_layout_update_xml": "",
            "custom_root_template": "",
            "custom_theme": "",
            "custom_theme_from": "",
            "custom_theme_to": "",
            "id": 0,
            "identifier": "",
            "layout_update_xml": "",
            "meta_description": "",
            "meta_keywords": "",
            "meta_title": "",
            "page_layout": "",
            "sort_order": "",
            "title": "",
            "update_time": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/cmsPage \
  --header 'content-type: application/json' \
  --data '{
  "page": {
    "active": false,
    "content": "",
    "content_heading": "",
    "creation_time": "",
    "custom_layout_update_xml": "",
    "custom_root_template": "",
    "custom_theme": "",
    "custom_theme_from": "",
    "custom_theme_to": "",
    "id": 0,
    "identifier": "",
    "layout_update_xml": "",
    "meta_description": "",
    "meta_keywords": "",
    "meta_title": "",
    "page_layout": "",
    "sort_order": "",
    "title": "",
    "update_time": ""
  }
}'
echo '{
  "page": {
    "active": false,
    "content": "",
    "content_heading": "",
    "creation_time": "",
    "custom_layout_update_xml": "",
    "custom_root_template": "",
    "custom_theme": "",
    "custom_theme_from": "",
    "custom_theme_to": "",
    "id": 0,
    "identifier": "",
    "layout_update_xml": "",
    "meta_description": "",
    "meta_keywords": "",
    "meta_title": "",
    "page_layout": "",
    "sort_order": "",
    "title": "",
    "update_time": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/cmsPage \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "page": {\n    "active": false,\n    "content": "",\n    "content_heading": "",\n    "creation_time": "",\n    "custom_layout_update_xml": "",\n    "custom_root_template": "",\n    "custom_theme": "",\n    "custom_theme_from": "",\n    "custom_theme_to": "",\n    "id": 0,\n    "identifier": "",\n    "layout_update_xml": "",\n    "meta_description": "",\n    "meta_keywords": "",\n    "meta_title": "",\n    "page_layout": "",\n    "sort_order": "",\n    "title": "",\n    "update_time": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/cmsPage
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["page": [
    "active": false,
    "content": "",
    "content_heading": "",
    "creation_time": "",
    "custom_layout_update_xml": "",
    "custom_root_template": "",
    "custom_theme": "",
    "custom_theme_from": "",
    "custom_theme_to": "",
    "id": 0,
    "identifier": "",
    "layout_update_xml": "",
    "meta_description": "",
    "meta_keywords": "",
    "meta_title": "",
    "page_layout": "",
    "sort_order": "",
    "title": "",
    "update_time": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/cmsPage")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT cmsPage-{id}
{{baseUrl}}/V1/cmsPage/:id
QUERY PARAMS

id
BODY json

{
  "page": {
    "active": false,
    "content": "",
    "content_heading": "",
    "creation_time": "",
    "custom_layout_update_xml": "",
    "custom_root_template": "",
    "custom_theme": "",
    "custom_theme_from": "",
    "custom_theme_to": "",
    "id": 0,
    "identifier": "",
    "layout_update_xml": "",
    "meta_description": "",
    "meta_keywords": "",
    "meta_title": "",
    "page_layout": "",
    "sort_order": "",
    "title": "",
    "update_time": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/cmsPage/:id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/cmsPage/:id" {:content-type :json
                                                          :form-params {:page {:active false
                                                                               :content ""
                                                                               :content_heading ""
                                                                               :creation_time ""
                                                                               :custom_layout_update_xml ""
                                                                               :custom_root_template ""
                                                                               :custom_theme ""
                                                                               :custom_theme_from ""
                                                                               :custom_theme_to ""
                                                                               :id 0
                                                                               :identifier ""
                                                                               :layout_update_xml ""
                                                                               :meta_description ""
                                                                               :meta_keywords ""
                                                                               :meta_title ""
                                                                               :page_layout ""
                                                                               :sort_order ""
                                                                               :title ""
                                                                               :update_time ""}}})
require "http/client"

url = "{{baseUrl}}/V1/cmsPage/:id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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}}/V1/cmsPage/:id"),
    Content = new StringContent("{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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}}/V1/cmsPage/:id");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/cmsPage/:id"

	payload := strings.NewReader("{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/cmsPage/:id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 482

{
  "page": {
    "active": false,
    "content": "",
    "content_heading": "",
    "creation_time": "",
    "custom_layout_update_xml": "",
    "custom_root_template": "",
    "custom_theme": "",
    "custom_theme_from": "",
    "custom_theme_to": "",
    "id": 0,
    "identifier": "",
    "layout_update_xml": "",
    "meta_description": "",
    "meta_keywords": "",
    "meta_title": "",
    "page_layout": "",
    "sort_order": "",
    "title": "",
    "update_time": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/cmsPage/:id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/cmsPage/:id"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/cmsPage/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/cmsPage/:id")
  .header("content-type", "application/json")
  .body("{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  page: {
    active: false,
    content: '',
    content_heading: '',
    creation_time: '',
    custom_layout_update_xml: '',
    custom_root_template: '',
    custom_theme: '',
    custom_theme_from: '',
    custom_theme_to: '',
    id: 0,
    identifier: '',
    layout_update_xml: '',
    meta_description: '',
    meta_keywords: '',
    meta_title: '',
    page_layout: '',
    sort_order: '',
    title: '',
    update_time: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/cmsPage/:id');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/cmsPage/:id',
  headers: {'content-type': 'application/json'},
  data: {
    page: {
      active: false,
      content: '',
      content_heading: '',
      creation_time: '',
      custom_layout_update_xml: '',
      custom_root_template: '',
      custom_theme: '',
      custom_theme_from: '',
      custom_theme_to: '',
      id: 0,
      identifier: '',
      layout_update_xml: '',
      meta_description: '',
      meta_keywords: '',
      meta_title: '',
      page_layout: '',
      sort_order: '',
      title: '',
      update_time: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/cmsPage/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"page":{"active":false,"content":"","content_heading":"","creation_time":"","custom_layout_update_xml":"","custom_root_template":"","custom_theme":"","custom_theme_from":"","custom_theme_to":"","id":0,"identifier":"","layout_update_xml":"","meta_description":"","meta_keywords":"","meta_title":"","page_layout":"","sort_order":"","title":"","update_time":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/cmsPage/:id',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "page": {\n    "active": false,\n    "content": "",\n    "content_heading": "",\n    "creation_time": "",\n    "custom_layout_update_xml": "",\n    "custom_root_template": "",\n    "custom_theme": "",\n    "custom_theme_from": "",\n    "custom_theme_to": "",\n    "id": 0,\n    "identifier": "",\n    "layout_update_xml": "",\n    "meta_description": "",\n    "meta_keywords": "",\n    "meta_title": "",\n    "page_layout": "",\n    "sort_order": "",\n    "title": "",\n    "update_time": ""\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  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/cmsPage/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/cmsPage/:id',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  page: {
    active: false,
    content: '',
    content_heading: '',
    creation_time: '',
    custom_layout_update_xml: '',
    custom_root_template: '',
    custom_theme: '',
    custom_theme_from: '',
    custom_theme_to: '',
    id: 0,
    identifier: '',
    layout_update_xml: '',
    meta_description: '',
    meta_keywords: '',
    meta_title: '',
    page_layout: '',
    sort_order: '',
    title: '',
    update_time: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/cmsPage/:id',
  headers: {'content-type': 'application/json'},
  body: {
    page: {
      active: false,
      content: '',
      content_heading: '',
      creation_time: '',
      custom_layout_update_xml: '',
      custom_root_template: '',
      custom_theme: '',
      custom_theme_from: '',
      custom_theme_to: '',
      id: 0,
      identifier: '',
      layout_update_xml: '',
      meta_description: '',
      meta_keywords: '',
      meta_title: '',
      page_layout: '',
      sort_order: '',
      title: '',
      update_time: ''
    }
  },
  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}}/V1/cmsPage/:id');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  page: {
    active: false,
    content: '',
    content_heading: '',
    creation_time: '',
    custom_layout_update_xml: '',
    custom_root_template: '',
    custom_theme: '',
    custom_theme_from: '',
    custom_theme_to: '',
    id: 0,
    identifier: '',
    layout_update_xml: '',
    meta_description: '',
    meta_keywords: '',
    meta_title: '',
    page_layout: '',
    sort_order: '',
    title: '',
    update_time: ''
  }
});

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}}/V1/cmsPage/:id',
  headers: {'content-type': 'application/json'},
  data: {
    page: {
      active: false,
      content: '',
      content_heading: '',
      creation_time: '',
      custom_layout_update_xml: '',
      custom_root_template: '',
      custom_theme: '',
      custom_theme_from: '',
      custom_theme_to: '',
      id: 0,
      identifier: '',
      layout_update_xml: '',
      meta_description: '',
      meta_keywords: '',
      meta_title: '',
      page_layout: '',
      sort_order: '',
      title: '',
      update_time: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/cmsPage/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"page":{"active":false,"content":"","content_heading":"","creation_time":"","custom_layout_update_xml":"","custom_root_template":"","custom_theme":"","custom_theme_from":"","custom_theme_to":"","id":0,"identifier":"","layout_update_xml":"","meta_description":"","meta_keywords":"","meta_title":"","page_layout":"","sort_order":"","title":"","update_time":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"page": @{ @"active": @NO, @"content": @"", @"content_heading": @"", @"creation_time": @"", @"custom_layout_update_xml": @"", @"custom_root_template": @"", @"custom_theme": @"", @"custom_theme_from": @"", @"custom_theme_to": @"", @"id": @0, @"identifier": @"", @"layout_update_xml": @"", @"meta_description": @"", @"meta_keywords": @"", @"meta_title": @"", @"page_layout": @"", @"sort_order": @"", @"title": @"", @"update_time": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/cmsPage/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/cmsPage/:id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/cmsPage/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'page' => [
        'active' => null,
        'content' => '',
        'content_heading' => '',
        'creation_time' => '',
        'custom_layout_update_xml' => '',
        'custom_root_template' => '',
        'custom_theme' => '',
        'custom_theme_from' => '',
        'custom_theme_to' => '',
        'id' => 0,
        'identifier' => '',
        'layout_update_xml' => '',
        'meta_description' => '',
        'meta_keywords' => '',
        'meta_title' => '',
        'page_layout' => '',
        'sort_order' => '',
        'title' => '',
        'update_time' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/cmsPage/:id', [
  'body' => '{
  "page": {
    "active": false,
    "content": "",
    "content_heading": "",
    "creation_time": "",
    "custom_layout_update_xml": "",
    "custom_root_template": "",
    "custom_theme": "",
    "custom_theme_from": "",
    "custom_theme_to": "",
    "id": 0,
    "identifier": "",
    "layout_update_xml": "",
    "meta_description": "",
    "meta_keywords": "",
    "meta_title": "",
    "page_layout": "",
    "sort_order": "",
    "title": "",
    "update_time": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/cmsPage/:id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'page' => [
    'active' => null,
    'content' => '',
    'content_heading' => '',
    'creation_time' => '',
    'custom_layout_update_xml' => '',
    'custom_root_template' => '',
    'custom_theme' => '',
    'custom_theme_from' => '',
    'custom_theme_to' => '',
    'id' => 0,
    'identifier' => '',
    'layout_update_xml' => '',
    'meta_description' => '',
    'meta_keywords' => '',
    'meta_title' => '',
    'page_layout' => '',
    'sort_order' => '',
    'title' => '',
    'update_time' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'page' => [
    'active' => null,
    'content' => '',
    'content_heading' => '',
    'creation_time' => '',
    'custom_layout_update_xml' => '',
    'custom_root_template' => '',
    'custom_theme' => '',
    'custom_theme_from' => '',
    'custom_theme_to' => '',
    'id' => 0,
    'identifier' => '',
    'layout_update_xml' => '',
    'meta_description' => '',
    'meta_keywords' => '',
    'meta_title' => '',
    'page_layout' => '',
    'sort_order' => '',
    'title' => '',
    'update_time' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/cmsPage/:id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/cmsPage/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "page": {
    "active": false,
    "content": "",
    "content_heading": "",
    "creation_time": "",
    "custom_layout_update_xml": "",
    "custom_root_template": "",
    "custom_theme": "",
    "custom_theme_from": "",
    "custom_theme_to": "",
    "id": 0,
    "identifier": "",
    "layout_update_xml": "",
    "meta_description": "",
    "meta_keywords": "",
    "meta_title": "",
    "page_layout": "",
    "sort_order": "",
    "title": "",
    "update_time": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/cmsPage/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "page": {
    "active": false,
    "content": "",
    "content_heading": "",
    "creation_time": "",
    "custom_layout_update_xml": "",
    "custom_root_template": "",
    "custom_theme": "",
    "custom_theme_from": "",
    "custom_theme_to": "",
    "id": 0,
    "identifier": "",
    "layout_update_xml": "",
    "meta_description": "",
    "meta_keywords": "",
    "meta_title": "",
    "page_layout": "",
    "sort_order": "",
    "title": "",
    "update_time": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/cmsPage/:id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/cmsPage/:id"

payload = { "page": {
        "active": False,
        "content": "",
        "content_heading": "",
        "creation_time": "",
        "custom_layout_update_xml": "",
        "custom_root_template": "",
        "custom_theme": "",
        "custom_theme_from": "",
        "custom_theme_to": "",
        "id": 0,
        "identifier": "",
        "layout_update_xml": "",
        "meta_description": "",
        "meta_keywords": "",
        "meta_title": "",
        "page_layout": "",
        "sort_order": "",
        "title": "",
        "update_time": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/cmsPage/:id"

payload <- "{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/cmsPage/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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/V1/cmsPage/:id') do |req|
  req.body = "{\n  \"page\": {\n    \"active\": false,\n    \"content\": \"\",\n    \"content_heading\": \"\",\n    \"creation_time\": \"\",\n    \"custom_layout_update_xml\": \"\",\n    \"custom_root_template\": \"\",\n    \"custom_theme\": \"\",\n    \"custom_theme_from\": \"\",\n    \"custom_theme_to\": \"\",\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"layout_update_xml\": \"\",\n    \"meta_description\": \"\",\n    \"meta_keywords\": \"\",\n    \"meta_title\": \"\",\n    \"page_layout\": \"\",\n    \"sort_order\": \"\",\n    \"title\": \"\",\n    \"update_time\": \"\"\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}}/V1/cmsPage/:id";

    let payload = json!({"page": json!({
            "active": false,
            "content": "",
            "content_heading": "",
            "creation_time": "",
            "custom_layout_update_xml": "",
            "custom_root_template": "",
            "custom_theme": "",
            "custom_theme_from": "",
            "custom_theme_to": "",
            "id": 0,
            "identifier": "",
            "layout_update_xml": "",
            "meta_description": "",
            "meta_keywords": "",
            "meta_title": "",
            "page_layout": "",
            "sort_order": "",
            "title": "",
            "update_time": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/cmsPage/:id \
  --header 'content-type: application/json' \
  --data '{
  "page": {
    "active": false,
    "content": "",
    "content_heading": "",
    "creation_time": "",
    "custom_layout_update_xml": "",
    "custom_root_template": "",
    "custom_theme": "",
    "custom_theme_from": "",
    "custom_theme_to": "",
    "id": 0,
    "identifier": "",
    "layout_update_xml": "",
    "meta_description": "",
    "meta_keywords": "",
    "meta_title": "",
    "page_layout": "",
    "sort_order": "",
    "title": "",
    "update_time": ""
  }
}'
echo '{
  "page": {
    "active": false,
    "content": "",
    "content_heading": "",
    "creation_time": "",
    "custom_layout_update_xml": "",
    "custom_root_template": "",
    "custom_theme": "",
    "custom_theme_from": "",
    "custom_theme_to": "",
    "id": 0,
    "identifier": "",
    "layout_update_xml": "",
    "meta_description": "",
    "meta_keywords": "",
    "meta_title": "",
    "page_layout": "",
    "sort_order": "",
    "title": "",
    "update_time": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/cmsPage/:id \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "page": {\n    "active": false,\n    "content": "",\n    "content_heading": "",\n    "creation_time": "",\n    "custom_layout_update_xml": "",\n    "custom_root_template": "",\n    "custom_theme": "",\n    "custom_theme_from": "",\n    "custom_theme_to": "",\n    "id": 0,\n    "identifier": "",\n    "layout_update_xml": "",\n    "meta_description": "",\n    "meta_keywords": "",\n    "meta_title": "",\n    "page_layout": "",\n    "sort_order": "",\n    "title": "",\n    "update_time": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/cmsPage/:id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["page": [
    "active": false,
    "content": "",
    "content_heading": "",
    "creation_time": "",
    "custom_layout_update_xml": "",
    "custom_root_template": "",
    "custom_theme": "",
    "custom_theme_from": "",
    "custom_theme_to": "",
    "id": 0,
    "identifier": "",
    "layout_update_xml": "",
    "meta_description": "",
    "meta_keywords": "",
    "meta_title": "",
    "page_layout": "",
    "sort_order": "",
    "title": "",
    "update_time": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/cmsPage/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET cmsPage-{pageId} (GET)
{{baseUrl}}/V1/cmsPage/:pageId
QUERY PARAMS

pageId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/cmsPage/:pageId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/cmsPage/:pageId")
require "http/client"

url = "{{baseUrl}}/V1/cmsPage/:pageId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/cmsPage/:pageId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/cmsPage/:pageId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/cmsPage/:pageId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/cmsPage/:pageId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/cmsPage/:pageId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/cmsPage/:pageId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/cmsPage/:pageId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/cmsPage/:pageId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/cmsPage/:pageId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/cmsPage/:pageId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/cmsPage/:pageId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/cmsPage/:pageId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/cmsPage/:pageId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/cmsPage/:pageId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/cmsPage/:pageId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/cmsPage/:pageId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/cmsPage/:pageId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/cmsPage/:pageId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/cmsPage/:pageId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/cmsPage/:pageId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/cmsPage/:pageId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/cmsPage/:pageId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/cmsPage/:pageId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/cmsPage/:pageId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/cmsPage/:pageId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/cmsPage/:pageId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/cmsPage/:pageId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/cmsPage/:pageId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/cmsPage/:pageId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/cmsPage/:pageId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/cmsPage/:pageId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/cmsPage/:pageId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/cmsPage/:pageId
http GET {{baseUrl}}/V1/cmsPage/:pageId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/cmsPage/:pageId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/cmsPage/:pageId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE cmsPage-{pageId}
{{baseUrl}}/V1/cmsPage/:pageId
QUERY PARAMS

pageId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/cmsPage/:pageId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/cmsPage/:pageId")
require "http/client"

url = "{{baseUrl}}/V1/cmsPage/:pageId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/cmsPage/:pageId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/cmsPage/:pageId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/cmsPage/:pageId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/cmsPage/:pageId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/cmsPage/:pageId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/cmsPage/:pageId"))
    .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}}/V1/cmsPage/:pageId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/cmsPage/:pageId")
  .asString();
const 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}}/V1/cmsPage/:pageId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/cmsPage/:pageId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/cmsPage/:pageId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/cmsPage/:pageId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/cmsPage/:pageId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/cmsPage/:pageId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/cmsPage/:pageId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/cmsPage/:pageId');

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}}/V1/cmsPage/:pageId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/cmsPage/:pageId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/cmsPage/:pageId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/cmsPage/:pageId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/cmsPage/:pageId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/cmsPage/:pageId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/cmsPage/:pageId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/cmsPage/:pageId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/cmsPage/:pageId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/cmsPage/:pageId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/cmsPage/:pageId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/cmsPage/:pageId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/cmsPage/:pageId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/cmsPage/:pageId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/cmsPage/:pageId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/cmsPage/:pageId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/cmsPage/:pageId
http DELETE {{baseUrl}}/V1/cmsPage/:pageId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/cmsPage/:pageId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/cmsPage/:pageId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/cmsPage/search");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/cmsPage/search")
require "http/client"

url = "{{baseUrl}}/V1/cmsPage/search"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/cmsPage/search"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/cmsPage/search");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/cmsPage/search"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/cmsPage/search HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/cmsPage/search")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/cmsPage/search"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/cmsPage/search")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/cmsPage/search")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/cmsPage/search');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/cmsPage/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/cmsPage/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/cmsPage/search',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/cmsPage/search")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/cmsPage/search',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/cmsPage/search'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/cmsPage/search');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/cmsPage/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/cmsPage/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/cmsPage/search"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/cmsPage/search" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/cmsPage/search",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/cmsPage/search');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/cmsPage/search');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/cmsPage/search');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/cmsPage/search' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/cmsPage/search' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/cmsPage/search")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/cmsPage/search"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/cmsPage/search"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/cmsPage/search")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/cmsPage/search') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/cmsPage/search";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/cmsPage/search
http GET {{baseUrl}}/V1/cmsPage/search
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/cmsPage/search
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/cmsPage/search")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST company- (POST)
{{baseUrl}}/V1/company/
BODY json

{
  "company": {
    "city": "",
    "comment": "",
    "company_email": "",
    "company_name": "",
    "country_id": "",
    "customer_group_id": 0,
    "extension_attributes": {
      "applicable_payment_method": 0,
      "available_payment_methods": "",
      "quote_config": {
        "company_id": "",
        "extension_attributes": {},
        "is_quote_enabled": false
      },
      "use_config_settings": 0
    },
    "id": 0,
    "legal_name": "",
    "postcode": "",
    "region": "",
    "region_id": "",
    "reject_reason": "",
    "rejected_at": "",
    "reseller_id": "",
    "sales_representative_id": 0,
    "status": 0,
    "street": [],
    "super_user_id": 0,
    "telephone": "",
    "vat_tax_id": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/company/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/company/" {:content-type :json
                                                        :form-params {:company {:city ""
                                                                                :comment ""
                                                                                :company_email ""
                                                                                :company_name ""
                                                                                :country_id ""
                                                                                :customer_group_id 0
                                                                                :extension_attributes {:applicable_payment_method 0
                                                                                                       :available_payment_methods ""
                                                                                                       :quote_config {:company_id ""
                                                                                                                      :extension_attributes {}
                                                                                                                      :is_quote_enabled false}
                                                                                                       :use_config_settings 0}
                                                                                :id 0
                                                                                :legal_name ""
                                                                                :postcode ""
                                                                                :region ""
                                                                                :region_id ""
                                                                                :reject_reason ""
                                                                                :rejected_at ""
                                                                                :reseller_id ""
                                                                                :sales_representative_id 0
                                                                                :status 0
                                                                                :street []
                                                                                :super_user_id 0
                                                                                :telephone ""
                                                                                :vat_tax_id ""}}})
require "http/client"

url = "{{baseUrl}}/V1/company/"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\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}}/V1/company/"),
    Content = new StringContent("{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\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}}/V1/company/");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/company/"

	payload := strings.NewReader("{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/company/ HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 730

{
  "company": {
    "city": "",
    "comment": "",
    "company_email": "",
    "company_name": "",
    "country_id": "",
    "customer_group_id": 0,
    "extension_attributes": {
      "applicable_payment_method": 0,
      "available_payment_methods": "",
      "quote_config": {
        "company_id": "",
        "extension_attributes": {},
        "is_quote_enabled": false
      },
      "use_config_settings": 0
    },
    "id": 0,
    "legal_name": "",
    "postcode": "",
    "region": "",
    "region_id": "",
    "reject_reason": "",
    "rejected_at": "",
    "reseller_id": "",
    "sales_representative_id": 0,
    "status": 0,
    "street": [],
    "super_user_id": 0,
    "telephone": "",
    "vat_tax_id": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/company/")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/company/"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\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  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/company/")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/company/")
  .header("content-type", "application/json")
  .body("{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  company: {
    city: '',
    comment: '',
    company_email: '',
    company_name: '',
    country_id: '',
    customer_group_id: 0,
    extension_attributes: {
      applicable_payment_method: 0,
      available_payment_methods: '',
      quote_config: {
        company_id: '',
        extension_attributes: {},
        is_quote_enabled: false
      },
      use_config_settings: 0
    },
    id: 0,
    legal_name: '',
    postcode: '',
    region: '',
    region_id: '',
    reject_reason: '',
    rejected_at: '',
    reseller_id: '',
    sales_representative_id: 0,
    status: 0,
    street: [],
    super_user_id: 0,
    telephone: '',
    vat_tax_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}}/V1/company/');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/company/',
  headers: {'content-type': 'application/json'},
  data: {
    company: {
      city: '',
      comment: '',
      company_email: '',
      company_name: '',
      country_id: '',
      customer_group_id: 0,
      extension_attributes: {
        applicable_payment_method: 0,
        available_payment_methods: '',
        quote_config: {company_id: '', extension_attributes: {}, is_quote_enabled: false},
        use_config_settings: 0
      },
      id: 0,
      legal_name: '',
      postcode: '',
      region: '',
      region_id: '',
      reject_reason: '',
      rejected_at: '',
      reseller_id: '',
      sales_representative_id: 0,
      status: 0,
      street: [],
      super_user_id: 0,
      telephone: '',
      vat_tax_id: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/company/';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"company":{"city":"","comment":"","company_email":"","company_name":"","country_id":"","customer_group_id":0,"extension_attributes":{"applicable_payment_method":0,"available_payment_methods":"","quote_config":{"company_id":"","extension_attributes":{},"is_quote_enabled":false},"use_config_settings":0},"id":0,"legal_name":"","postcode":"","region":"","region_id":"","reject_reason":"","rejected_at":"","reseller_id":"","sales_representative_id":0,"status":0,"street":[],"super_user_id":0,"telephone":"","vat_tax_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}}/V1/company/',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "company": {\n    "city": "",\n    "comment": "",\n    "company_email": "",\n    "company_name": "",\n    "country_id": "",\n    "customer_group_id": 0,\n    "extension_attributes": {\n      "applicable_payment_method": 0,\n      "available_payment_methods": "",\n      "quote_config": {\n        "company_id": "",\n        "extension_attributes": {},\n        "is_quote_enabled": false\n      },\n      "use_config_settings": 0\n    },\n    "id": 0,\n    "legal_name": "",\n    "postcode": "",\n    "region": "",\n    "region_id": "",\n    "reject_reason": "",\n    "rejected_at": "",\n    "reseller_id": "",\n    "sales_representative_id": 0,\n    "status": 0,\n    "street": [],\n    "super_user_id": 0,\n    "telephone": "",\n    "vat_tax_id": ""\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  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/company/")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/company/',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  company: {
    city: '',
    comment: '',
    company_email: '',
    company_name: '',
    country_id: '',
    customer_group_id: 0,
    extension_attributes: {
      applicable_payment_method: 0,
      available_payment_methods: '',
      quote_config: {company_id: '', extension_attributes: {}, is_quote_enabled: false},
      use_config_settings: 0
    },
    id: 0,
    legal_name: '',
    postcode: '',
    region: '',
    region_id: '',
    reject_reason: '',
    rejected_at: '',
    reseller_id: '',
    sales_representative_id: 0,
    status: 0,
    street: [],
    super_user_id: 0,
    telephone: '',
    vat_tax_id: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/company/',
  headers: {'content-type': 'application/json'},
  body: {
    company: {
      city: '',
      comment: '',
      company_email: '',
      company_name: '',
      country_id: '',
      customer_group_id: 0,
      extension_attributes: {
        applicable_payment_method: 0,
        available_payment_methods: '',
        quote_config: {company_id: '', extension_attributes: {}, is_quote_enabled: false},
        use_config_settings: 0
      },
      id: 0,
      legal_name: '',
      postcode: '',
      region: '',
      region_id: '',
      reject_reason: '',
      rejected_at: '',
      reseller_id: '',
      sales_representative_id: 0,
      status: 0,
      street: [],
      super_user_id: 0,
      telephone: '',
      vat_tax_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}}/V1/company/');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  company: {
    city: '',
    comment: '',
    company_email: '',
    company_name: '',
    country_id: '',
    customer_group_id: 0,
    extension_attributes: {
      applicable_payment_method: 0,
      available_payment_methods: '',
      quote_config: {
        company_id: '',
        extension_attributes: {},
        is_quote_enabled: false
      },
      use_config_settings: 0
    },
    id: 0,
    legal_name: '',
    postcode: '',
    region: '',
    region_id: '',
    reject_reason: '',
    rejected_at: '',
    reseller_id: '',
    sales_representative_id: 0,
    status: 0,
    street: [],
    super_user_id: 0,
    telephone: '',
    vat_tax_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}}/V1/company/',
  headers: {'content-type': 'application/json'},
  data: {
    company: {
      city: '',
      comment: '',
      company_email: '',
      company_name: '',
      country_id: '',
      customer_group_id: 0,
      extension_attributes: {
        applicable_payment_method: 0,
        available_payment_methods: '',
        quote_config: {company_id: '', extension_attributes: {}, is_quote_enabled: false},
        use_config_settings: 0
      },
      id: 0,
      legal_name: '',
      postcode: '',
      region: '',
      region_id: '',
      reject_reason: '',
      rejected_at: '',
      reseller_id: '',
      sales_representative_id: 0,
      status: 0,
      street: [],
      super_user_id: 0,
      telephone: '',
      vat_tax_id: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/company/';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"company":{"city":"","comment":"","company_email":"","company_name":"","country_id":"","customer_group_id":0,"extension_attributes":{"applicable_payment_method":0,"available_payment_methods":"","quote_config":{"company_id":"","extension_attributes":{},"is_quote_enabled":false},"use_config_settings":0},"id":0,"legal_name":"","postcode":"","region":"","region_id":"","reject_reason":"","rejected_at":"","reseller_id":"","sales_representative_id":0,"status":0,"street":[],"super_user_id":0,"telephone":"","vat_tax_id":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"company": @{ @"city": @"", @"comment": @"", @"company_email": @"", @"company_name": @"", @"country_id": @"", @"customer_group_id": @0, @"extension_attributes": @{ @"applicable_payment_method": @0, @"available_payment_methods": @"", @"quote_config": @{ @"company_id": @"", @"extension_attributes": @{  }, @"is_quote_enabled": @NO }, @"use_config_settings": @0 }, @"id": @0, @"legal_name": @"", @"postcode": @"", @"region": @"", @"region_id": @"", @"reject_reason": @"", @"rejected_at": @"", @"reseller_id": @"", @"sales_representative_id": @0, @"status": @0, @"street": @[  ], @"super_user_id": @0, @"telephone": @"", @"vat_tax_id": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/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}}/V1/company/" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/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([
    'company' => [
        'city' => '',
        'comment' => '',
        'company_email' => '',
        'company_name' => '',
        'country_id' => '',
        'customer_group_id' => 0,
        'extension_attributes' => [
                'applicable_payment_method' => 0,
                'available_payment_methods' => '',
                'quote_config' => [
                                'company_id' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'is_quote_enabled' => null
                ],
                'use_config_settings' => 0
        ],
        'id' => 0,
        'legal_name' => '',
        'postcode' => '',
        'region' => '',
        'region_id' => '',
        'reject_reason' => '',
        'rejected_at' => '',
        'reseller_id' => '',
        'sales_representative_id' => 0,
        'status' => 0,
        'street' => [
                
        ],
        'super_user_id' => 0,
        'telephone' => '',
        'vat_tax_id' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/company/', [
  'body' => '{
  "company": {
    "city": "",
    "comment": "",
    "company_email": "",
    "company_name": "",
    "country_id": "",
    "customer_group_id": 0,
    "extension_attributes": {
      "applicable_payment_method": 0,
      "available_payment_methods": "",
      "quote_config": {
        "company_id": "",
        "extension_attributes": {},
        "is_quote_enabled": false
      },
      "use_config_settings": 0
    },
    "id": 0,
    "legal_name": "",
    "postcode": "",
    "region": "",
    "region_id": "",
    "reject_reason": "",
    "rejected_at": "",
    "reseller_id": "",
    "sales_representative_id": 0,
    "status": 0,
    "street": [],
    "super_user_id": 0,
    "telephone": "",
    "vat_tax_id": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/company/');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'company' => [
    'city' => '',
    'comment' => '',
    'company_email' => '',
    'company_name' => '',
    'country_id' => '',
    'customer_group_id' => 0,
    'extension_attributes' => [
        'applicable_payment_method' => 0,
        'available_payment_methods' => '',
        'quote_config' => [
                'company_id' => '',
                'extension_attributes' => [
                                
                ],
                'is_quote_enabled' => null
        ],
        'use_config_settings' => 0
    ],
    'id' => 0,
    'legal_name' => '',
    'postcode' => '',
    'region' => '',
    'region_id' => '',
    'reject_reason' => '',
    'rejected_at' => '',
    'reseller_id' => '',
    'sales_representative_id' => 0,
    'status' => 0,
    'street' => [
        
    ],
    'super_user_id' => 0,
    'telephone' => '',
    'vat_tax_id' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'company' => [
    'city' => '',
    'comment' => '',
    'company_email' => '',
    'company_name' => '',
    'country_id' => '',
    'customer_group_id' => 0,
    'extension_attributes' => [
        'applicable_payment_method' => 0,
        'available_payment_methods' => '',
        'quote_config' => [
                'company_id' => '',
                'extension_attributes' => [
                                
                ],
                'is_quote_enabled' => null
        ],
        'use_config_settings' => 0
    ],
    'id' => 0,
    'legal_name' => '',
    'postcode' => '',
    'region' => '',
    'region_id' => '',
    'reject_reason' => '',
    'rejected_at' => '',
    'reseller_id' => '',
    'sales_representative_id' => 0,
    'status' => 0,
    'street' => [
        
    ],
    'super_user_id' => 0,
    'telephone' => '',
    'vat_tax_id' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/company/');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/company/' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "company": {
    "city": "",
    "comment": "",
    "company_email": "",
    "company_name": "",
    "country_id": "",
    "customer_group_id": 0,
    "extension_attributes": {
      "applicable_payment_method": 0,
      "available_payment_methods": "",
      "quote_config": {
        "company_id": "",
        "extension_attributes": {},
        "is_quote_enabled": false
      },
      "use_config_settings": 0
    },
    "id": 0,
    "legal_name": "",
    "postcode": "",
    "region": "",
    "region_id": "",
    "reject_reason": "",
    "rejected_at": "",
    "reseller_id": "",
    "sales_representative_id": 0,
    "status": 0,
    "street": [],
    "super_user_id": 0,
    "telephone": "",
    "vat_tax_id": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/company/' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "company": {
    "city": "",
    "comment": "",
    "company_email": "",
    "company_name": "",
    "country_id": "",
    "customer_group_id": 0,
    "extension_attributes": {
      "applicable_payment_method": 0,
      "available_payment_methods": "",
      "quote_config": {
        "company_id": "",
        "extension_attributes": {},
        "is_quote_enabled": false
      },
      "use_config_settings": 0
    },
    "id": 0,
    "legal_name": "",
    "postcode": "",
    "region": "",
    "region_id": "",
    "reject_reason": "",
    "rejected_at": "",
    "reseller_id": "",
    "sales_representative_id": 0,
    "status": 0,
    "street": [],
    "super_user_id": 0,
    "telephone": "",
    "vat_tax_id": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/company/", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/company/"

payload = { "company": {
        "city": "",
        "comment": "",
        "company_email": "",
        "company_name": "",
        "country_id": "",
        "customer_group_id": 0,
        "extension_attributes": {
            "applicable_payment_method": 0,
            "available_payment_methods": "",
            "quote_config": {
                "company_id": "",
                "extension_attributes": {},
                "is_quote_enabled": False
            },
            "use_config_settings": 0
        },
        "id": 0,
        "legal_name": "",
        "postcode": "",
        "region": "",
        "region_id": "",
        "reject_reason": "",
        "rejected_at": "",
        "reseller_id": "",
        "sales_representative_id": 0,
        "status": 0,
        "street": [],
        "super_user_id": 0,
        "telephone": "",
        "vat_tax_id": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/company/"

payload <- "{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/company/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\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/V1/company/') do |req|
  req.body = "{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/company/";

    let payload = json!({"company": json!({
            "city": "",
            "comment": "",
            "company_email": "",
            "company_name": "",
            "country_id": "",
            "customer_group_id": 0,
            "extension_attributes": json!({
                "applicable_payment_method": 0,
                "available_payment_methods": "",
                "quote_config": json!({
                    "company_id": "",
                    "extension_attributes": json!({}),
                    "is_quote_enabled": false
                }),
                "use_config_settings": 0
            }),
            "id": 0,
            "legal_name": "",
            "postcode": "",
            "region": "",
            "region_id": "",
            "reject_reason": "",
            "rejected_at": "",
            "reseller_id": "",
            "sales_representative_id": 0,
            "status": 0,
            "street": (),
            "super_user_id": 0,
            "telephone": "",
            "vat_tax_id": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/company/ \
  --header 'content-type: application/json' \
  --data '{
  "company": {
    "city": "",
    "comment": "",
    "company_email": "",
    "company_name": "",
    "country_id": "",
    "customer_group_id": 0,
    "extension_attributes": {
      "applicable_payment_method": 0,
      "available_payment_methods": "",
      "quote_config": {
        "company_id": "",
        "extension_attributes": {},
        "is_quote_enabled": false
      },
      "use_config_settings": 0
    },
    "id": 0,
    "legal_name": "",
    "postcode": "",
    "region": "",
    "region_id": "",
    "reject_reason": "",
    "rejected_at": "",
    "reseller_id": "",
    "sales_representative_id": 0,
    "status": 0,
    "street": [],
    "super_user_id": 0,
    "telephone": "",
    "vat_tax_id": ""
  }
}'
echo '{
  "company": {
    "city": "",
    "comment": "",
    "company_email": "",
    "company_name": "",
    "country_id": "",
    "customer_group_id": 0,
    "extension_attributes": {
      "applicable_payment_method": 0,
      "available_payment_methods": "",
      "quote_config": {
        "company_id": "",
        "extension_attributes": {},
        "is_quote_enabled": false
      },
      "use_config_settings": 0
    },
    "id": 0,
    "legal_name": "",
    "postcode": "",
    "region": "",
    "region_id": "",
    "reject_reason": "",
    "rejected_at": "",
    "reseller_id": "",
    "sales_representative_id": 0,
    "status": 0,
    "street": [],
    "super_user_id": 0,
    "telephone": "",
    "vat_tax_id": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/company/ \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "company": {\n    "city": "",\n    "comment": "",\n    "company_email": "",\n    "company_name": "",\n    "country_id": "",\n    "customer_group_id": 0,\n    "extension_attributes": {\n      "applicable_payment_method": 0,\n      "available_payment_methods": "",\n      "quote_config": {\n        "company_id": "",\n        "extension_attributes": {},\n        "is_quote_enabled": false\n      },\n      "use_config_settings": 0\n    },\n    "id": 0,\n    "legal_name": "",\n    "postcode": "",\n    "region": "",\n    "region_id": "",\n    "reject_reason": "",\n    "rejected_at": "",\n    "reseller_id": "",\n    "sales_representative_id": 0,\n    "status": 0,\n    "street": [],\n    "super_user_id": 0,\n    "telephone": "",\n    "vat_tax_id": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/company/
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["company": [
    "city": "",
    "comment": "",
    "company_email": "",
    "company_name": "",
    "country_id": "",
    "customer_group_id": 0,
    "extension_attributes": [
      "applicable_payment_method": 0,
      "available_payment_methods": "",
      "quote_config": [
        "company_id": "",
        "extension_attributes": [],
        "is_quote_enabled": false
      ],
      "use_config_settings": 0
    ],
    "id": 0,
    "legal_name": "",
    "postcode": "",
    "region": "",
    "region_id": "",
    "reject_reason": "",
    "rejected_at": "",
    "reseller_id": "",
    "sales_representative_id": 0,
    "status": 0,
    "street": [],
    "super_user_id": 0,
    "telephone": "",
    "vat_tax_id": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/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 company-
{{baseUrl}}/V1/company/
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/company/");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/company/")
require "http/client"

url = "{{baseUrl}}/V1/company/"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/company/"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/company/");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/company/"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/company/ HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/company/")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/company/"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/company/")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/company/")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/company/');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/company/'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/company/';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/company/',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/company/")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/company/',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/company/'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/company/');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/company/'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/company/';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/company/"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/company/" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/company/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/company/');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/company/');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/company/');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/company/' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/company/' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/company/")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/company/"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/company/"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/company/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/company/') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/company/";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/company/
http GET {{baseUrl}}/V1/company/
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/company/
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/company/")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET company-{companyId} (GET)
{{baseUrl}}/V1/company/:companyId
QUERY PARAMS

companyId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/company/:companyId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/company/:companyId")
require "http/client"

url = "{{baseUrl}}/V1/company/:companyId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/company/:companyId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/company/:companyId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/company/:companyId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/company/:companyId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/company/:companyId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/company/:companyId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/company/:companyId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/company/:companyId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/company/:companyId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/company/:companyId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/company/:companyId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/company/:companyId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/company/:companyId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/company/:companyId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/company/:companyId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/company/:companyId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/company/:companyId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/company/:companyId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/company/:companyId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/company/:companyId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/company/:companyId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/company/:companyId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/company/:companyId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/company/:companyId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/company/:companyId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/company/:companyId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/company/:companyId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/company/:companyId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/company/:companyId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/company/:companyId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/company/:companyId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/company/:companyId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/company/:companyId
http GET {{baseUrl}}/V1/company/:companyId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/company/:companyId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/company/:companyId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT company-{companyId} (PUT)
{{baseUrl}}/V1/company/:companyId
QUERY PARAMS

companyId
BODY json

{
  "company": {
    "city": "",
    "comment": "",
    "company_email": "",
    "company_name": "",
    "country_id": "",
    "customer_group_id": 0,
    "extension_attributes": {
      "applicable_payment_method": 0,
      "available_payment_methods": "",
      "quote_config": {
        "company_id": "",
        "extension_attributes": {},
        "is_quote_enabled": false
      },
      "use_config_settings": 0
    },
    "id": 0,
    "legal_name": "",
    "postcode": "",
    "region": "",
    "region_id": "",
    "reject_reason": "",
    "rejected_at": "",
    "reseller_id": "",
    "sales_representative_id": 0,
    "status": 0,
    "street": [],
    "super_user_id": 0,
    "telephone": "",
    "vat_tax_id": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/company/:companyId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/company/:companyId" {:content-type :json
                                                                 :form-params {:company {:city ""
                                                                                         :comment ""
                                                                                         :company_email ""
                                                                                         :company_name ""
                                                                                         :country_id ""
                                                                                         :customer_group_id 0
                                                                                         :extension_attributes {:applicable_payment_method 0
                                                                                                                :available_payment_methods ""
                                                                                                                :quote_config {:company_id ""
                                                                                                                               :extension_attributes {}
                                                                                                                               :is_quote_enabled false}
                                                                                                                :use_config_settings 0}
                                                                                         :id 0
                                                                                         :legal_name ""
                                                                                         :postcode ""
                                                                                         :region ""
                                                                                         :region_id ""
                                                                                         :reject_reason ""
                                                                                         :rejected_at ""
                                                                                         :reseller_id ""
                                                                                         :sales_representative_id 0
                                                                                         :status 0
                                                                                         :street []
                                                                                         :super_user_id 0
                                                                                         :telephone ""
                                                                                         :vat_tax_id ""}}})
require "http/client"

url = "{{baseUrl}}/V1/company/:companyId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\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}}/V1/company/:companyId"),
    Content = new StringContent("{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\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}}/V1/company/:companyId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/company/:companyId"

	payload := strings.NewReader("{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/company/:companyId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 730

{
  "company": {
    "city": "",
    "comment": "",
    "company_email": "",
    "company_name": "",
    "country_id": "",
    "customer_group_id": 0,
    "extension_attributes": {
      "applicable_payment_method": 0,
      "available_payment_methods": "",
      "quote_config": {
        "company_id": "",
        "extension_attributes": {},
        "is_quote_enabled": false
      },
      "use_config_settings": 0
    },
    "id": 0,
    "legal_name": "",
    "postcode": "",
    "region": "",
    "region_id": "",
    "reject_reason": "",
    "rejected_at": "",
    "reseller_id": "",
    "sales_representative_id": 0,
    "status": 0,
    "street": [],
    "super_user_id": 0,
    "telephone": "",
    "vat_tax_id": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/company/:companyId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/company/:companyId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\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  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/company/:companyId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/company/:companyId")
  .header("content-type", "application/json")
  .body("{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  company: {
    city: '',
    comment: '',
    company_email: '',
    company_name: '',
    country_id: '',
    customer_group_id: 0,
    extension_attributes: {
      applicable_payment_method: 0,
      available_payment_methods: '',
      quote_config: {
        company_id: '',
        extension_attributes: {},
        is_quote_enabled: false
      },
      use_config_settings: 0
    },
    id: 0,
    legal_name: '',
    postcode: '',
    region: '',
    region_id: '',
    reject_reason: '',
    rejected_at: '',
    reseller_id: '',
    sales_representative_id: 0,
    status: 0,
    street: [],
    super_user_id: 0,
    telephone: '',
    vat_tax_id: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/company/:companyId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/company/:companyId',
  headers: {'content-type': 'application/json'},
  data: {
    company: {
      city: '',
      comment: '',
      company_email: '',
      company_name: '',
      country_id: '',
      customer_group_id: 0,
      extension_attributes: {
        applicable_payment_method: 0,
        available_payment_methods: '',
        quote_config: {company_id: '', extension_attributes: {}, is_quote_enabled: false},
        use_config_settings: 0
      },
      id: 0,
      legal_name: '',
      postcode: '',
      region: '',
      region_id: '',
      reject_reason: '',
      rejected_at: '',
      reseller_id: '',
      sales_representative_id: 0,
      status: 0,
      street: [],
      super_user_id: 0,
      telephone: '',
      vat_tax_id: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/company/:companyId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"company":{"city":"","comment":"","company_email":"","company_name":"","country_id":"","customer_group_id":0,"extension_attributes":{"applicable_payment_method":0,"available_payment_methods":"","quote_config":{"company_id":"","extension_attributes":{},"is_quote_enabled":false},"use_config_settings":0},"id":0,"legal_name":"","postcode":"","region":"","region_id":"","reject_reason":"","rejected_at":"","reseller_id":"","sales_representative_id":0,"status":0,"street":[],"super_user_id":0,"telephone":"","vat_tax_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}}/V1/company/:companyId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "company": {\n    "city": "",\n    "comment": "",\n    "company_email": "",\n    "company_name": "",\n    "country_id": "",\n    "customer_group_id": 0,\n    "extension_attributes": {\n      "applicable_payment_method": 0,\n      "available_payment_methods": "",\n      "quote_config": {\n        "company_id": "",\n        "extension_attributes": {},\n        "is_quote_enabled": false\n      },\n      "use_config_settings": 0\n    },\n    "id": 0,\n    "legal_name": "",\n    "postcode": "",\n    "region": "",\n    "region_id": "",\n    "reject_reason": "",\n    "rejected_at": "",\n    "reseller_id": "",\n    "sales_representative_id": 0,\n    "status": 0,\n    "street": [],\n    "super_user_id": 0,\n    "telephone": "",\n    "vat_tax_id": ""\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  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/company/:companyId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/company/:companyId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  company: {
    city: '',
    comment: '',
    company_email: '',
    company_name: '',
    country_id: '',
    customer_group_id: 0,
    extension_attributes: {
      applicable_payment_method: 0,
      available_payment_methods: '',
      quote_config: {company_id: '', extension_attributes: {}, is_quote_enabled: false},
      use_config_settings: 0
    },
    id: 0,
    legal_name: '',
    postcode: '',
    region: '',
    region_id: '',
    reject_reason: '',
    rejected_at: '',
    reseller_id: '',
    sales_representative_id: 0,
    status: 0,
    street: [],
    super_user_id: 0,
    telephone: '',
    vat_tax_id: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/company/:companyId',
  headers: {'content-type': 'application/json'},
  body: {
    company: {
      city: '',
      comment: '',
      company_email: '',
      company_name: '',
      country_id: '',
      customer_group_id: 0,
      extension_attributes: {
        applicable_payment_method: 0,
        available_payment_methods: '',
        quote_config: {company_id: '', extension_attributes: {}, is_quote_enabled: false},
        use_config_settings: 0
      },
      id: 0,
      legal_name: '',
      postcode: '',
      region: '',
      region_id: '',
      reject_reason: '',
      rejected_at: '',
      reseller_id: '',
      sales_representative_id: 0,
      status: 0,
      street: [],
      super_user_id: 0,
      telephone: '',
      vat_tax_id: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/company/:companyId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  company: {
    city: '',
    comment: '',
    company_email: '',
    company_name: '',
    country_id: '',
    customer_group_id: 0,
    extension_attributes: {
      applicable_payment_method: 0,
      available_payment_methods: '',
      quote_config: {
        company_id: '',
        extension_attributes: {},
        is_quote_enabled: false
      },
      use_config_settings: 0
    },
    id: 0,
    legal_name: '',
    postcode: '',
    region: '',
    region_id: '',
    reject_reason: '',
    rejected_at: '',
    reseller_id: '',
    sales_representative_id: 0,
    status: 0,
    street: [],
    super_user_id: 0,
    telephone: '',
    vat_tax_id: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/company/:companyId',
  headers: {'content-type': 'application/json'},
  data: {
    company: {
      city: '',
      comment: '',
      company_email: '',
      company_name: '',
      country_id: '',
      customer_group_id: 0,
      extension_attributes: {
        applicable_payment_method: 0,
        available_payment_methods: '',
        quote_config: {company_id: '', extension_attributes: {}, is_quote_enabled: false},
        use_config_settings: 0
      },
      id: 0,
      legal_name: '',
      postcode: '',
      region: '',
      region_id: '',
      reject_reason: '',
      rejected_at: '',
      reseller_id: '',
      sales_representative_id: 0,
      status: 0,
      street: [],
      super_user_id: 0,
      telephone: '',
      vat_tax_id: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/company/:companyId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"company":{"city":"","comment":"","company_email":"","company_name":"","country_id":"","customer_group_id":0,"extension_attributes":{"applicable_payment_method":0,"available_payment_methods":"","quote_config":{"company_id":"","extension_attributes":{},"is_quote_enabled":false},"use_config_settings":0},"id":0,"legal_name":"","postcode":"","region":"","region_id":"","reject_reason":"","rejected_at":"","reseller_id":"","sales_representative_id":0,"status":0,"street":[],"super_user_id":0,"telephone":"","vat_tax_id":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"company": @{ @"city": @"", @"comment": @"", @"company_email": @"", @"company_name": @"", @"country_id": @"", @"customer_group_id": @0, @"extension_attributes": @{ @"applicable_payment_method": @0, @"available_payment_methods": @"", @"quote_config": @{ @"company_id": @"", @"extension_attributes": @{  }, @"is_quote_enabled": @NO }, @"use_config_settings": @0 }, @"id": @0, @"legal_name": @"", @"postcode": @"", @"region": @"", @"region_id": @"", @"reject_reason": @"", @"rejected_at": @"", @"reseller_id": @"", @"sales_representative_id": @0, @"status": @0, @"street": @[  ], @"super_user_id": @0, @"telephone": @"", @"vat_tax_id": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/company/:companyId"]
                                                       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}}/V1/company/:companyId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/company/:companyId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'company' => [
        'city' => '',
        'comment' => '',
        'company_email' => '',
        'company_name' => '',
        'country_id' => '',
        'customer_group_id' => 0,
        'extension_attributes' => [
                'applicable_payment_method' => 0,
                'available_payment_methods' => '',
                'quote_config' => [
                                'company_id' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'is_quote_enabled' => null
                ],
                'use_config_settings' => 0
        ],
        'id' => 0,
        'legal_name' => '',
        'postcode' => '',
        'region' => '',
        'region_id' => '',
        'reject_reason' => '',
        'rejected_at' => '',
        'reseller_id' => '',
        'sales_representative_id' => 0,
        'status' => 0,
        'street' => [
                
        ],
        'super_user_id' => 0,
        'telephone' => '',
        'vat_tax_id' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/company/:companyId', [
  'body' => '{
  "company": {
    "city": "",
    "comment": "",
    "company_email": "",
    "company_name": "",
    "country_id": "",
    "customer_group_id": 0,
    "extension_attributes": {
      "applicable_payment_method": 0,
      "available_payment_methods": "",
      "quote_config": {
        "company_id": "",
        "extension_attributes": {},
        "is_quote_enabled": false
      },
      "use_config_settings": 0
    },
    "id": 0,
    "legal_name": "",
    "postcode": "",
    "region": "",
    "region_id": "",
    "reject_reason": "",
    "rejected_at": "",
    "reseller_id": "",
    "sales_representative_id": 0,
    "status": 0,
    "street": [],
    "super_user_id": 0,
    "telephone": "",
    "vat_tax_id": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/company/:companyId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'company' => [
    'city' => '',
    'comment' => '',
    'company_email' => '',
    'company_name' => '',
    'country_id' => '',
    'customer_group_id' => 0,
    'extension_attributes' => [
        'applicable_payment_method' => 0,
        'available_payment_methods' => '',
        'quote_config' => [
                'company_id' => '',
                'extension_attributes' => [
                                
                ],
                'is_quote_enabled' => null
        ],
        'use_config_settings' => 0
    ],
    'id' => 0,
    'legal_name' => '',
    'postcode' => '',
    'region' => '',
    'region_id' => '',
    'reject_reason' => '',
    'rejected_at' => '',
    'reseller_id' => '',
    'sales_representative_id' => 0,
    'status' => 0,
    'street' => [
        
    ],
    'super_user_id' => 0,
    'telephone' => '',
    'vat_tax_id' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'company' => [
    'city' => '',
    'comment' => '',
    'company_email' => '',
    'company_name' => '',
    'country_id' => '',
    'customer_group_id' => 0,
    'extension_attributes' => [
        'applicable_payment_method' => 0,
        'available_payment_methods' => '',
        'quote_config' => [
                'company_id' => '',
                'extension_attributes' => [
                                
                ],
                'is_quote_enabled' => null
        ],
        'use_config_settings' => 0
    ],
    'id' => 0,
    'legal_name' => '',
    'postcode' => '',
    'region' => '',
    'region_id' => '',
    'reject_reason' => '',
    'rejected_at' => '',
    'reseller_id' => '',
    'sales_representative_id' => 0,
    'status' => 0,
    'street' => [
        
    ],
    'super_user_id' => 0,
    'telephone' => '',
    'vat_tax_id' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/company/:companyId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/company/:companyId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "company": {
    "city": "",
    "comment": "",
    "company_email": "",
    "company_name": "",
    "country_id": "",
    "customer_group_id": 0,
    "extension_attributes": {
      "applicable_payment_method": 0,
      "available_payment_methods": "",
      "quote_config": {
        "company_id": "",
        "extension_attributes": {},
        "is_quote_enabled": false
      },
      "use_config_settings": 0
    },
    "id": 0,
    "legal_name": "",
    "postcode": "",
    "region": "",
    "region_id": "",
    "reject_reason": "",
    "rejected_at": "",
    "reseller_id": "",
    "sales_representative_id": 0,
    "status": 0,
    "street": [],
    "super_user_id": 0,
    "telephone": "",
    "vat_tax_id": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/company/:companyId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "company": {
    "city": "",
    "comment": "",
    "company_email": "",
    "company_name": "",
    "country_id": "",
    "customer_group_id": 0,
    "extension_attributes": {
      "applicable_payment_method": 0,
      "available_payment_methods": "",
      "quote_config": {
        "company_id": "",
        "extension_attributes": {},
        "is_quote_enabled": false
      },
      "use_config_settings": 0
    },
    "id": 0,
    "legal_name": "",
    "postcode": "",
    "region": "",
    "region_id": "",
    "reject_reason": "",
    "rejected_at": "",
    "reseller_id": "",
    "sales_representative_id": 0,
    "status": 0,
    "street": [],
    "super_user_id": 0,
    "telephone": "",
    "vat_tax_id": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/company/:companyId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/company/:companyId"

payload = { "company": {
        "city": "",
        "comment": "",
        "company_email": "",
        "company_name": "",
        "country_id": "",
        "customer_group_id": 0,
        "extension_attributes": {
            "applicable_payment_method": 0,
            "available_payment_methods": "",
            "quote_config": {
                "company_id": "",
                "extension_attributes": {},
                "is_quote_enabled": False
            },
            "use_config_settings": 0
        },
        "id": 0,
        "legal_name": "",
        "postcode": "",
        "region": "",
        "region_id": "",
        "reject_reason": "",
        "rejected_at": "",
        "reseller_id": "",
        "sales_representative_id": 0,
        "status": 0,
        "street": [],
        "super_user_id": 0,
        "telephone": "",
        "vat_tax_id": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/company/:companyId"

payload <- "{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/company/:companyId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\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/V1/company/:companyId') do |req|
  req.body = "{\n  \"company\": {\n    \"city\": \"\",\n    \"comment\": \"\",\n    \"company_email\": \"\",\n    \"company_name\": \"\",\n    \"country_id\": \"\",\n    \"customer_group_id\": 0,\n    \"extension_attributes\": {\n      \"applicable_payment_method\": 0,\n      \"available_payment_methods\": \"\",\n      \"quote_config\": {\n        \"company_id\": \"\",\n        \"extension_attributes\": {},\n        \"is_quote_enabled\": false\n      },\n      \"use_config_settings\": 0\n    },\n    \"id\": 0,\n    \"legal_name\": \"\",\n    \"postcode\": \"\",\n    \"region\": \"\",\n    \"region_id\": \"\",\n    \"reject_reason\": \"\",\n    \"rejected_at\": \"\",\n    \"reseller_id\": \"\",\n    \"sales_representative_id\": 0,\n    \"status\": 0,\n    \"street\": [],\n    \"super_user_id\": 0,\n    \"telephone\": \"\",\n    \"vat_tax_id\": \"\"\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}}/V1/company/:companyId";

    let payload = json!({"company": json!({
            "city": "",
            "comment": "",
            "company_email": "",
            "company_name": "",
            "country_id": "",
            "customer_group_id": 0,
            "extension_attributes": json!({
                "applicable_payment_method": 0,
                "available_payment_methods": "",
                "quote_config": json!({
                    "company_id": "",
                    "extension_attributes": json!({}),
                    "is_quote_enabled": false
                }),
                "use_config_settings": 0
            }),
            "id": 0,
            "legal_name": "",
            "postcode": "",
            "region": "",
            "region_id": "",
            "reject_reason": "",
            "rejected_at": "",
            "reseller_id": "",
            "sales_representative_id": 0,
            "status": 0,
            "street": (),
            "super_user_id": 0,
            "telephone": "",
            "vat_tax_id": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/company/:companyId \
  --header 'content-type: application/json' \
  --data '{
  "company": {
    "city": "",
    "comment": "",
    "company_email": "",
    "company_name": "",
    "country_id": "",
    "customer_group_id": 0,
    "extension_attributes": {
      "applicable_payment_method": 0,
      "available_payment_methods": "",
      "quote_config": {
        "company_id": "",
        "extension_attributes": {},
        "is_quote_enabled": false
      },
      "use_config_settings": 0
    },
    "id": 0,
    "legal_name": "",
    "postcode": "",
    "region": "",
    "region_id": "",
    "reject_reason": "",
    "rejected_at": "",
    "reseller_id": "",
    "sales_representative_id": 0,
    "status": 0,
    "street": [],
    "super_user_id": 0,
    "telephone": "",
    "vat_tax_id": ""
  }
}'
echo '{
  "company": {
    "city": "",
    "comment": "",
    "company_email": "",
    "company_name": "",
    "country_id": "",
    "customer_group_id": 0,
    "extension_attributes": {
      "applicable_payment_method": 0,
      "available_payment_methods": "",
      "quote_config": {
        "company_id": "",
        "extension_attributes": {},
        "is_quote_enabled": false
      },
      "use_config_settings": 0
    },
    "id": 0,
    "legal_name": "",
    "postcode": "",
    "region": "",
    "region_id": "",
    "reject_reason": "",
    "rejected_at": "",
    "reseller_id": "",
    "sales_representative_id": 0,
    "status": 0,
    "street": [],
    "super_user_id": 0,
    "telephone": "",
    "vat_tax_id": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/company/:companyId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "company": {\n    "city": "",\n    "comment": "",\n    "company_email": "",\n    "company_name": "",\n    "country_id": "",\n    "customer_group_id": 0,\n    "extension_attributes": {\n      "applicable_payment_method": 0,\n      "available_payment_methods": "",\n      "quote_config": {\n        "company_id": "",\n        "extension_attributes": {},\n        "is_quote_enabled": false\n      },\n      "use_config_settings": 0\n    },\n    "id": 0,\n    "legal_name": "",\n    "postcode": "",\n    "region": "",\n    "region_id": "",\n    "reject_reason": "",\n    "rejected_at": "",\n    "reseller_id": "",\n    "sales_representative_id": 0,\n    "status": 0,\n    "street": [],\n    "super_user_id": 0,\n    "telephone": "",\n    "vat_tax_id": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/company/:companyId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["company": [
    "city": "",
    "comment": "",
    "company_email": "",
    "company_name": "",
    "country_id": "",
    "customer_group_id": 0,
    "extension_attributes": [
      "applicable_payment_method": 0,
      "available_payment_methods": "",
      "quote_config": [
        "company_id": "",
        "extension_attributes": [],
        "is_quote_enabled": false
      ],
      "use_config_settings": 0
    ],
    "id": 0,
    "legal_name": "",
    "postcode": "",
    "region": "",
    "region_id": "",
    "reject_reason": "",
    "rejected_at": "",
    "reseller_id": "",
    "sales_representative_id": 0,
    "status": 0,
    "street": [],
    "super_user_id": 0,
    "telephone": "",
    "vat_tax_id": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/company/:companyId")! 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()
DELETE company-{companyId}
{{baseUrl}}/V1/company/:companyId
QUERY PARAMS

companyId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/company/:companyId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/company/:companyId")
require "http/client"

url = "{{baseUrl}}/V1/company/:companyId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/company/:companyId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/company/:companyId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/company/:companyId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/company/:companyId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/company/:companyId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/company/:companyId"))
    .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}}/V1/company/:companyId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/company/:companyId")
  .asString();
const 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}}/V1/company/:companyId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/company/:companyId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/company/:companyId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/company/:companyId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/company/:companyId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/company/:companyId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/company/:companyId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/company/:companyId');

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}}/V1/company/:companyId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/company/:companyId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/company/:companyId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/company/:companyId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/company/:companyId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/company/:companyId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/company/:companyId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/company/:companyId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/company/:companyId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/company/:companyId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/company/:companyId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/company/:companyId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/company/:companyId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/company/:companyId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/company/:companyId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/company/:companyId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/company/:companyId
http DELETE {{baseUrl}}/V1/company/:companyId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/company/:companyId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/company/:companyId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT company-assignRoles
{{baseUrl}}/V1/company/assignRoles
BODY json

{
  "roles": [
    {
      "company_id": 0,
      "extension_attributes": {},
      "id": 0,
      "permissions": [
        {
          "id": 0,
          "permission": "",
          "resource_id": "",
          "role_id": 0
        }
      ],
      "role_name": ""
    }
  ],
  "userId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/company/assignRoles");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"roles\": [\n    {\n      \"company_id\": 0,\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"permissions\": [\n        {\n          \"id\": 0,\n          \"permission\": \"\",\n          \"resource_id\": \"\",\n          \"role_id\": 0\n        }\n      ],\n      \"role_name\": \"\"\n    }\n  ],\n  \"userId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/company/assignRoles" {:content-type :json
                                                                  :form-params {:roles [{:company_id 0
                                                                                         :extension_attributes {}
                                                                                         :id 0
                                                                                         :permissions [{:id 0
                                                                                                        :permission ""
                                                                                                        :resource_id ""
                                                                                                        :role_id 0}]
                                                                                         :role_name ""}]
                                                                                :userId 0}})
require "http/client"

url = "{{baseUrl}}/V1/company/assignRoles"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"roles\": [\n    {\n      \"company_id\": 0,\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"permissions\": [\n        {\n          \"id\": 0,\n          \"permission\": \"\",\n          \"resource_id\": \"\",\n          \"role_id\": 0\n        }\n      ],\n      \"role_name\": \"\"\n    }\n  ],\n  \"userId\": 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}}/V1/company/assignRoles"),
    Content = new StringContent("{\n  \"roles\": [\n    {\n      \"company_id\": 0,\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"permissions\": [\n        {\n          \"id\": 0,\n          \"permission\": \"\",\n          \"resource_id\": \"\",\n          \"role_id\": 0\n        }\n      ],\n      \"role_name\": \"\"\n    }\n  ],\n  \"userId\": 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}}/V1/company/assignRoles");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"roles\": [\n    {\n      \"company_id\": 0,\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"permissions\": [\n        {\n          \"id\": 0,\n          \"permission\": \"\",\n          \"resource_id\": \"\",\n          \"role_id\": 0\n        }\n      ],\n      \"role_name\": \"\"\n    }\n  ],\n  \"userId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/company/assignRoles"

	payload := strings.NewReader("{\n  \"roles\": [\n    {\n      \"company_id\": 0,\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"permissions\": [\n        {\n          \"id\": 0,\n          \"permission\": \"\",\n          \"resource_id\": \"\",\n          \"role_id\": 0\n        }\n      ],\n      \"role_name\": \"\"\n    }\n  ],\n  \"userId\": 0\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/company/assignRoles HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 292

{
  "roles": [
    {
      "company_id": 0,
      "extension_attributes": {},
      "id": 0,
      "permissions": [
        {
          "id": 0,
          "permission": "",
          "resource_id": "",
          "role_id": 0
        }
      ],
      "role_name": ""
    }
  ],
  "userId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/company/assignRoles")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"roles\": [\n    {\n      \"company_id\": 0,\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"permissions\": [\n        {\n          \"id\": 0,\n          \"permission\": \"\",\n          \"resource_id\": \"\",\n          \"role_id\": 0\n        }\n      ],\n      \"role_name\": \"\"\n    }\n  ],\n  \"userId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/company/assignRoles"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"roles\": [\n    {\n      \"company_id\": 0,\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"permissions\": [\n        {\n          \"id\": 0,\n          \"permission\": \"\",\n          \"resource_id\": \"\",\n          \"role_id\": 0\n        }\n      ],\n      \"role_name\": \"\"\n    }\n  ],\n  \"userId\": 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  \"roles\": [\n    {\n      \"company_id\": 0,\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"permissions\": [\n        {\n          \"id\": 0,\n          \"permission\": \"\",\n          \"resource_id\": \"\",\n          \"role_id\": 0\n        }\n      ],\n      \"role_name\": \"\"\n    }\n  ],\n  \"userId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/company/assignRoles")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/company/assignRoles")
  .header("content-type", "application/json")
  .body("{\n  \"roles\": [\n    {\n      \"company_id\": 0,\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"permissions\": [\n        {\n          \"id\": 0,\n          \"permission\": \"\",\n          \"resource_id\": \"\",\n          \"role_id\": 0\n        }\n      ],\n      \"role_name\": \"\"\n    }\n  ],\n  \"userId\": 0\n}")
  .asString();
const data = JSON.stringify({
  roles: [
    {
      company_id: 0,
      extension_attributes: {},
      id: 0,
      permissions: [
        {
          id: 0,
          permission: '',
          resource_id: '',
          role_id: 0
        }
      ],
      role_name: ''
    }
  ],
  userId: 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}}/V1/company/assignRoles');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/company/assignRoles',
  headers: {'content-type': 'application/json'},
  data: {
    roles: [
      {
        company_id: 0,
        extension_attributes: {},
        id: 0,
        permissions: [{id: 0, permission: '', resource_id: '', role_id: 0}],
        role_name: ''
      }
    ],
    userId: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/company/assignRoles';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"roles":[{"company_id":0,"extension_attributes":{},"id":0,"permissions":[{"id":0,"permission":"","resource_id":"","role_id":0}],"role_name":""}],"userId":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}}/V1/company/assignRoles',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "roles": [\n    {\n      "company_id": 0,\n      "extension_attributes": {},\n      "id": 0,\n      "permissions": [\n        {\n          "id": 0,\n          "permission": "",\n          "resource_id": "",\n          "role_id": 0\n        }\n      ],\n      "role_name": ""\n    }\n  ],\n  "userId": 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  \"roles\": [\n    {\n      \"company_id\": 0,\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"permissions\": [\n        {\n          \"id\": 0,\n          \"permission\": \"\",\n          \"resource_id\": \"\",\n          \"role_id\": 0\n        }\n      ],\n      \"role_name\": \"\"\n    }\n  ],\n  \"userId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/company/assignRoles")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/company/assignRoles',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  roles: [
    {
      company_id: 0,
      extension_attributes: {},
      id: 0,
      permissions: [{id: 0, permission: '', resource_id: '', role_id: 0}],
      role_name: ''
    }
  ],
  userId: 0
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/company/assignRoles',
  headers: {'content-type': 'application/json'},
  body: {
    roles: [
      {
        company_id: 0,
        extension_attributes: {},
        id: 0,
        permissions: [{id: 0, permission: '', resource_id: '', role_id: 0}],
        role_name: ''
      }
    ],
    userId: 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}}/V1/company/assignRoles');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  roles: [
    {
      company_id: 0,
      extension_attributes: {},
      id: 0,
      permissions: [
        {
          id: 0,
          permission: '',
          resource_id: '',
          role_id: 0
        }
      ],
      role_name: ''
    }
  ],
  userId: 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}}/V1/company/assignRoles',
  headers: {'content-type': 'application/json'},
  data: {
    roles: [
      {
        company_id: 0,
        extension_attributes: {},
        id: 0,
        permissions: [{id: 0, permission: '', resource_id: '', role_id: 0}],
        role_name: ''
      }
    ],
    userId: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/company/assignRoles';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"roles":[{"company_id":0,"extension_attributes":{},"id":0,"permissions":[{"id":0,"permission":"","resource_id":"","role_id":0}],"role_name":""}],"userId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"roles": @[ @{ @"company_id": @0, @"extension_attributes": @{  }, @"id": @0, @"permissions": @[ @{ @"id": @0, @"permission": @"", @"resource_id": @"", @"role_id": @0 } ], @"role_name": @"" } ],
                              @"userId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/company/assignRoles"]
                                                       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}}/V1/company/assignRoles" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"roles\": [\n    {\n      \"company_id\": 0,\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"permissions\": [\n        {\n          \"id\": 0,\n          \"permission\": \"\",\n          \"resource_id\": \"\",\n          \"role_id\": 0\n        }\n      ],\n      \"role_name\": \"\"\n    }\n  ],\n  \"userId\": 0\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/company/assignRoles",
  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([
    'roles' => [
        [
                'company_id' => 0,
                'extension_attributes' => [
                                
                ],
                'id' => 0,
                'permissions' => [
                                [
                                                                'id' => 0,
                                                                'permission' => '',
                                                                'resource_id' => '',
                                                                'role_id' => 0
                                ]
                ],
                'role_name' => ''
        ]
    ],
    'userId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/company/assignRoles', [
  'body' => '{
  "roles": [
    {
      "company_id": 0,
      "extension_attributes": {},
      "id": 0,
      "permissions": [
        {
          "id": 0,
          "permission": "",
          "resource_id": "",
          "role_id": 0
        }
      ],
      "role_name": ""
    }
  ],
  "userId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/company/assignRoles');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'roles' => [
    [
        'company_id' => 0,
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'permissions' => [
                [
                                'id' => 0,
                                'permission' => '',
                                'resource_id' => '',
                                'role_id' => 0
                ]
        ],
        'role_name' => ''
    ]
  ],
  'userId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'roles' => [
    [
        'company_id' => 0,
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'permissions' => [
                [
                                'id' => 0,
                                'permission' => '',
                                'resource_id' => '',
                                'role_id' => 0
                ]
        ],
        'role_name' => ''
    ]
  ],
  'userId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/company/assignRoles');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/company/assignRoles' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "roles": [
    {
      "company_id": 0,
      "extension_attributes": {},
      "id": 0,
      "permissions": [
        {
          "id": 0,
          "permission": "",
          "resource_id": "",
          "role_id": 0
        }
      ],
      "role_name": ""
    }
  ],
  "userId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/company/assignRoles' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "roles": [
    {
      "company_id": 0,
      "extension_attributes": {},
      "id": 0,
      "permissions": [
        {
          "id": 0,
          "permission": "",
          "resource_id": "",
          "role_id": 0
        }
      ],
      "role_name": ""
    }
  ],
  "userId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"roles\": [\n    {\n      \"company_id\": 0,\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"permissions\": [\n        {\n          \"id\": 0,\n          \"permission\": \"\",\n          \"resource_id\": \"\",\n          \"role_id\": 0\n        }\n      ],\n      \"role_name\": \"\"\n    }\n  ],\n  \"userId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/company/assignRoles", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/company/assignRoles"

payload = {
    "roles": [
        {
            "company_id": 0,
            "extension_attributes": {},
            "id": 0,
            "permissions": [
                {
                    "id": 0,
                    "permission": "",
                    "resource_id": "",
                    "role_id": 0
                }
            ],
            "role_name": ""
        }
    ],
    "userId": 0
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/company/assignRoles"

payload <- "{\n  \"roles\": [\n    {\n      \"company_id\": 0,\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"permissions\": [\n        {\n          \"id\": 0,\n          \"permission\": \"\",\n          \"resource_id\": \"\",\n          \"role_id\": 0\n        }\n      ],\n      \"role_name\": \"\"\n    }\n  ],\n  \"userId\": 0\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/company/assignRoles")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"roles\": [\n    {\n      \"company_id\": 0,\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"permissions\": [\n        {\n          \"id\": 0,\n          \"permission\": \"\",\n          \"resource_id\": \"\",\n          \"role_id\": 0\n        }\n      ],\n      \"role_name\": \"\"\n    }\n  ],\n  \"userId\": 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/V1/company/assignRoles') do |req|
  req.body = "{\n  \"roles\": [\n    {\n      \"company_id\": 0,\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"permissions\": [\n        {\n          \"id\": 0,\n          \"permission\": \"\",\n          \"resource_id\": \"\",\n          \"role_id\": 0\n        }\n      ],\n      \"role_name\": \"\"\n    }\n  ],\n  \"userId\": 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}}/V1/company/assignRoles";

    let payload = json!({
        "roles": (
            json!({
                "company_id": 0,
                "extension_attributes": json!({}),
                "id": 0,
                "permissions": (
                    json!({
                        "id": 0,
                        "permission": "",
                        "resource_id": "",
                        "role_id": 0
                    })
                ),
                "role_name": ""
            })
        ),
        "userId": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/company/assignRoles \
  --header 'content-type: application/json' \
  --data '{
  "roles": [
    {
      "company_id": 0,
      "extension_attributes": {},
      "id": 0,
      "permissions": [
        {
          "id": 0,
          "permission": "",
          "resource_id": "",
          "role_id": 0
        }
      ],
      "role_name": ""
    }
  ],
  "userId": 0
}'
echo '{
  "roles": [
    {
      "company_id": 0,
      "extension_attributes": {},
      "id": 0,
      "permissions": [
        {
          "id": 0,
          "permission": "",
          "resource_id": "",
          "role_id": 0
        }
      ],
      "role_name": ""
    }
  ],
  "userId": 0
}' |  \
  http PUT {{baseUrl}}/V1/company/assignRoles \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "roles": [\n    {\n      "company_id": 0,\n      "extension_attributes": {},\n      "id": 0,\n      "permissions": [\n        {\n          "id": 0,\n          "permission": "",\n          "resource_id": "",\n          "role_id": 0\n        }\n      ],\n      "role_name": ""\n    }\n  ],\n  "userId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/company/assignRoles
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "roles": [
    [
      "company_id": 0,
      "extension_attributes": [],
      "id": 0,
      "permissions": [
        [
          "id": 0,
          "permission": "",
          "resource_id": "",
          "role_id": 0
        ]
      ],
      "role_name": ""
    ]
  ],
  "userId": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/company/assignRoles")! 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 company-role- (POST)
{{baseUrl}}/V1/company/role/
BODY json

{
  "role": {
    "company_id": 0,
    "extension_attributes": {},
    "id": 0,
    "permissions": [
      {
        "id": 0,
        "permission": "",
        "resource_id": "",
        "role_id": 0
      }
    ],
    "role_name": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/company/role/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/company/role/" {:content-type :json
                                                             :form-params {:role {:company_id 0
                                                                                  :extension_attributes {}
                                                                                  :id 0
                                                                                  :permissions [{:id 0
                                                                                                 :permission ""
                                                                                                 :resource_id ""
                                                                                                 :role_id 0}]
                                                                                  :role_name ""}}})
require "http/client"

url = "{{baseUrl}}/V1/company/role/"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\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}}/V1/company/role/"),
    Content = new StringContent("{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\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}}/V1/company/role/");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/company/role/"

	payload := strings.NewReader("{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/company/role/ HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 240

{
  "role": {
    "company_id": 0,
    "extension_attributes": {},
    "id": 0,
    "permissions": [
      {
        "id": 0,
        "permission": "",
        "resource_id": "",
        "role_id": 0
      }
    ],
    "role_name": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/company/role/")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/company/role/"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\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  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/company/role/")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/company/role/")
  .header("content-type", "application/json")
  .body("{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  role: {
    company_id: 0,
    extension_attributes: {},
    id: 0,
    permissions: [
      {
        id: 0,
        permission: '',
        resource_id: '',
        role_id: 0
      }
    ],
    role_name: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/company/role/');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/company/role/',
  headers: {'content-type': 'application/json'},
  data: {
    role: {
      company_id: 0,
      extension_attributes: {},
      id: 0,
      permissions: [{id: 0, permission: '', resource_id: '', role_id: 0}],
      role_name: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/company/role/';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"role":{"company_id":0,"extension_attributes":{},"id":0,"permissions":[{"id":0,"permission":"","resource_id":"","role_id":0}],"role_name":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/company/role/',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "role": {\n    "company_id": 0,\n    "extension_attributes": {},\n    "id": 0,\n    "permissions": [\n      {\n        "id": 0,\n        "permission": "",\n        "resource_id": "",\n        "role_id": 0\n      }\n    ],\n    "role_name": ""\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  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/company/role/")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/company/role/',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  role: {
    company_id: 0,
    extension_attributes: {},
    id: 0,
    permissions: [{id: 0, permission: '', resource_id: '', role_id: 0}],
    role_name: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/company/role/',
  headers: {'content-type': 'application/json'},
  body: {
    role: {
      company_id: 0,
      extension_attributes: {},
      id: 0,
      permissions: [{id: 0, permission: '', resource_id: '', role_id: 0}],
      role_name: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/company/role/');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  role: {
    company_id: 0,
    extension_attributes: {},
    id: 0,
    permissions: [
      {
        id: 0,
        permission: '',
        resource_id: '',
        role_id: 0
      }
    ],
    role_name: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/company/role/',
  headers: {'content-type': 'application/json'},
  data: {
    role: {
      company_id: 0,
      extension_attributes: {},
      id: 0,
      permissions: [{id: 0, permission: '', resource_id: '', role_id: 0}],
      role_name: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/company/role/';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"role":{"company_id":0,"extension_attributes":{},"id":0,"permissions":[{"id":0,"permission":"","resource_id":"","role_id":0}],"role_name":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"role": @{ @"company_id": @0, @"extension_attributes": @{  }, @"id": @0, @"permissions": @[ @{ @"id": @0, @"permission": @"", @"resource_id": @"", @"role_id": @0 } ], @"role_name": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/company/role/"]
                                                       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}}/V1/company/role/" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/company/role/",
  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([
    'role' => [
        'company_id' => 0,
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'permissions' => [
                [
                                'id' => 0,
                                'permission' => '',
                                'resource_id' => '',
                                'role_id' => 0
                ]
        ],
        'role_name' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/company/role/', [
  'body' => '{
  "role": {
    "company_id": 0,
    "extension_attributes": {},
    "id": 0,
    "permissions": [
      {
        "id": 0,
        "permission": "",
        "resource_id": "",
        "role_id": 0
      }
    ],
    "role_name": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/company/role/');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'role' => [
    'company_id' => 0,
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'permissions' => [
        [
                'id' => 0,
                'permission' => '',
                'resource_id' => '',
                'role_id' => 0
        ]
    ],
    'role_name' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'role' => [
    'company_id' => 0,
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'permissions' => [
        [
                'id' => 0,
                'permission' => '',
                'resource_id' => '',
                'role_id' => 0
        ]
    ],
    'role_name' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/company/role/');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/company/role/' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "role": {
    "company_id": 0,
    "extension_attributes": {},
    "id": 0,
    "permissions": [
      {
        "id": 0,
        "permission": "",
        "resource_id": "",
        "role_id": 0
      }
    ],
    "role_name": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/company/role/' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "role": {
    "company_id": 0,
    "extension_attributes": {},
    "id": 0,
    "permissions": [
      {
        "id": 0,
        "permission": "",
        "resource_id": "",
        "role_id": 0
      }
    ],
    "role_name": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/company/role/", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/company/role/"

payload = { "role": {
        "company_id": 0,
        "extension_attributes": {},
        "id": 0,
        "permissions": [
            {
                "id": 0,
                "permission": "",
                "resource_id": "",
                "role_id": 0
            }
        ],
        "role_name": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/company/role/"

payload <- "{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/company/role/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\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/V1/company/role/') do |req|
  req.body = "{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/company/role/";

    let payload = json!({"role": json!({
            "company_id": 0,
            "extension_attributes": json!({}),
            "id": 0,
            "permissions": (
                json!({
                    "id": 0,
                    "permission": "",
                    "resource_id": "",
                    "role_id": 0
                })
            ),
            "role_name": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/company/role/ \
  --header 'content-type: application/json' \
  --data '{
  "role": {
    "company_id": 0,
    "extension_attributes": {},
    "id": 0,
    "permissions": [
      {
        "id": 0,
        "permission": "",
        "resource_id": "",
        "role_id": 0
      }
    ],
    "role_name": ""
  }
}'
echo '{
  "role": {
    "company_id": 0,
    "extension_attributes": {},
    "id": 0,
    "permissions": [
      {
        "id": 0,
        "permission": "",
        "resource_id": "",
        "role_id": 0
      }
    ],
    "role_name": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/company/role/ \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "role": {\n    "company_id": 0,\n    "extension_attributes": {},\n    "id": 0,\n    "permissions": [\n      {\n        "id": 0,\n        "permission": "",\n        "resource_id": "",\n        "role_id": 0\n      }\n    ],\n    "role_name": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/company/role/
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["role": [
    "company_id": 0,
    "extension_attributes": [],
    "id": 0,
    "permissions": [
      [
        "id": 0,
        "permission": "",
        "resource_id": "",
        "role_id": 0
      ]
    ],
    "role_name": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/company/role/")! 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 company-role-
{{baseUrl}}/V1/company/role/
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/company/role/");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/company/role/")
require "http/client"

url = "{{baseUrl}}/V1/company/role/"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/company/role/"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/company/role/");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/company/role/"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/company/role/ HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/company/role/")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/company/role/"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/company/role/")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/company/role/")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/company/role/');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/company/role/'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/company/role/';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/company/role/',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/company/role/")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/company/role/',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/company/role/'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/company/role/');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/company/role/'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/company/role/';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/company/role/"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/company/role/" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/company/role/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/company/role/');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/company/role/');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/company/role/');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/company/role/' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/company/role/' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/company/role/")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/company/role/"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/company/role/"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/company/role/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/company/role/') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/company/role/";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/company/role/
http GET {{baseUrl}}/V1/company/role/
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/company/role/
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/company/role/")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT company-role-{id}
{{baseUrl}}/V1/company/role/:id
QUERY PARAMS

id
BODY json

{
  "role": {
    "company_id": 0,
    "extension_attributes": {},
    "id": 0,
    "permissions": [
      {
        "id": 0,
        "permission": "",
        "resource_id": "",
        "role_id": 0
      }
    ],
    "role_name": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/company/role/:id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/company/role/:id" {:content-type :json
                                                               :form-params {:role {:company_id 0
                                                                                    :extension_attributes {}
                                                                                    :id 0
                                                                                    :permissions [{:id 0
                                                                                                   :permission ""
                                                                                                   :resource_id ""
                                                                                                   :role_id 0}]
                                                                                    :role_name ""}}})
require "http/client"

url = "{{baseUrl}}/V1/company/role/:id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\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}}/V1/company/role/:id"),
    Content = new StringContent("{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\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}}/V1/company/role/:id");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/company/role/:id"

	payload := strings.NewReader("{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/company/role/:id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 240

{
  "role": {
    "company_id": 0,
    "extension_attributes": {},
    "id": 0,
    "permissions": [
      {
        "id": 0,
        "permission": "",
        "resource_id": "",
        "role_id": 0
      }
    ],
    "role_name": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/company/role/:id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/company/role/:id"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\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  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/company/role/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/company/role/:id")
  .header("content-type", "application/json")
  .body("{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  role: {
    company_id: 0,
    extension_attributes: {},
    id: 0,
    permissions: [
      {
        id: 0,
        permission: '',
        resource_id: '',
        role_id: 0
      }
    ],
    role_name: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/company/role/:id');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/company/role/:id',
  headers: {'content-type': 'application/json'},
  data: {
    role: {
      company_id: 0,
      extension_attributes: {},
      id: 0,
      permissions: [{id: 0, permission: '', resource_id: '', role_id: 0}],
      role_name: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/company/role/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"role":{"company_id":0,"extension_attributes":{},"id":0,"permissions":[{"id":0,"permission":"","resource_id":"","role_id":0}],"role_name":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/company/role/:id',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "role": {\n    "company_id": 0,\n    "extension_attributes": {},\n    "id": 0,\n    "permissions": [\n      {\n        "id": 0,\n        "permission": "",\n        "resource_id": "",\n        "role_id": 0\n      }\n    ],\n    "role_name": ""\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  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/company/role/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/company/role/:id',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  role: {
    company_id: 0,
    extension_attributes: {},
    id: 0,
    permissions: [{id: 0, permission: '', resource_id: '', role_id: 0}],
    role_name: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/company/role/:id',
  headers: {'content-type': 'application/json'},
  body: {
    role: {
      company_id: 0,
      extension_attributes: {},
      id: 0,
      permissions: [{id: 0, permission: '', resource_id: '', role_id: 0}],
      role_name: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/company/role/:id');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  role: {
    company_id: 0,
    extension_attributes: {},
    id: 0,
    permissions: [
      {
        id: 0,
        permission: '',
        resource_id: '',
        role_id: 0
      }
    ],
    role_name: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/company/role/:id',
  headers: {'content-type': 'application/json'},
  data: {
    role: {
      company_id: 0,
      extension_attributes: {},
      id: 0,
      permissions: [{id: 0, permission: '', resource_id: '', role_id: 0}],
      role_name: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/company/role/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"role":{"company_id":0,"extension_attributes":{},"id":0,"permissions":[{"id":0,"permission":"","resource_id":"","role_id":0}],"role_name":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"role": @{ @"company_id": @0, @"extension_attributes": @{  }, @"id": @0, @"permissions": @[ @{ @"id": @0, @"permission": @"", @"resource_id": @"", @"role_id": @0 } ], @"role_name": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/company/role/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/company/role/:id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/company/role/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'role' => [
        'company_id' => 0,
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'permissions' => [
                [
                                'id' => 0,
                                'permission' => '',
                                'resource_id' => '',
                                'role_id' => 0
                ]
        ],
        'role_name' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/company/role/:id', [
  'body' => '{
  "role": {
    "company_id": 0,
    "extension_attributes": {},
    "id": 0,
    "permissions": [
      {
        "id": 0,
        "permission": "",
        "resource_id": "",
        "role_id": 0
      }
    ],
    "role_name": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/company/role/:id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'role' => [
    'company_id' => 0,
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'permissions' => [
        [
                'id' => 0,
                'permission' => '',
                'resource_id' => '',
                'role_id' => 0
        ]
    ],
    'role_name' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'role' => [
    'company_id' => 0,
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'permissions' => [
        [
                'id' => 0,
                'permission' => '',
                'resource_id' => '',
                'role_id' => 0
        ]
    ],
    'role_name' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/company/role/:id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/company/role/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "role": {
    "company_id": 0,
    "extension_attributes": {},
    "id": 0,
    "permissions": [
      {
        "id": 0,
        "permission": "",
        "resource_id": "",
        "role_id": 0
      }
    ],
    "role_name": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/company/role/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "role": {
    "company_id": 0,
    "extension_attributes": {},
    "id": 0,
    "permissions": [
      {
        "id": 0,
        "permission": "",
        "resource_id": "",
        "role_id": 0
      }
    ],
    "role_name": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/company/role/:id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/company/role/:id"

payload = { "role": {
        "company_id": 0,
        "extension_attributes": {},
        "id": 0,
        "permissions": [
            {
                "id": 0,
                "permission": "",
                "resource_id": "",
                "role_id": 0
            }
        ],
        "role_name": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/company/role/:id"

payload <- "{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/company/role/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\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/V1/company/role/:id') do |req|
  req.body = "{\n  \"role\": {\n    \"company_id\": 0,\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"permissions\": [\n      {\n        \"id\": 0,\n        \"permission\": \"\",\n        \"resource_id\": \"\",\n        \"role_id\": 0\n      }\n    ],\n    \"role_name\": \"\"\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}}/V1/company/role/:id";

    let payload = json!({"role": json!({
            "company_id": 0,
            "extension_attributes": json!({}),
            "id": 0,
            "permissions": (
                json!({
                    "id": 0,
                    "permission": "",
                    "resource_id": "",
                    "role_id": 0
                })
            ),
            "role_name": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/company/role/:id \
  --header 'content-type: application/json' \
  --data '{
  "role": {
    "company_id": 0,
    "extension_attributes": {},
    "id": 0,
    "permissions": [
      {
        "id": 0,
        "permission": "",
        "resource_id": "",
        "role_id": 0
      }
    ],
    "role_name": ""
  }
}'
echo '{
  "role": {
    "company_id": 0,
    "extension_attributes": {},
    "id": 0,
    "permissions": [
      {
        "id": 0,
        "permission": "",
        "resource_id": "",
        "role_id": 0
      }
    ],
    "role_name": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/company/role/:id \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "role": {\n    "company_id": 0,\n    "extension_attributes": {},\n    "id": 0,\n    "permissions": [\n      {\n        "id": 0,\n        "permission": "",\n        "resource_id": "",\n        "role_id": 0\n      }\n    ],\n    "role_name": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/company/role/:id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["role": [
    "company_id": 0,
    "extension_attributes": [],
    "id": 0,
    "permissions": [
      [
        "id": 0,
        "permission": "",
        "resource_id": "",
        "role_id": 0
      ]
    ],
    "role_name": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/company/role/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET company-role-{roleId} (GET)
{{baseUrl}}/V1/company/role/:roleId
QUERY PARAMS

roleId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/company/role/:roleId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/company/role/:roleId")
require "http/client"

url = "{{baseUrl}}/V1/company/role/:roleId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/company/role/:roleId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/company/role/:roleId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/company/role/:roleId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/company/role/:roleId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/company/role/:roleId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/company/role/:roleId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/company/role/:roleId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/company/role/:roleId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/company/role/:roleId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/company/role/:roleId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/company/role/:roleId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/company/role/:roleId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/company/role/:roleId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/company/role/:roleId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/company/role/:roleId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/company/role/:roleId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/company/role/:roleId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/company/role/:roleId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/company/role/:roleId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/company/role/:roleId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/company/role/:roleId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/company/role/:roleId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/company/role/:roleId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/company/role/:roleId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/company/role/:roleId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/company/role/:roleId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/company/role/:roleId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/company/role/:roleId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/company/role/:roleId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/company/role/:roleId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/company/role/:roleId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/company/role/:roleId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/company/role/:roleId
http GET {{baseUrl}}/V1/company/role/:roleId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/company/role/:roleId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/company/role/:roleId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE company-role-{roleId}
{{baseUrl}}/V1/company/role/:roleId
QUERY PARAMS

roleId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/company/role/:roleId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/company/role/:roleId")
require "http/client"

url = "{{baseUrl}}/V1/company/role/:roleId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/company/role/:roleId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/company/role/:roleId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/company/role/:roleId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/company/role/:roleId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/company/role/:roleId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/company/role/:roleId"))
    .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}}/V1/company/role/:roleId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/company/role/:roleId")
  .asString();
const 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}}/V1/company/role/:roleId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/company/role/:roleId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/company/role/:roleId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/company/role/:roleId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/company/role/:roleId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/company/role/:roleId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/company/role/:roleId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/company/role/:roleId');

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}}/V1/company/role/:roleId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/company/role/:roleId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/company/role/:roleId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/company/role/:roleId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/company/role/:roleId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/company/role/:roleId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/company/role/:roleId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/company/role/:roleId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/company/role/:roleId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/company/role/:roleId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/company/role/:roleId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/company/role/:roleId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/company/role/:roleId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/company/role/:roleId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/company/role/:roleId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/company/role/:roleId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/company/role/:roleId
http DELETE {{baseUrl}}/V1/company/role/:roleId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/company/role/:roleId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/company/role/:roleId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET company-role-{roleId}-users
{{baseUrl}}/V1/company/role/:roleId/users
QUERY PARAMS

roleId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/company/role/:roleId/users");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/company/role/:roleId/users")
require "http/client"

url = "{{baseUrl}}/V1/company/role/:roleId/users"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/company/role/:roleId/users"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/company/role/:roleId/users");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/company/role/:roleId/users"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/company/role/:roleId/users HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/company/role/:roleId/users")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/company/role/:roleId/users"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/company/role/:roleId/users")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/company/role/:roleId/users")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/company/role/:roleId/users');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/company/role/:roleId/users'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/company/role/:roleId/users';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/company/role/:roleId/users',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/company/role/:roleId/users")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/company/role/:roleId/users',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/company/role/:roleId/users'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/company/role/:roleId/users');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/company/role/:roleId/users'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/company/role/:roleId/users';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/company/role/:roleId/users"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/company/role/:roleId/users" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/company/role/:roleId/users",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/company/role/:roleId/users');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/company/role/:roleId/users');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/company/role/:roleId/users');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/company/role/:roleId/users' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/company/role/:roleId/users' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/company/role/:roleId/users")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/company/role/:roleId/users"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/company/role/:roleId/users"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/company/role/:roleId/users")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/company/role/:roleId/users') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/company/role/:roleId/users";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/company/role/:roleId/users
http GET {{baseUrl}}/V1/company/role/:roleId/users
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/company/role/:roleId/users
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/company/role/:roleId/users")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET companyCredits-
{{baseUrl}}/V1/companyCredits/
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/companyCredits/");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/companyCredits/")
require "http/client"

url = "{{baseUrl}}/V1/companyCredits/"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/companyCredits/"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/companyCredits/");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/companyCredits/"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/companyCredits/ HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/companyCredits/")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/companyCredits/"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/companyCredits/")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/companyCredits/")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/companyCredits/');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/companyCredits/'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/companyCredits/';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/companyCredits/',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/companyCredits/")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/companyCredits/',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/companyCredits/'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/companyCredits/');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/companyCredits/'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/companyCredits/';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/companyCredits/"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/companyCredits/" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/companyCredits/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/companyCredits/');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/companyCredits/');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/companyCredits/');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/companyCredits/' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/companyCredits/' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/companyCredits/")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/companyCredits/"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/companyCredits/"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/companyCredits/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/companyCredits/') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/companyCredits/";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/companyCredits/
http GET {{baseUrl}}/V1/companyCredits/
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/companyCredits/
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/companyCredits/")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET companyCredits-{creditId}
{{baseUrl}}/V1/companyCredits/:creditId
QUERY PARAMS

creditId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/companyCredits/:creditId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/companyCredits/:creditId")
require "http/client"

url = "{{baseUrl}}/V1/companyCredits/:creditId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/companyCredits/:creditId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/companyCredits/:creditId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/companyCredits/:creditId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/companyCredits/:creditId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/companyCredits/:creditId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/companyCredits/:creditId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/companyCredits/:creditId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/companyCredits/:creditId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/companyCredits/:creditId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/companyCredits/:creditId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/companyCredits/:creditId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/companyCredits/:creditId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/companyCredits/:creditId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/companyCredits/:creditId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/companyCredits/:creditId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/companyCredits/:creditId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/companyCredits/:creditId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/companyCredits/:creditId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/companyCredits/:creditId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/companyCredits/:creditId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/companyCredits/:creditId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/companyCredits/:creditId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/companyCredits/:creditId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/companyCredits/:creditId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/companyCredits/:creditId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/companyCredits/:creditId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/companyCredits/:creditId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/companyCredits/:creditId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/companyCredits/:creditId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/companyCredits/:creditId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/companyCredits/:creditId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/companyCredits/:creditId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/companyCredits/:creditId
http GET {{baseUrl}}/V1/companyCredits/:creditId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/companyCredits/:creditId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/companyCredits/:creditId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST companyCredits-{creditId}-decreaseBalance
{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance
QUERY PARAMS

creditId
BODY json

{
  "comment": "",
  "currency": "",
  "operationType": 0,
  "options": {
    "currency_base": "",
    "currency_display": "",
    "order_increment": "",
    "purchase_order": ""
  },
  "value": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance" {:content-type :json
                                                                                        :form-params {:comment ""
                                                                                                      :currency ""
                                                                                                      :operationType 0
                                                                                                      :options {:currency_base ""
                                                                                                                :currency_display ""
                                                                                                                :order_increment ""
                                                                                                                :purchase_order ""}
                                                                                                      :value ""}})
require "http/client"

url = "{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance"),
    Content = new StringContent("{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance"

	payload := strings.NewReader("{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/companyCredits/:creditId/decreaseBalance HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 199

{
  "comment": "",
  "currency": "",
  "operationType": 0,
  "options": {
    "currency_base": "",
    "currency_display": "",
    "order_increment": "",
    "purchase_order": ""
  },
  "value": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance")
  .header("content-type", "application/json")
  .body("{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  comment: '',
  currency: '',
  operationType: 0,
  options: {
    currency_base: '',
    currency_display: '',
    order_increment: '',
    purchase_order: ''
  },
  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}}/V1/companyCredits/:creditId/decreaseBalance');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance',
  headers: {'content-type': 'application/json'},
  data: {
    comment: '',
    currency: '',
    operationType: 0,
    options: {
      currency_base: '',
      currency_display: '',
      order_increment: '',
      purchase_order: ''
    },
    value: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"comment":"","currency":"","operationType":0,"options":{"currency_base":"","currency_display":"","order_increment":"","purchase_order":""},"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}}/V1/companyCredits/:creditId/decreaseBalance',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "comment": "",\n  "currency": "",\n  "operationType": 0,\n  "options": {\n    "currency_base": "",\n    "currency_display": "",\n    "order_increment": "",\n    "purchase_order": ""\n  },\n  "value": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/companyCredits/:creditId/decreaseBalance',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  comment: '',
  currency: '',
  operationType: 0,
  options: {
    currency_base: '',
    currency_display: '',
    order_increment: '',
    purchase_order: ''
  },
  value: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance',
  headers: {'content-type': 'application/json'},
  body: {
    comment: '',
    currency: '',
    operationType: 0,
    options: {
      currency_base: '',
      currency_display: '',
      order_increment: '',
      purchase_order: ''
    },
    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}}/V1/companyCredits/:creditId/decreaseBalance');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  comment: '',
  currency: '',
  operationType: 0,
  options: {
    currency_base: '',
    currency_display: '',
    order_increment: '',
    purchase_order: ''
  },
  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}}/V1/companyCredits/:creditId/decreaseBalance',
  headers: {'content-type': 'application/json'},
  data: {
    comment: '',
    currency: '',
    operationType: 0,
    options: {
      currency_base: '',
      currency_display: '',
      order_increment: '',
      purchase_order: ''
    },
    value: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"comment":"","currency":"","operationType":0,"options":{"currency_base":"","currency_display":"","order_increment":"","purchase_order":""},"value":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"comment": @"",
                              @"currency": @"",
                              @"operationType": @0,
                              @"options": @{ @"currency_base": @"", @"currency_display": @"", @"order_increment": @"", @"purchase_order": @"" },
                              @"value": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance"]
                                                       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}}/V1/companyCredits/:creditId/decreaseBalance" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'comment' => '',
    'currency' => '',
    'operationType' => 0,
    'options' => [
        'currency_base' => '',
        'currency_display' => '',
        'order_increment' => '',
        'purchase_order' => ''
    ],
    'value' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance', [
  'body' => '{
  "comment": "",
  "currency": "",
  "operationType": 0,
  "options": {
    "currency_base": "",
    "currency_display": "",
    "order_increment": "",
    "purchase_order": ""
  },
  "value": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'comment' => '',
  'currency' => '',
  'operationType' => 0,
  'options' => [
    'currency_base' => '',
    'currency_display' => '',
    'order_increment' => '',
    'purchase_order' => ''
  ],
  'value' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'comment' => '',
  'currency' => '',
  'operationType' => 0,
  'options' => [
    'currency_base' => '',
    'currency_display' => '',
    'order_increment' => '',
    'purchase_order' => ''
  ],
  'value' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "comment": "",
  "currency": "",
  "operationType": 0,
  "options": {
    "currency_base": "",
    "currency_display": "",
    "order_increment": "",
    "purchase_order": ""
  },
  "value": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "comment": "",
  "currency": "",
  "operationType": 0,
  "options": {
    "currency_base": "",
    "currency_display": "",
    "order_increment": "",
    "purchase_order": ""
  },
  "value": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/companyCredits/:creditId/decreaseBalance", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance"

payload = {
    "comment": "",
    "currency": "",
    "operationType": 0,
    "options": {
        "currency_base": "",
        "currency_display": "",
        "order_increment": "",
        "purchase_order": ""
    },
    "value": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance"

payload <- "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/V1/companyCredits/:creditId/decreaseBalance') do |req|
  req.body = "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance";

    let payload = json!({
        "comment": "",
        "currency": "",
        "operationType": 0,
        "options": json!({
            "currency_base": "",
            "currency_display": "",
            "order_increment": "",
            "purchase_order": ""
        }),
        "value": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance \
  --header 'content-type: application/json' \
  --data '{
  "comment": "",
  "currency": "",
  "operationType": 0,
  "options": {
    "currency_base": "",
    "currency_display": "",
    "order_increment": "",
    "purchase_order": ""
  },
  "value": ""
}'
echo '{
  "comment": "",
  "currency": "",
  "operationType": 0,
  "options": {
    "currency_base": "",
    "currency_display": "",
    "order_increment": "",
    "purchase_order": ""
  },
  "value": ""
}' |  \
  http POST {{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "comment": "",\n  "currency": "",\n  "operationType": 0,\n  "options": {\n    "currency_base": "",\n    "currency_display": "",\n    "order_increment": "",\n    "purchase_order": ""\n  },\n  "value": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "comment": "",
  "currency": "",
  "operationType": 0,
  "options": [
    "currency_base": "",
    "currency_display": "",
    "order_increment": "",
    "purchase_order": ""
  ],
  "value": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/companyCredits/:creditId/decreaseBalance")! 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 companyCredits-{creditId}-increaseBalance
{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance
QUERY PARAMS

creditId
BODY json

{
  "comment": "",
  "currency": "",
  "operationType": 0,
  "options": {
    "currency_base": "",
    "currency_display": "",
    "order_increment": "",
    "purchase_order": ""
  },
  "value": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance" {:content-type :json
                                                                                        :form-params {:comment ""
                                                                                                      :currency ""
                                                                                                      :operationType 0
                                                                                                      :options {:currency_base ""
                                                                                                                :currency_display ""
                                                                                                                :order_increment ""
                                                                                                                :purchase_order ""}
                                                                                                      :value ""}})
require "http/client"

url = "{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance"),
    Content = new StringContent("{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance"

	payload := strings.NewReader("{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/companyCredits/:creditId/increaseBalance HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 199

{
  "comment": "",
  "currency": "",
  "operationType": 0,
  "options": {
    "currency_base": "",
    "currency_display": "",
    "order_increment": "",
    "purchase_order": ""
  },
  "value": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance")
  .header("content-type", "application/json")
  .body("{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  comment: '',
  currency: '',
  operationType: 0,
  options: {
    currency_base: '',
    currency_display: '',
    order_increment: '',
    purchase_order: ''
  },
  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}}/V1/companyCredits/:creditId/increaseBalance');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance',
  headers: {'content-type': 'application/json'},
  data: {
    comment: '',
    currency: '',
    operationType: 0,
    options: {
      currency_base: '',
      currency_display: '',
      order_increment: '',
      purchase_order: ''
    },
    value: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"comment":"","currency":"","operationType":0,"options":{"currency_base":"","currency_display":"","order_increment":"","purchase_order":""},"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}}/V1/companyCredits/:creditId/increaseBalance',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "comment": "",\n  "currency": "",\n  "operationType": 0,\n  "options": {\n    "currency_base": "",\n    "currency_display": "",\n    "order_increment": "",\n    "purchase_order": ""\n  },\n  "value": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/companyCredits/:creditId/increaseBalance',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  comment: '',
  currency: '',
  operationType: 0,
  options: {
    currency_base: '',
    currency_display: '',
    order_increment: '',
    purchase_order: ''
  },
  value: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance',
  headers: {'content-type': 'application/json'},
  body: {
    comment: '',
    currency: '',
    operationType: 0,
    options: {
      currency_base: '',
      currency_display: '',
      order_increment: '',
      purchase_order: ''
    },
    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}}/V1/companyCredits/:creditId/increaseBalance');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  comment: '',
  currency: '',
  operationType: 0,
  options: {
    currency_base: '',
    currency_display: '',
    order_increment: '',
    purchase_order: ''
  },
  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}}/V1/companyCredits/:creditId/increaseBalance',
  headers: {'content-type': 'application/json'},
  data: {
    comment: '',
    currency: '',
    operationType: 0,
    options: {
      currency_base: '',
      currency_display: '',
      order_increment: '',
      purchase_order: ''
    },
    value: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"comment":"","currency":"","operationType":0,"options":{"currency_base":"","currency_display":"","order_increment":"","purchase_order":""},"value":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"comment": @"",
                              @"currency": @"",
                              @"operationType": @0,
                              @"options": @{ @"currency_base": @"", @"currency_display": @"", @"order_increment": @"", @"purchase_order": @"" },
                              @"value": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance"]
                                                       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}}/V1/companyCredits/:creditId/increaseBalance" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'comment' => '',
    'currency' => '',
    'operationType' => 0,
    'options' => [
        'currency_base' => '',
        'currency_display' => '',
        'order_increment' => '',
        'purchase_order' => ''
    ],
    'value' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance', [
  'body' => '{
  "comment": "",
  "currency": "",
  "operationType": 0,
  "options": {
    "currency_base": "",
    "currency_display": "",
    "order_increment": "",
    "purchase_order": ""
  },
  "value": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'comment' => '',
  'currency' => '',
  'operationType' => 0,
  'options' => [
    'currency_base' => '',
    'currency_display' => '',
    'order_increment' => '',
    'purchase_order' => ''
  ],
  'value' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'comment' => '',
  'currency' => '',
  'operationType' => 0,
  'options' => [
    'currency_base' => '',
    'currency_display' => '',
    'order_increment' => '',
    'purchase_order' => ''
  ],
  'value' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "comment": "",
  "currency": "",
  "operationType": 0,
  "options": {
    "currency_base": "",
    "currency_display": "",
    "order_increment": "",
    "purchase_order": ""
  },
  "value": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "comment": "",
  "currency": "",
  "operationType": 0,
  "options": {
    "currency_base": "",
    "currency_display": "",
    "order_increment": "",
    "purchase_order": ""
  },
  "value": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/companyCredits/:creditId/increaseBalance", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance"

payload = {
    "comment": "",
    "currency": "",
    "operationType": 0,
    "options": {
        "currency_base": "",
        "currency_display": "",
        "order_increment": "",
        "purchase_order": ""
    },
    "value": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance"

payload <- "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/V1/companyCredits/:creditId/increaseBalance') do |req|
  req.body = "{\n  \"comment\": \"\",\n  \"currency\": \"\",\n  \"operationType\": 0,\n  \"options\": {\n    \"currency_base\": \"\",\n    \"currency_display\": \"\",\n    \"order_increment\": \"\",\n    \"purchase_order\": \"\"\n  },\n  \"value\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance";

    let payload = json!({
        "comment": "",
        "currency": "",
        "operationType": 0,
        "options": json!({
            "currency_base": "",
            "currency_display": "",
            "order_increment": "",
            "purchase_order": ""
        }),
        "value": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/companyCredits/:creditId/increaseBalance \
  --header 'content-type: application/json' \
  --data '{
  "comment": "",
  "currency": "",
  "operationType": 0,
  "options": {
    "currency_base": "",
    "currency_display": "",
    "order_increment": "",
    "purchase_order": ""
  },
  "value": ""
}'
echo '{
  "comment": "",
  "currency": "",
  "operationType": 0,
  "options": {
    "currency_base": "",
    "currency_display": "",
    "order_increment": "",
    "purchase_order": ""
  },
  "value": ""
}' |  \
  http POST {{baseUrl}}/V1/companyCredits/:creditId/increaseBalance \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "comment": "",\n  "currency": "",\n  "operationType": 0,\n  "options": {\n    "currency_base": "",\n    "currency_display": "",\n    "order_increment": "",\n    "purchase_order": ""\n  },\n  "value": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/companyCredits/:creditId/increaseBalance
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "comment": "",
  "currency": "",
  "operationType": 0,
  "options": [
    "currency_base": "",
    "currency_display": "",
    "order_increment": "",
    "purchase_order": ""
  ],
  "value": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/companyCredits/:creditId/increaseBalance")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT companyCredits-{id}
{{baseUrl}}/V1/companyCredits/:id
QUERY PARAMS

id
BODY json

{
  "creditLimit": {
    "available_limit": "",
    "balance": "",
    "company_id": 0,
    "credit_comment": "",
    "credit_limit": "",
    "currency_code": "",
    "exceed_limit": false,
    "extension_attributes": {},
    "id": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/companyCredits/:id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"creditLimit\": {\n    \"available_limit\": \"\",\n    \"balance\": \"\",\n    \"company_id\": 0,\n    \"credit_comment\": \"\",\n    \"credit_limit\": \"\",\n    \"currency_code\": \"\",\n    \"exceed_limit\": false,\n    \"extension_attributes\": {},\n    \"id\": 0\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/companyCredits/:id" {:content-type :json
                                                                 :form-params {:creditLimit {:available_limit ""
                                                                                             :balance ""
                                                                                             :company_id 0
                                                                                             :credit_comment ""
                                                                                             :credit_limit ""
                                                                                             :currency_code ""
                                                                                             :exceed_limit false
                                                                                             :extension_attributes {}
                                                                                             :id 0}}})
require "http/client"

url = "{{baseUrl}}/V1/companyCredits/:id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"creditLimit\": {\n    \"available_limit\": \"\",\n    \"balance\": \"\",\n    \"company_id\": 0,\n    \"credit_comment\": \"\",\n    \"credit_limit\": \"\",\n    \"currency_code\": \"\",\n    \"exceed_limit\": false,\n    \"extension_attributes\": {},\n    \"id\": 0\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}}/V1/companyCredits/:id"),
    Content = new StringContent("{\n  \"creditLimit\": {\n    \"available_limit\": \"\",\n    \"balance\": \"\",\n    \"company_id\": 0,\n    \"credit_comment\": \"\",\n    \"credit_limit\": \"\",\n    \"currency_code\": \"\",\n    \"exceed_limit\": false,\n    \"extension_attributes\": {},\n    \"id\": 0\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}}/V1/companyCredits/:id");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"creditLimit\": {\n    \"available_limit\": \"\",\n    \"balance\": \"\",\n    \"company_id\": 0,\n    \"credit_comment\": \"\",\n    \"credit_limit\": \"\",\n    \"currency_code\": \"\",\n    \"exceed_limit\": false,\n    \"extension_attributes\": {},\n    \"id\": 0\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/companyCredits/:id"

	payload := strings.NewReader("{\n  \"creditLimit\": {\n    \"available_limit\": \"\",\n    \"balance\": \"\",\n    \"company_id\": 0,\n    \"credit_comment\": \"\",\n    \"credit_limit\": \"\",\n    \"currency_code\": \"\",\n    \"exceed_limit\": false,\n    \"extension_attributes\": {},\n    \"id\": 0\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/companyCredits/:id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 239

{
  "creditLimit": {
    "available_limit": "",
    "balance": "",
    "company_id": 0,
    "credit_comment": "",
    "credit_limit": "",
    "currency_code": "",
    "exceed_limit": false,
    "extension_attributes": {},
    "id": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/companyCredits/:id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"creditLimit\": {\n    \"available_limit\": \"\",\n    \"balance\": \"\",\n    \"company_id\": 0,\n    \"credit_comment\": \"\",\n    \"credit_limit\": \"\",\n    \"currency_code\": \"\",\n    \"exceed_limit\": false,\n    \"extension_attributes\": {},\n    \"id\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/companyCredits/:id"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"creditLimit\": {\n    \"available_limit\": \"\",\n    \"balance\": \"\",\n    \"company_id\": 0,\n    \"credit_comment\": \"\",\n    \"credit_limit\": \"\",\n    \"currency_code\": \"\",\n    \"exceed_limit\": false,\n    \"extension_attributes\": {},\n    \"id\": 0\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  \"creditLimit\": {\n    \"available_limit\": \"\",\n    \"balance\": \"\",\n    \"company_id\": 0,\n    \"credit_comment\": \"\",\n    \"credit_limit\": \"\",\n    \"currency_code\": \"\",\n    \"exceed_limit\": false,\n    \"extension_attributes\": {},\n    \"id\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/companyCredits/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/companyCredits/:id")
  .header("content-type", "application/json")
  .body("{\n  \"creditLimit\": {\n    \"available_limit\": \"\",\n    \"balance\": \"\",\n    \"company_id\": 0,\n    \"credit_comment\": \"\",\n    \"credit_limit\": \"\",\n    \"currency_code\": \"\",\n    \"exceed_limit\": false,\n    \"extension_attributes\": {},\n    \"id\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  creditLimit: {
    available_limit: '',
    balance: '',
    company_id: 0,
    credit_comment: '',
    credit_limit: '',
    currency_code: '',
    exceed_limit: false,
    extension_attributes: {},
    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}}/V1/companyCredits/:id');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/companyCredits/:id',
  headers: {'content-type': 'application/json'},
  data: {
    creditLimit: {
      available_limit: '',
      balance: '',
      company_id: 0,
      credit_comment: '',
      credit_limit: '',
      currency_code: '',
      exceed_limit: false,
      extension_attributes: {},
      id: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/companyCredits/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"creditLimit":{"available_limit":"","balance":"","company_id":0,"credit_comment":"","credit_limit":"","currency_code":"","exceed_limit":false,"extension_attributes":{},"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}}/V1/companyCredits/:id',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "creditLimit": {\n    "available_limit": "",\n    "balance": "",\n    "company_id": 0,\n    "credit_comment": "",\n    "credit_limit": "",\n    "currency_code": "",\n    "exceed_limit": false,\n    "extension_attributes": {},\n    "id": 0\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  \"creditLimit\": {\n    \"available_limit\": \"\",\n    \"balance\": \"\",\n    \"company_id\": 0,\n    \"credit_comment\": \"\",\n    \"credit_limit\": \"\",\n    \"currency_code\": \"\",\n    \"exceed_limit\": false,\n    \"extension_attributes\": {},\n    \"id\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/companyCredits/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/companyCredits/:id',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  creditLimit: {
    available_limit: '',
    balance: '',
    company_id: 0,
    credit_comment: '',
    credit_limit: '',
    currency_code: '',
    exceed_limit: false,
    extension_attributes: {},
    id: 0
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/companyCredits/:id',
  headers: {'content-type': 'application/json'},
  body: {
    creditLimit: {
      available_limit: '',
      balance: '',
      company_id: 0,
      credit_comment: '',
      credit_limit: '',
      currency_code: '',
      exceed_limit: false,
      extension_attributes: {},
      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}}/V1/companyCredits/:id');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  creditLimit: {
    available_limit: '',
    balance: '',
    company_id: 0,
    credit_comment: '',
    credit_limit: '',
    currency_code: '',
    exceed_limit: false,
    extension_attributes: {},
    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}}/V1/companyCredits/:id',
  headers: {'content-type': 'application/json'},
  data: {
    creditLimit: {
      available_limit: '',
      balance: '',
      company_id: 0,
      credit_comment: '',
      credit_limit: '',
      currency_code: '',
      exceed_limit: false,
      extension_attributes: {},
      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}}/V1/companyCredits/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"creditLimit":{"available_limit":"","balance":"","company_id":0,"credit_comment":"","credit_limit":"","currency_code":"","exceed_limit":false,"extension_attributes":{},"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 = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"creditLimit": @{ @"available_limit": @"", @"balance": @"", @"company_id": @0, @"credit_comment": @"", @"credit_limit": @"", @"currency_code": @"", @"exceed_limit": @NO, @"extension_attributes": @{  }, @"id": @0 } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/companyCredits/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/companyCredits/:id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"creditLimit\": {\n    \"available_limit\": \"\",\n    \"balance\": \"\",\n    \"company_id\": 0,\n    \"credit_comment\": \"\",\n    \"credit_limit\": \"\",\n    \"currency_code\": \"\",\n    \"exceed_limit\": false,\n    \"extension_attributes\": {},\n    \"id\": 0\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/companyCredits/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'creditLimit' => [
        'available_limit' => '',
        'balance' => '',
        'company_id' => 0,
        'credit_comment' => '',
        'credit_limit' => '',
        'currency_code' => '',
        'exceed_limit' => null,
        'extension_attributes' => [
                
        ],
        'id' => 0
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/companyCredits/:id', [
  'body' => '{
  "creditLimit": {
    "available_limit": "",
    "balance": "",
    "company_id": 0,
    "credit_comment": "",
    "credit_limit": "",
    "currency_code": "",
    "exceed_limit": false,
    "extension_attributes": {},
    "id": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/companyCredits/:id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'creditLimit' => [
    'available_limit' => '',
    'balance' => '',
    'company_id' => 0,
    'credit_comment' => '',
    'credit_limit' => '',
    'currency_code' => '',
    'exceed_limit' => null,
    'extension_attributes' => [
        
    ],
    'id' => 0
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'creditLimit' => [
    'available_limit' => '',
    'balance' => '',
    'company_id' => 0,
    'credit_comment' => '',
    'credit_limit' => '',
    'currency_code' => '',
    'exceed_limit' => null,
    'extension_attributes' => [
        
    ],
    'id' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/companyCredits/:id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/companyCredits/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "creditLimit": {
    "available_limit": "",
    "balance": "",
    "company_id": 0,
    "credit_comment": "",
    "credit_limit": "",
    "currency_code": "",
    "exceed_limit": false,
    "extension_attributes": {},
    "id": 0
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/companyCredits/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "creditLimit": {
    "available_limit": "",
    "balance": "",
    "company_id": 0,
    "credit_comment": "",
    "credit_limit": "",
    "currency_code": "",
    "exceed_limit": false,
    "extension_attributes": {},
    "id": 0
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"creditLimit\": {\n    \"available_limit\": \"\",\n    \"balance\": \"\",\n    \"company_id\": 0,\n    \"credit_comment\": \"\",\n    \"credit_limit\": \"\",\n    \"currency_code\": \"\",\n    \"exceed_limit\": false,\n    \"extension_attributes\": {},\n    \"id\": 0\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/companyCredits/:id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/companyCredits/:id"

payload = { "creditLimit": {
        "available_limit": "",
        "balance": "",
        "company_id": 0,
        "credit_comment": "",
        "credit_limit": "",
        "currency_code": "",
        "exceed_limit": False,
        "extension_attributes": {},
        "id": 0
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/companyCredits/:id"

payload <- "{\n  \"creditLimit\": {\n    \"available_limit\": \"\",\n    \"balance\": \"\",\n    \"company_id\": 0,\n    \"credit_comment\": \"\",\n    \"credit_limit\": \"\",\n    \"currency_code\": \"\",\n    \"exceed_limit\": false,\n    \"extension_attributes\": {},\n    \"id\": 0\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/companyCredits/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"creditLimit\": {\n    \"available_limit\": \"\",\n    \"balance\": \"\",\n    \"company_id\": 0,\n    \"credit_comment\": \"\",\n    \"credit_limit\": \"\",\n    \"currency_code\": \"\",\n    \"exceed_limit\": false,\n    \"extension_attributes\": {},\n    \"id\": 0\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/V1/companyCredits/:id') do |req|
  req.body = "{\n  \"creditLimit\": {\n    \"available_limit\": \"\",\n    \"balance\": \"\",\n    \"company_id\": 0,\n    \"credit_comment\": \"\",\n    \"credit_limit\": \"\",\n    \"currency_code\": \"\",\n    \"exceed_limit\": false,\n    \"extension_attributes\": {},\n    \"id\": 0\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}}/V1/companyCredits/:id";

    let payload = json!({"creditLimit": json!({
            "available_limit": "",
            "balance": "",
            "company_id": 0,
            "credit_comment": "",
            "credit_limit": "",
            "currency_code": "",
            "exceed_limit": false,
            "extension_attributes": json!({}),
            "id": 0
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/companyCredits/:id \
  --header 'content-type: application/json' \
  --data '{
  "creditLimit": {
    "available_limit": "",
    "balance": "",
    "company_id": 0,
    "credit_comment": "",
    "credit_limit": "",
    "currency_code": "",
    "exceed_limit": false,
    "extension_attributes": {},
    "id": 0
  }
}'
echo '{
  "creditLimit": {
    "available_limit": "",
    "balance": "",
    "company_id": 0,
    "credit_comment": "",
    "credit_limit": "",
    "currency_code": "",
    "exceed_limit": false,
    "extension_attributes": {},
    "id": 0
  }
}' |  \
  http PUT {{baseUrl}}/V1/companyCredits/:id \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "creditLimit": {\n    "available_limit": "",\n    "balance": "",\n    "company_id": 0,\n    "credit_comment": "",\n    "credit_limit": "",\n    "currency_code": "",\n    "exceed_limit": false,\n    "extension_attributes": {},\n    "id": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/companyCredits/:id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["creditLimit": [
    "available_limit": "",
    "balance": "",
    "company_id": 0,
    "credit_comment": "",
    "credit_limit": "",
    "currency_code": "",
    "exceed_limit": false,
    "extension_attributes": [],
    "id": 0
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/companyCredits/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET companyCredits-company-{companyId}
{{baseUrl}}/V1/companyCredits/company/:companyId
QUERY PARAMS

companyId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/companyCredits/company/:companyId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/companyCredits/company/:companyId")
require "http/client"

url = "{{baseUrl}}/V1/companyCredits/company/:companyId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/companyCredits/company/:companyId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/companyCredits/company/:companyId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/companyCredits/company/:companyId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/companyCredits/company/:companyId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/companyCredits/company/:companyId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/companyCredits/company/:companyId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/companyCredits/company/:companyId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/companyCredits/company/:companyId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/companyCredits/company/:companyId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/companyCredits/company/:companyId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/companyCredits/company/:companyId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/companyCredits/company/:companyId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/companyCredits/company/:companyId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/companyCredits/company/:companyId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/companyCredits/company/:companyId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/companyCredits/company/:companyId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/companyCredits/company/:companyId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/companyCredits/company/:companyId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/companyCredits/company/:companyId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/companyCredits/company/:companyId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/companyCredits/company/:companyId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/companyCredits/company/:companyId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/companyCredits/company/:companyId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/companyCredits/company/:companyId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/companyCredits/company/:companyId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/companyCredits/company/:companyId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/companyCredits/company/:companyId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/companyCredits/company/:companyId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/companyCredits/company/:companyId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/companyCredits/company/:companyId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/companyCredits/company/:companyId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/companyCredits/company/:companyId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/companyCredits/company/:companyId
http GET {{baseUrl}}/V1/companyCredits/company/:companyId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/companyCredits/company/:companyId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/companyCredits/company/:companyId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET companyCredits-history
{{baseUrl}}/V1/companyCredits/history
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/companyCredits/history");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/companyCredits/history")
require "http/client"

url = "{{baseUrl}}/V1/companyCredits/history"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/companyCredits/history"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/companyCredits/history");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/companyCredits/history"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/companyCredits/history HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/companyCredits/history")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/companyCredits/history"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/companyCredits/history")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/companyCredits/history")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/companyCredits/history');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/companyCredits/history'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/companyCredits/history';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/companyCredits/history',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/companyCredits/history")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/companyCredits/history',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/companyCredits/history'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/companyCredits/history');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/companyCredits/history'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/companyCredits/history';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/companyCredits/history"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/companyCredits/history" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/companyCredits/history",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/companyCredits/history');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/companyCredits/history');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/companyCredits/history');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/companyCredits/history' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/companyCredits/history' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/companyCredits/history")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/companyCredits/history"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/companyCredits/history"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/companyCredits/history")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/companyCredits/history') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/companyCredits/history";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/companyCredits/history
http GET {{baseUrl}}/V1/companyCredits/history
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/companyCredits/history
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/companyCredits/history")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT companyCredits-history-{historyId}
{{baseUrl}}/V1/companyCredits/history/:historyId
QUERY PARAMS

historyId
BODY json

{
  "comment": "",
  "purchaseOrder": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/companyCredits/history/:historyId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"comment\": \"\",\n  \"purchaseOrder\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/companyCredits/history/:historyId" {:content-type :json
                                                                                :form-params {:comment ""
                                                                                              :purchaseOrder ""}})
require "http/client"

url = "{{baseUrl}}/V1/companyCredits/history/:historyId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"comment\": \"\",\n  \"purchaseOrder\": \"\"\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}}/V1/companyCredits/history/:historyId"),
    Content = new StringContent("{\n  \"comment\": \"\",\n  \"purchaseOrder\": \"\"\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}}/V1/companyCredits/history/:historyId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"comment\": \"\",\n  \"purchaseOrder\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/companyCredits/history/:historyId"

	payload := strings.NewReader("{\n  \"comment\": \"\",\n  \"purchaseOrder\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/companyCredits/history/:historyId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 42

{
  "comment": "",
  "purchaseOrder": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/companyCredits/history/:historyId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"comment\": \"\",\n  \"purchaseOrder\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/companyCredits/history/:historyId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"comment\": \"\",\n  \"purchaseOrder\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"comment\": \"\",\n  \"purchaseOrder\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/companyCredits/history/:historyId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/companyCredits/history/:historyId")
  .header("content-type", "application/json")
  .body("{\n  \"comment\": \"\",\n  \"purchaseOrder\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  comment: '',
  purchaseOrder: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/companyCredits/history/:historyId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/companyCredits/history/:historyId',
  headers: {'content-type': 'application/json'},
  data: {comment: '', purchaseOrder: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/companyCredits/history/:historyId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"comment":"","purchaseOrder":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/companyCredits/history/:historyId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "comment": "",\n  "purchaseOrder": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"comment\": \"\",\n  \"purchaseOrder\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/companyCredits/history/:historyId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/companyCredits/history/:historyId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({comment: '', purchaseOrder: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/companyCredits/history/:historyId',
  headers: {'content-type': 'application/json'},
  body: {comment: '', purchaseOrder: ''},
  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}}/V1/companyCredits/history/:historyId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  comment: '',
  purchaseOrder: ''
});

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}}/V1/companyCredits/history/:historyId',
  headers: {'content-type': 'application/json'},
  data: {comment: '', purchaseOrder: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/companyCredits/history/:historyId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"comment":"","purchaseOrder":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"comment": @"",
                              @"purchaseOrder": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/companyCredits/history/:historyId"]
                                                       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}}/V1/companyCredits/history/:historyId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"comment\": \"\",\n  \"purchaseOrder\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/companyCredits/history/:historyId",
  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([
    'comment' => '',
    'purchaseOrder' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/companyCredits/history/:historyId', [
  'body' => '{
  "comment": "",
  "purchaseOrder": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/companyCredits/history/:historyId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'comment' => '',
  'purchaseOrder' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'comment' => '',
  'purchaseOrder' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/companyCredits/history/:historyId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/companyCredits/history/:historyId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "comment": "",
  "purchaseOrder": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/companyCredits/history/:historyId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "comment": "",
  "purchaseOrder": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"comment\": \"\",\n  \"purchaseOrder\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/companyCredits/history/:historyId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/companyCredits/history/:historyId"

payload = {
    "comment": "",
    "purchaseOrder": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/companyCredits/history/:historyId"

payload <- "{\n  \"comment\": \"\",\n  \"purchaseOrder\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/companyCredits/history/:historyId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"comment\": \"\",\n  \"purchaseOrder\": \"\"\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/V1/companyCredits/history/:historyId') do |req|
  req.body = "{\n  \"comment\": \"\",\n  \"purchaseOrder\": \"\"\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}}/V1/companyCredits/history/:historyId";

    let payload = json!({
        "comment": "",
        "purchaseOrder": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/companyCredits/history/:historyId \
  --header 'content-type: application/json' \
  --data '{
  "comment": "",
  "purchaseOrder": ""
}'
echo '{
  "comment": "",
  "purchaseOrder": ""
}' |  \
  http PUT {{baseUrl}}/V1/companyCredits/history/:historyId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "comment": "",\n  "purchaseOrder": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/companyCredits/history/:historyId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "comment": "",
  "purchaseOrder": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/companyCredits/history/:historyId")! 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 configurable-products-{sku}-child
{{baseUrl}}/V1/configurable-products/:sku/child
QUERY PARAMS

sku
BODY json

{
  "childSku": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/configurable-products/:sku/child");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"childSku\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/configurable-products/:sku/child" {:content-type :json
                                                                                :form-params {:childSku ""}})
require "http/client"

url = "{{baseUrl}}/V1/configurable-products/:sku/child"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"childSku\": \"\"\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}}/V1/configurable-products/:sku/child"),
    Content = new StringContent("{\n  \"childSku\": \"\"\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}}/V1/configurable-products/:sku/child");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"childSku\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/configurable-products/:sku/child"

	payload := strings.NewReader("{\n  \"childSku\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/configurable-products/:sku/child HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 20

{
  "childSku": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/configurable-products/:sku/child")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"childSku\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/configurable-products/:sku/child"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"childSku\": \"\"\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  \"childSku\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/configurable-products/:sku/child")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/configurable-products/:sku/child")
  .header("content-type", "application/json")
  .body("{\n  \"childSku\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  childSku: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/configurable-products/:sku/child');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/configurable-products/:sku/child',
  headers: {'content-type': 'application/json'},
  data: {childSku: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/configurable-products/:sku/child';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"childSku":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/configurable-products/:sku/child',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "childSku": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"childSku\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/configurable-products/:sku/child")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/configurable-products/:sku/child',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({childSku: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/configurable-products/:sku/child',
  headers: {'content-type': 'application/json'},
  body: {childSku: ''},
  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}}/V1/configurable-products/:sku/child');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  childSku: ''
});

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}}/V1/configurable-products/:sku/child',
  headers: {'content-type': 'application/json'},
  data: {childSku: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/configurable-products/:sku/child';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"childSku":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"childSku": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/configurable-products/:sku/child"]
                                                       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}}/V1/configurable-products/:sku/child" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"childSku\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/configurable-products/:sku/child",
  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([
    'childSku' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/configurable-products/:sku/child', [
  'body' => '{
  "childSku": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/configurable-products/:sku/child');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'childSku' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'childSku' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/configurable-products/:sku/child');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/configurable-products/:sku/child' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "childSku": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/configurable-products/:sku/child' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "childSku": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"childSku\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/configurable-products/:sku/child", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/configurable-products/:sku/child"

payload = { "childSku": "" }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/configurable-products/:sku/child"

payload <- "{\n  \"childSku\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/configurable-products/:sku/child")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"childSku\": \"\"\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/V1/configurable-products/:sku/child') do |req|
  req.body = "{\n  \"childSku\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/configurable-products/:sku/child";

    let payload = json!({"childSku": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/configurable-products/:sku/child \
  --header 'content-type: application/json' \
  --data '{
  "childSku": ""
}'
echo '{
  "childSku": ""
}' |  \
  http POST {{baseUrl}}/V1/configurable-products/:sku/child \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "childSku": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/configurable-products/:sku/child
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["childSku": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/configurable-products/:sku/child")! 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 configurable-products-{sku}-children
{{baseUrl}}/V1/configurable-products/:sku/children
QUERY PARAMS

sku
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/configurable-products/:sku/children");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/configurable-products/:sku/children")
require "http/client"

url = "{{baseUrl}}/V1/configurable-products/:sku/children"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/configurable-products/:sku/children"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/configurable-products/:sku/children");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/configurable-products/:sku/children"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/configurable-products/:sku/children HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/configurable-products/:sku/children")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/configurable-products/:sku/children"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/configurable-products/:sku/children")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/configurable-products/:sku/children")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/configurable-products/:sku/children');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/configurable-products/:sku/children'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/configurable-products/:sku/children';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/configurable-products/:sku/children',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/configurable-products/:sku/children")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/configurable-products/:sku/children',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/configurable-products/:sku/children'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/configurable-products/:sku/children');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/configurable-products/:sku/children'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/configurable-products/:sku/children';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/configurable-products/:sku/children"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/configurable-products/:sku/children" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/configurable-products/:sku/children",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/configurable-products/:sku/children');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/configurable-products/:sku/children');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/configurable-products/:sku/children');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/configurable-products/:sku/children' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/configurable-products/:sku/children' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/configurable-products/:sku/children")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/configurable-products/:sku/children"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/configurable-products/:sku/children"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/configurable-products/:sku/children")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/configurable-products/:sku/children') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/configurable-products/:sku/children";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/configurable-products/:sku/children
http GET {{baseUrl}}/V1/configurable-products/:sku/children
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/configurable-products/:sku/children
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/configurable-products/:sku/children")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE configurable-products-{sku}-children-{childSku}
{{baseUrl}}/V1/configurable-products/:sku/children/:childSku
QUERY PARAMS

sku
childSku
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/configurable-products/:sku/children/:childSku");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/configurable-products/:sku/children/:childSku")
require "http/client"

url = "{{baseUrl}}/V1/configurable-products/:sku/children/:childSku"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/configurable-products/:sku/children/:childSku"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/configurable-products/:sku/children/:childSku");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/configurable-products/:sku/children/:childSku"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/configurable-products/:sku/children/:childSku HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/configurable-products/:sku/children/:childSku")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/configurable-products/:sku/children/:childSku"))
    .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}}/V1/configurable-products/:sku/children/:childSku")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/configurable-products/:sku/children/:childSku")
  .asString();
const 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}}/V1/configurable-products/:sku/children/:childSku');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/configurable-products/:sku/children/:childSku'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/configurable-products/:sku/children/:childSku';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/configurable-products/:sku/children/:childSku',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/configurable-products/:sku/children/:childSku")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/configurable-products/:sku/children/:childSku',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/configurable-products/:sku/children/:childSku'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/configurable-products/:sku/children/:childSku');

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}}/V1/configurable-products/:sku/children/:childSku'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/configurable-products/:sku/children/:childSku';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/configurable-products/:sku/children/:childSku"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/configurable-products/:sku/children/:childSku" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/configurable-products/:sku/children/:childSku",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/configurable-products/:sku/children/:childSku');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/configurable-products/:sku/children/:childSku');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/configurable-products/:sku/children/:childSku');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/configurable-products/:sku/children/:childSku' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/configurable-products/:sku/children/:childSku' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/configurable-products/:sku/children/:childSku")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/configurable-products/:sku/children/:childSku"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/configurable-products/:sku/children/:childSku"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/configurable-products/:sku/children/:childSku")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/configurable-products/:sku/children/:childSku') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/configurable-products/:sku/children/:childSku";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/configurable-products/:sku/children/:childSku
http DELETE {{baseUrl}}/V1/configurable-products/:sku/children/:childSku
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/configurable-products/:sku/children/:childSku
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/configurable-products/:sku/children/:childSku")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST configurable-products-{sku}-options
{{baseUrl}}/V1/configurable-products/:sku/options
QUERY PARAMS

sku
BODY json

{
  "option": {
    "attribute_id": "",
    "extension_attributes": {},
    "id": 0,
    "is_use_default": false,
    "label": "",
    "position": 0,
    "product_id": 0,
    "values": [
      {
        "extension_attributes": {},
        "value_index": 0
      }
    ]
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/configurable-products/:sku/options");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/configurable-products/:sku/options" {:content-type :json
                                                                                  :form-params {:option {:attribute_id ""
                                                                                                         :extension_attributes {}
                                                                                                         :id 0
                                                                                                         :is_use_default false
                                                                                                         :label ""
                                                                                                         :position 0
                                                                                                         :product_id 0
                                                                                                         :values [{:extension_attributes {}
                                                                                                                   :value_index 0}]}}})
require "http/client"

url = "{{baseUrl}}/V1/configurable-products/:sku/options"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\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}}/V1/configurable-products/:sku/options"),
    Content = new StringContent("{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/configurable-products/:sku/options");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/configurable-products/:sku/options"

	payload := strings.NewReader("{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/configurable-products/:sku/options HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 275

{
  "option": {
    "attribute_id": "",
    "extension_attributes": {},
    "id": 0,
    "is_use_default": false,
    "label": "",
    "position": 0,
    "product_id": 0,
    "values": [
      {
        "extension_attributes": {},
        "value_index": 0
      }
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/configurable-products/:sku/options")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/configurable-products/:sku/options"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/configurable-products/:sku/options")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/configurable-products/:sku/options")
  .header("content-type", "application/json")
  .body("{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}")
  .asString();
const data = JSON.stringify({
  option: {
    attribute_id: '',
    extension_attributes: {},
    id: 0,
    is_use_default: false,
    label: '',
    position: 0,
    product_id: 0,
    values: [
      {
        extension_attributes: {},
        value_index: 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}}/V1/configurable-products/:sku/options');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/configurable-products/:sku/options',
  headers: {'content-type': 'application/json'},
  data: {
    option: {
      attribute_id: '',
      extension_attributes: {},
      id: 0,
      is_use_default: false,
      label: '',
      position: 0,
      product_id: 0,
      values: [{extension_attributes: {}, value_index: 0}]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/configurable-products/:sku/options';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"option":{"attribute_id":"","extension_attributes":{},"id":0,"is_use_default":false,"label":"","position":0,"product_id":0,"values":[{"extension_attributes":{},"value_index":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}}/V1/configurable-products/:sku/options',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "option": {\n    "attribute_id": "",\n    "extension_attributes": {},\n    "id": 0,\n    "is_use_default": false,\n    "label": "",\n    "position": 0,\n    "product_id": 0,\n    "values": [\n      {\n        "extension_attributes": {},\n        "value_index": 0\n      }\n    ]\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/configurable-products/:sku/options")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/configurable-products/:sku/options',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  option: {
    attribute_id: '',
    extension_attributes: {},
    id: 0,
    is_use_default: false,
    label: '',
    position: 0,
    product_id: 0,
    values: [{extension_attributes: {}, value_index: 0}]
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/configurable-products/:sku/options',
  headers: {'content-type': 'application/json'},
  body: {
    option: {
      attribute_id: '',
      extension_attributes: {},
      id: 0,
      is_use_default: false,
      label: '',
      position: 0,
      product_id: 0,
      values: [{extension_attributes: {}, value_index: 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}}/V1/configurable-products/:sku/options');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  option: {
    attribute_id: '',
    extension_attributes: {},
    id: 0,
    is_use_default: false,
    label: '',
    position: 0,
    product_id: 0,
    values: [
      {
        extension_attributes: {},
        value_index: 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}}/V1/configurable-products/:sku/options',
  headers: {'content-type': 'application/json'},
  data: {
    option: {
      attribute_id: '',
      extension_attributes: {},
      id: 0,
      is_use_default: false,
      label: '',
      position: 0,
      product_id: 0,
      values: [{extension_attributes: {}, value_index: 0}]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/configurable-products/:sku/options';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"option":{"attribute_id":"","extension_attributes":{},"id":0,"is_use_default":false,"label":"","position":0,"product_id":0,"values":[{"extension_attributes":{},"value_index":0}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"option": @{ @"attribute_id": @"", @"extension_attributes": @{  }, @"id": @0, @"is_use_default": @NO, @"label": @"", @"position": @0, @"product_id": @0, @"values": @[ @{ @"extension_attributes": @{  }, @"value_index": @0 } ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/configurable-products/:sku/options"]
                                                       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}}/V1/configurable-products/:sku/options" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/configurable-products/:sku/options",
  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([
    'option' => [
        'attribute_id' => '',
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'is_use_default' => null,
        'label' => '',
        'position' => 0,
        'product_id' => 0,
        'values' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'value_index' => 0
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/configurable-products/:sku/options', [
  'body' => '{
  "option": {
    "attribute_id": "",
    "extension_attributes": {},
    "id": 0,
    "is_use_default": false,
    "label": "",
    "position": 0,
    "product_id": 0,
    "values": [
      {
        "extension_attributes": {},
        "value_index": 0
      }
    ]
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/configurable-products/:sku/options');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'option' => [
    'attribute_id' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'is_use_default' => null,
    'label' => '',
    'position' => 0,
    'product_id' => 0,
    'values' => [
        [
                'extension_attributes' => [
                                
                ],
                'value_index' => 0
        ]
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'option' => [
    'attribute_id' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'is_use_default' => null,
    'label' => '',
    'position' => 0,
    'product_id' => 0,
    'values' => [
        [
                'extension_attributes' => [
                                
                ],
                'value_index' => 0
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/configurable-products/:sku/options');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/configurable-products/:sku/options' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "option": {
    "attribute_id": "",
    "extension_attributes": {},
    "id": 0,
    "is_use_default": false,
    "label": "",
    "position": 0,
    "product_id": 0,
    "values": [
      {
        "extension_attributes": {},
        "value_index": 0
      }
    ]
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/configurable-products/:sku/options' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "option": {
    "attribute_id": "",
    "extension_attributes": {},
    "id": 0,
    "is_use_default": false,
    "label": "",
    "position": 0,
    "product_id": 0,
    "values": [
      {
        "extension_attributes": {},
        "value_index": 0
      }
    ]
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/configurable-products/:sku/options", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/configurable-products/:sku/options"

payload = { "option": {
        "attribute_id": "",
        "extension_attributes": {},
        "id": 0,
        "is_use_default": False,
        "label": "",
        "position": 0,
        "product_id": 0,
        "values": [
            {
                "extension_attributes": {},
                "value_index": 0
            }
        ]
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/configurable-products/:sku/options"

payload <- "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/configurable-products/:sku/options")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/V1/configurable-products/:sku/options') do |req|
  req.body = "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\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}}/V1/configurable-products/:sku/options";

    let payload = json!({"option": json!({
            "attribute_id": "",
            "extension_attributes": json!({}),
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": (
                json!({
                    "extension_attributes": json!({}),
                    "value_index": 0
                })
            )
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/configurable-products/:sku/options \
  --header 'content-type: application/json' \
  --data '{
  "option": {
    "attribute_id": "",
    "extension_attributes": {},
    "id": 0,
    "is_use_default": false,
    "label": "",
    "position": 0,
    "product_id": 0,
    "values": [
      {
        "extension_attributes": {},
        "value_index": 0
      }
    ]
  }
}'
echo '{
  "option": {
    "attribute_id": "",
    "extension_attributes": {},
    "id": 0,
    "is_use_default": false,
    "label": "",
    "position": 0,
    "product_id": 0,
    "values": [
      {
        "extension_attributes": {},
        "value_index": 0
      }
    ]
  }
}' |  \
  http POST {{baseUrl}}/V1/configurable-products/:sku/options \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "option": {\n    "attribute_id": "",\n    "extension_attributes": {},\n    "id": 0,\n    "is_use_default": false,\n    "label": "",\n    "position": 0,\n    "product_id": 0,\n    "values": [\n      {\n        "extension_attributes": {},\n        "value_index": 0\n      }\n    ]\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/configurable-products/:sku/options
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["option": [
    "attribute_id": "",
    "extension_attributes": [],
    "id": 0,
    "is_use_default": false,
    "label": "",
    "position": 0,
    "product_id": 0,
    "values": [
      [
        "extension_attributes": [],
        "value_index": 0
      ]
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/configurable-products/:sku/options")! 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 configurable-products-{sku}-options-{id} (GET)
{{baseUrl}}/V1/configurable-products/:sku/options/:id
QUERY PARAMS

sku
id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/configurable-products/:sku/options/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/configurable-products/:sku/options/:id")
require "http/client"

url = "{{baseUrl}}/V1/configurable-products/:sku/options/:id"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/configurable-products/:sku/options/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/configurable-products/:sku/options/:id");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/configurable-products/:sku/options/:id"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/configurable-products/:sku/options/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/configurable-products/:sku/options/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/configurable-products/:sku/options/:id"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/configurable-products/:sku/options/:id")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/configurable-products/:sku/options/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/configurable-products/:sku/options/:id');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/configurable-products/:sku/options/:id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/configurable-products/:sku/options/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/configurable-products/:sku/options/:id',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/configurable-products/:sku/options/:id")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/configurable-products/:sku/options/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/configurable-products/:sku/options/:id'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/configurable-products/:sku/options/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/configurable-products/:sku/options/:id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/configurable-products/:sku/options/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/configurable-products/:sku/options/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/configurable-products/:sku/options/:id" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/configurable-products/:sku/options/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/configurable-products/:sku/options/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/configurable-products/:sku/options/:id');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/configurable-products/:sku/options/:id');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/configurable-products/:sku/options/:id' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/configurable-products/:sku/options/:id' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/configurable-products/:sku/options/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/configurable-products/:sku/options/:id"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/configurable-products/:sku/options/:id"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/configurable-products/:sku/options/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/configurable-products/:sku/options/:id') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/configurable-products/:sku/options/:id";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/configurable-products/:sku/options/:id
http GET {{baseUrl}}/V1/configurable-products/:sku/options/:id
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/configurable-products/:sku/options/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/configurable-products/:sku/options/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT configurable-products-{sku}-options-{id} (PUT)
{{baseUrl}}/V1/configurable-products/:sku/options/:id
QUERY PARAMS

sku
id
BODY json

{
  "option": {
    "attribute_id": "",
    "extension_attributes": {},
    "id": 0,
    "is_use_default": false,
    "label": "",
    "position": 0,
    "product_id": 0,
    "values": [
      {
        "extension_attributes": {},
        "value_index": 0
      }
    ]
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/configurable-products/:sku/options/:id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/configurable-products/:sku/options/:id" {:content-type :json
                                                                                     :form-params {:option {:attribute_id ""
                                                                                                            :extension_attributes {}
                                                                                                            :id 0
                                                                                                            :is_use_default false
                                                                                                            :label ""
                                                                                                            :position 0
                                                                                                            :product_id 0
                                                                                                            :values [{:extension_attributes {}
                                                                                                                      :value_index 0}]}}})
require "http/client"

url = "{{baseUrl}}/V1/configurable-products/:sku/options/:id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/V1/configurable-products/:sku/options/:id"),
    Content = new StringContent("{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/configurable-products/:sku/options/:id");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/configurable-products/:sku/options/:id"

	payload := strings.NewReader("{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/configurable-products/:sku/options/:id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 275

{
  "option": {
    "attribute_id": "",
    "extension_attributes": {},
    "id": 0,
    "is_use_default": false,
    "label": "",
    "position": 0,
    "product_id": 0,
    "values": [
      {
        "extension_attributes": {},
        "value_index": 0
      }
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/configurable-products/:sku/options/:id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/configurable-products/:sku/options/:id"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/configurable-products/:sku/options/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/configurable-products/:sku/options/:id")
  .header("content-type", "application/json")
  .body("{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}")
  .asString();
const data = JSON.stringify({
  option: {
    attribute_id: '',
    extension_attributes: {},
    id: 0,
    is_use_default: false,
    label: '',
    position: 0,
    product_id: 0,
    values: [
      {
        extension_attributes: {},
        value_index: 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}}/V1/configurable-products/:sku/options/:id');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/configurable-products/:sku/options/:id',
  headers: {'content-type': 'application/json'},
  data: {
    option: {
      attribute_id: '',
      extension_attributes: {},
      id: 0,
      is_use_default: false,
      label: '',
      position: 0,
      product_id: 0,
      values: [{extension_attributes: {}, value_index: 0}]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/configurable-products/:sku/options/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"option":{"attribute_id":"","extension_attributes":{},"id":0,"is_use_default":false,"label":"","position":0,"product_id":0,"values":[{"extension_attributes":{},"value_index":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}}/V1/configurable-products/:sku/options/:id',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "option": {\n    "attribute_id": "",\n    "extension_attributes": {},\n    "id": 0,\n    "is_use_default": false,\n    "label": "",\n    "position": 0,\n    "product_id": 0,\n    "values": [\n      {\n        "extension_attributes": {},\n        "value_index": 0\n      }\n    ]\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/configurable-products/:sku/options/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/configurable-products/:sku/options/:id',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  option: {
    attribute_id: '',
    extension_attributes: {},
    id: 0,
    is_use_default: false,
    label: '',
    position: 0,
    product_id: 0,
    values: [{extension_attributes: {}, value_index: 0}]
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/configurable-products/:sku/options/:id',
  headers: {'content-type': 'application/json'},
  body: {
    option: {
      attribute_id: '',
      extension_attributes: {},
      id: 0,
      is_use_default: false,
      label: '',
      position: 0,
      product_id: 0,
      values: [{extension_attributes: {}, value_index: 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}}/V1/configurable-products/:sku/options/:id');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  option: {
    attribute_id: '',
    extension_attributes: {},
    id: 0,
    is_use_default: false,
    label: '',
    position: 0,
    product_id: 0,
    values: [
      {
        extension_attributes: {},
        value_index: 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}}/V1/configurable-products/:sku/options/:id',
  headers: {'content-type': 'application/json'},
  data: {
    option: {
      attribute_id: '',
      extension_attributes: {},
      id: 0,
      is_use_default: false,
      label: '',
      position: 0,
      product_id: 0,
      values: [{extension_attributes: {}, value_index: 0}]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/configurable-products/:sku/options/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"option":{"attribute_id":"","extension_attributes":{},"id":0,"is_use_default":false,"label":"","position":0,"product_id":0,"values":[{"extension_attributes":{},"value_index":0}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"option": @{ @"attribute_id": @"", @"extension_attributes": @{  }, @"id": @0, @"is_use_default": @NO, @"label": @"", @"position": @0, @"product_id": @0, @"values": @[ @{ @"extension_attributes": @{  }, @"value_index": @0 } ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/configurable-products/:sku/options/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/configurable-products/:sku/options/:id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/configurable-products/:sku/options/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'option' => [
        'attribute_id' => '',
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'is_use_default' => null,
        'label' => '',
        'position' => 0,
        'product_id' => 0,
        'values' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'value_index' => 0
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/configurable-products/:sku/options/:id', [
  'body' => '{
  "option": {
    "attribute_id": "",
    "extension_attributes": {},
    "id": 0,
    "is_use_default": false,
    "label": "",
    "position": 0,
    "product_id": 0,
    "values": [
      {
        "extension_attributes": {},
        "value_index": 0
      }
    ]
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/configurable-products/:sku/options/:id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'option' => [
    'attribute_id' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'is_use_default' => null,
    'label' => '',
    'position' => 0,
    'product_id' => 0,
    'values' => [
        [
                'extension_attributes' => [
                                
                ],
                'value_index' => 0
        ]
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'option' => [
    'attribute_id' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'is_use_default' => null,
    'label' => '',
    'position' => 0,
    'product_id' => 0,
    'values' => [
        [
                'extension_attributes' => [
                                
                ],
                'value_index' => 0
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/configurable-products/:sku/options/:id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/configurable-products/:sku/options/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "option": {
    "attribute_id": "",
    "extension_attributes": {},
    "id": 0,
    "is_use_default": false,
    "label": "",
    "position": 0,
    "product_id": 0,
    "values": [
      {
        "extension_attributes": {},
        "value_index": 0
      }
    ]
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/configurable-products/:sku/options/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "option": {
    "attribute_id": "",
    "extension_attributes": {},
    "id": 0,
    "is_use_default": false,
    "label": "",
    "position": 0,
    "product_id": 0,
    "values": [
      {
        "extension_attributes": {},
        "value_index": 0
      }
    ]
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/configurable-products/:sku/options/:id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/configurable-products/:sku/options/:id"

payload = { "option": {
        "attribute_id": "",
        "extension_attributes": {},
        "id": 0,
        "is_use_default": False,
        "label": "",
        "position": 0,
        "product_id": 0,
        "values": [
            {
                "extension_attributes": {},
                "value_index": 0
            }
        ]
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/configurable-products/:sku/options/:id"

payload <- "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/configurable-products/:sku/options/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/V1/configurable-products/:sku/options/:id') do |req|
  req.body = "{\n  \"option\": {\n    \"attribute_id\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_use_default\": false,\n    \"label\": \"\",\n    \"position\": 0,\n    \"product_id\": 0,\n    \"values\": [\n      {\n        \"extension_attributes\": {},\n        \"value_index\": 0\n      }\n    ]\n  }\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/configurable-products/:sku/options/:id";

    let payload = json!({"option": json!({
            "attribute_id": "",
            "extension_attributes": json!({}),
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": (
                json!({
                    "extension_attributes": json!({}),
                    "value_index": 0
                })
            )
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/configurable-products/:sku/options/:id \
  --header 'content-type: application/json' \
  --data '{
  "option": {
    "attribute_id": "",
    "extension_attributes": {},
    "id": 0,
    "is_use_default": false,
    "label": "",
    "position": 0,
    "product_id": 0,
    "values": [
      {
        "extension_attributes": {},
        "value_index": 0
      }
    ]
  }
}'
echo '{
  "option": {
    "attribute_id": "",
    "extension_attributes": {},
    "id": 0,
    "is_use_default": false,
    "label": "",
    "position": 0,
    "product_id": 0,
    "values": [
      {
        "extension_attributes": {},
        "value_index": 0
      }
    ]
  }
}' |  \
  http PUT {{baseUrl}}/V1/configurable-products/:sku/options/:id \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "option": {\n    "attribute_id": "",\n    "extension_attributes": {},\n    "id": 0,\n    "is_use_default": false,\n    "label": "",\n    "position": 0,\n    "product_id": 0,\n    "values": [\n      {\n        "extension_attributes": {},\n        "value_index": 0\n      }\n    ]\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/configurable-products/:sku/options/:id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["option": [
    "attribute_id": "",
    "extension_attributes": [],
    "id": 0,
    "is_use_default": false,
    "label": "",
    "position": 0,
    "product_id": 0,
    "values": [
      [
        "extension_attributes": [],
        "value_index": 0
      ]
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/configurable-products/:sku/options/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE configurable-products-{sku}-options-{id}
{{baseUrl}}/V1/configurable-products/:sku/options/:id
QUERY PARAMS

sku
id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/configurable-products/:sku/options/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/configurable-products/:sku/options/:id")
require "http/client"

url = "{{baseUrl}}/V1/configurable-products/:sku/options/:id"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/configurable-products/:sku/options/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/configurable-products/:sku/options/:id");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/configurable-products/:sku/options/:id"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/configurable-products/:sku/options/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/configurable-products/:sku/options/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/configurable-products/:sku/options/:id"))
    .method("DELETE", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/configurable-products/:sku/options/:id")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/configurable-products/:sku/options/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/V1/configurable-products/:sku/options/:id');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/configurable-products/:sku/options/:id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/configurable-products/:sku/options/:id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/configurable-products/:sku/options/:id',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/configurable-products/:sku/options/:id")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/configurable-products/:sku/options/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/configurable-products/:sku/options/:id'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/configurable-products/:sku/options/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/configurable-products/:sku/options/:id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/configurable-products/:sku/options/:id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/configurable-products/:sku/options/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/configurable-products/:sku/options/:id" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/configurable-products/:sku/options/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/configurable-products/:sku/options/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/configurable-products/:sku/options/:id');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/configurable-products/:sku/options/:id');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/configurable-products/:sku/options/:id' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/configurable-products/:sku/options/:id' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/configurable-products/:sku/options/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/configurable-products/:sku/options/:id"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/configurable-products/:sku/options/:id"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/configurable-products/:sku/options/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/configurable-products/:sku/options/:id') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/configurable-products/:sku/options/:id";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/configurable-products/:sku/options/:id
http DELETE {{baseUrl}}/V1/configurable-products/:sku/options/:id
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/configurable-products/:sku/options/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/configurable-products/:sku/options/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET configurable-products-{sku}-options-all
{{baseUrl}}/V1/configurable-products/:sku/options/all
QUERY PARAMS

sku
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/configurable-products/:sku/options/all");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/configurable-products/:sku/options/all")
require "http/client"

url = "{{baseUrl}}/V1/configurable-products/:sku/options/all"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/configurable-products/:sku/options/all"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/configurable-products/:sku/options/all");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/configurable-products/:sku/options/all"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/configurable-products/:sku/options/all HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/configurable-products/:sku/options/all")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/configurable-products/:sku/options/all"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/configurable-products/:sku/options/all")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/configurable-products/:sku/options/all")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/configurable-products/:sku/options/all');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/configurable-products/:sku/options/all'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/configurable-products/:sku/options/all';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/configurable-products/:sku/options/all',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/configurable-products/:sku/options/all")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/configurable-products/:sku/options/all',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/configurable-products/:sku/options/all'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/configurable-products/:sku/options/all');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/configurable-products/:sku/options/all'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/configurable-products/:sku/options/all';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/configurable-products/:sku/options/all"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/configurable-products/:sku/options/all" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/configurable-products/:sku/options/all",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/configurable-products/:sku/options/all');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/configurable-products/:sku/options/all');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/configurable-products/:sku/options/all');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/configurable-products/:sku/options/all' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/configurable-products/:sku/options/all' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/configurable-products/:sku/options/all")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/configurable-products/:sku/options/all"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/configurable-products/:sku/options/all"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/configurable-products/:sku/options/all")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/configurable-products/:sku/options/all') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/configurable-products/:sku/options/all";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/configurable-products/:sku/options/all
http GET {{baseUrl}}/V1/configurable-products/:sku/options/all
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/configurable-products/:sku/options/all
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/configurable-products/:sku/options/all")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT configurable-products-variation
{{baseUrl}}/V1/configurable-products/variation
BODY json

{
  "options": [
    {
      "attribute_id": "",
      "extension_attributes": {},
      "id": 0,
      "is_use_default": false,
      "label": "",
      "position": 0,
      "product_id": 0,
      "values": [
        {
          "extension_attributes": {},
          "value_index": 0
        }
      ]
    }
  ],
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {}
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/configurable-products/variation");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"options\": [\n    {\n      \"attribute_id\": \"\",\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"is_use_default\": false,\n      \"label\": \"\",\n      \"position\": 0,\n      \"product_id\": 0,\n      \"values\": [\n        {\n          \"extension_attributes\": {},\n          \"value_index\": 0\n        }\n      ]\n    }\n  ],\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {}\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/configurable-products/variation" {:content-type :json
                                                                              :form-params {:options [{:attribute_id ""
                                                                                                       :extension_attributes {}
                                                                                                       :id 0
                                                                                                       :is_use_default false
                                                                                                       :label ""
                                                                                                       :position 0
                                                                                                       :product_id 0
                                                                                                       :values [{:extension_attributes {}
                                                                                                                 :value_index 0}]}]
                                                                                            :product {:attribute_set_id 0
                                                                                                      :created_at ""
                                                                                                      :custom_attributes [{:attribute_code ""
                                                                                                                           :value ""}]
                                                                                                      :extension_attributes {:bundle_product_options [{:extension_attributes {}
                                                                                                                                                       :option_id 0
                                                                                                                                                       :position 0
                                                                                                                                                       :product_links [{:can_change_quantity 0
                                                                                                                                                                        :extension_attributes {}
                                                                                                                                                                        :id ""
                                                                                                                                                                        :is_default false
                                                                                                                                                                        :option_id 0
                                                                                                                                                                        :position 0
                                                                                                                                                                        :price ""
                                                                                                                                                                        :price_type 0
                                                                                                                                                                        :qty ""
                                                                                                                                                                        :sku ""}]
                                                                                                                                                       :required false
                                                                                                                                                       :sku ""
                                                                                                                                                       :title ""
                                                                                                                                                       :type ""}]
                                                                                                                             :category_links [{:category_id ""
                                                                                                                                               :extension_attributes {}
                                                                                                                                               :position 0}]
                                                                                                                             :configurable_product_links []
                                                                                                                             :configurable_product_options [{}]
                                                                                                                             :downloadable_product_links [{:extension_attributes {}
                                                                                                                                                           :id 0
                                                                                                                                                           :is_shareable 0
                                                                                                                                                           :link_file ""
                                                                                                                                                           :link_file_content {:extension_attributes {}
                                                                                                                                                                               :file_data ""
                                                                                                                                                                               :name ""}
                                                                                                                                                           :link_type ""
                                                                                                                                                           :link_url ""
                                                                                                                                                           :number_of_downloads 0
                                                                                                                                                           :price ""
                                                                                                                                                           :sample_file ""
                                                                                                                                                           :sample_file_content {}
                                                                                                                                                           :sample_type ""
                                                                                                                                                           :sample_url ""
                                                                                                                                                           :sort_order 0
                                                                                                                                                           :title ""}]
                                                                                                                             :downloadable_product_samples [{:extension_attributes {}
                                                                                                                                                             :id 0
                                                                                                                                                             :sample_file ""
                                                                                                                                                             :sample_file_content {}
                                                                                                                                                             :sample_type ""
                                                                                                                                                             :sample_url ""
                                                                                                                                                             :sort_order 0
                                                                                                                                                             :title ""}]
                                                                                                                             :giftcard_amounts [{:attribute_id 0
                                                                                                                                                 :extension_attributes {}
                                                                                                                                                 :value ""
                                                                                                                                                 :website_id 0
                                                                                                                                                 :website_value ""}]
                                                                                                                             :stock_item {:backorders 0
                                                                                                                                          :enable_qty_increments false
                                                                                                                                          :extension_attributes {}
                                                                                                                                          :is_decimal_divided false
                                                                                                                                          :is_in_stock false
                                                                                                                                          :is_qty_decimal false
                                                                                                                                          :item_id 0
                                                                                                                                          :low_stock_date ""
                                                                                                                                          :manage_stock false
                                                                                                                                          :max_sale_qty ""
                                                                                                                                          :min_qty ""
                                                                                                                                          :min_sale_qty ""
                                                                                                                                          :notify_stock_qty ""
                                                                                                                                          :product_id 0
                                                                                                                                          :qty ""
                                                                                                                                          :qty_increments ""
                                                                                                                                          :show_default_notification_message false
                                                                                                                                          :stock_id 0
                                                                                                                                          :stock_status_changed_auto 0
                                                                                                                                          :use_config_backorders false
                                                                                                                                          :use_config_enable_qty_inc false
                                                                                                                                          :use_config_manage_stock false
                                                                                                                                          :use_config_max_sale_qty false
                                                                                                                                          :use_config_min_qty false
                                                                                                                                          :use_config_min_sale_qty 0
                                                                                                                                          :use_config_notify_stock_qty false
                                                                                                                                          :use_config_qty_increments false}
                                                                                                                             :website_ids []}
                                                                                                      :id 0
                                                                                                      :media_gallery_entries [{:content {:base64_encoded_data ""
                                                                                                                                         :name ""
                                                                                                                                         :type ""}
                                                                                                                               :disabled false
                                                                                                                               :extension_attributes {:video_content {:media_type ""
                                                                                                                                                                      :video_description ""
                                                                                                                                                                      :video_metadata ""
                                                                                                                                                                      :video_provider ""
                                                                                                                                                                      :video_title ""
                                                                                                                                                                      :video_url ""}}
                                                                                                                               :file ""
                                                                                                                               :id 0
                                                                                                                               :label ""
                                                                                                                               :media_type ""
                                                                                                                               :position 0
                                                                                                                               :types []}]
                                                                                                      :name ""
                                                                                                      :options [{:extension_attributes {:vertex_flex_field ""}
                                                                                                                 :file_extension ""
                                                                                                                 :image_size_x 0
                                                                                                                 :image_size_y 0
                                                                                                                 :is_require false
                                                                                                                 :max_characters 0
                                                                                                                 :option_id 0
                                                                                                                 :price ""
                                                                                                                 :price_type ""
                                                                                                                 :product_sku ""
                                                                                                                 :sku ""
                                                                                                                 :sort_order 0
                                                                                                                 :title ""
                                                                                                                 :type ""
                                                                                                                 :values [{:option_type_id 0
                                                                                                                           :price ""
                                                                                                                           :price_type ""
                                                                                                                           :sku ""
                                                                                                                           :sort_order 0
                                                                                                                           :title ""}]}]
                                                                                                      :price ""
                                                                                                      :product_links [{:extension_attributes {:qty ""}
                                                                                                                       :link_type ""
                                                                                                                       :linked_product_sku ""
                                                                                                                       :linked_product_type ""
                                                                                                                       :position 0
                                                                                                                       :sku ""}]
                                                                                                      :sku ""
                                                                                                      :status 0
                                                                                                      :tier_prices [{:customer_group_id 0
                                                                                                                     :extension_attributes {:percentage_value ""
                                                                                                                                            :website_id 0}
                                                                                                                     :qty ""
                                                                                                                     :value ""}]
                                                                                                      :type_id ""
                                                                                                      :updated_at ""
                                                                                                      :visibility 0
                                                                                                      :weight ""}}})
require "http/client"

url = "{{baseUrl}}/V1/configurable-products/variation"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"options\": [\n    {\n      \"attribute_id\": \"\",\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"is_use_default\": false,\n      \"label\": \"\",\n      \"position\": 0,\n      \"product_id\": 0,\n      \"values\": [\n        {\n          \"extension_attributes\": {},\n          \"value_index\": 0\n        }\n      ]\n    }\n  ],\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {}\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\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}}/V1/configurable-products/variation"),
    Content = new StringContent("{\n  \"options\": [\n    {\n      \"attribute_id\": \"\",\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"is_use_default\": false,\n      \"label\": \"\",\n      \"position\": 0,\n      \"product_id\": 0,\n      \"values\": [\n        {\n          \"extension_attributes\": {},\n          \"value_index\": 0\n        }\n      ]\n    }\n  ],\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {}\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\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}}/V1/configurable-products/variation");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"options\": [\n    {\n      \"attribute_id\": \"\",\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"is_use_default\": false,\n      \"label\": \"\",\n      \"position\": 0,\n      \"product_id\": 0,\n      \"values\": [\n        {\n          \"extension_attributes\": {},\n          \"value_index\": 0\n        }\n      ]\n    }\n  ],\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {}\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/configurable-products/variation"

	payload := strings.NewReader("{\n  \"options\": [\n    {\n      \"attribute_id\": \"\",\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"is_use_default\": false,\n      \"label\": \"\",\n      \"position\": 0,\n      \"product_id\": 0,\n      \"values\": [\n        {\n          \"extension_attributes\": {},\n          \"value_index\": 0\n        }\n      ]\n    }\n  ],\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {}\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/configurable-products/variation HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 5349

{
  "options": [
    {
      "attribute_id": "",
      "extension_attributes": {},
      "id": 0,
      "is_use_default": false,
      "label": "",
      "position": 0,
      "product_id": 0,
      "values": [
        {
          "extension_attributes": {},
          "value_index": 0
        }
      ]
    }
  ],
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {}
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/configurable-products/variation")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"options\": [\n    {\n      \"attribute_id\": \"\",\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"is_use_default\": false,\n      \"label\": \"\",\n      \"position\": 0,\n      \"product_id\": 0,\n      \"values\": [\n        {\n          \"extension_attributes\": {},\n          \"value_index\": 0\n        }\n      ]\n    }\n  ],\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {}\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/configurable-products/variation"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"options\": [\n    {\n      \"attribute_id\": \"\",\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"is_use_default\": false,\n      \"label\": \"\",\n      \"position\": 0,\n      \"product_id\": 0,\n      \"values\": [\n        {\n          \"extension_attributes\": {},\n          \"value_index\": 0\n        }\n      ]\n    }\n  ],\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {}\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\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  \"options\": [\n    {\n      \"attribute_id\": \"\",\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"is_use_default\": false,\n      \"label\": \"\",\n      \"position\": 0,\n      \"product_id\": 0,\n      \"values\": [\n        {\n          \"extension_attributes\": {},\n          \"value_index\": 0\n        }\n      ]\n    }\n  ],\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {}\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/configurable-products/variation")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/configurable-products/variation")
  .header("content-type", "application/json")
  .body("{\n  \"options\": [\n    {\n      \"attribute_id\": \"\",\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"is_use_default\": false,\n      \"label\": \"\",\n      \"position\": 0,\n      \"product_id\": 0,\n      \"values\": [\n        {\n          \"extension_attributes\": {},\n          \"value_index\": 0\n        }\n      ]\n    }\n  ],\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {}\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  options: [
    {
      attribute_id: '',
      extension_attributes: {},
      id: 0,
      is_use_default: false,
      label: '',
      position: 0,
      product_id: 0,
      values: [
        {
          extension_attributes: {},
          value_index: 0
        }
      ]
    }
  ],
  product: {
    attribute_set_id: 0,
    created_at: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    extension_attributes: {
      bundle_product_options: [
        {
          extension_attributes: {},
          option_id: 0,
          position: 0,
          product_links: [
            {
              can_change_quantity: 0,
              extension_attributes: {},
              id: '',
              is_default: false,
              option_id: 0,
              position: 0,
              price: '',
              price_type: 0,
              qty: '',
              sku: ''
            }
          ],
          required: false,
          sku: '',
          title: '',
          type: ''
        }
      ],
      category_links: [
        {
          category_id: '',
          extension_attributes: {},
          position: 0
        }
      ],
      configurable_product_links: [],
      configurable_product_options: [
        {}
      ],
      downloadable_product_links: [
        {
          extension_attributes: {},
          id: 0,
          is_shareable: 0,
          link_file: '',
          link_file_content: {
            extension_attributes: {},
            file_data: '',
            name: ''
          },
          link_type: '',
          link_url: '',
          number_of_downloads: 0,
          price: '',
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      downloadable_product_samples: [
        {
          extension_attributes: {},
          id: 0,
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      giftcard_amounts: [
        {
          attribute_id: 0,
          extension_attributes: {},
          value: '',
          website_id: 0,
          website_value: ''
        }
      ],
      stock_item: {
        backorders: 0,
        enable_qty_increments: false,
        extension_attributes: {},
        is_decimal_divided: false,
        is_in_stock: false,
        is_qty_decimal: false,
        item_id: 0,
        low_stock_date: '',
        manage_stock: false,
        max_sale_qty: '',
        min_qty: '',
        min_sale_qty: '',
        notify_stock_qty: '',
        product_id: 0,
        qty: '',
        qty_increments: '',
        show_default_notification_message: false,
        stock_id: 0,
        stock_status_changed_auto: 0,
        use_config_backorders: false,
        use_config_enable_qty_inc: false,
        use_config_manage_stock: false,
        use_config_max_sale_qty: false,
        use_config_min_qty: false,
        use_config_min_sale_qty: 0,
        use_config_notify_stock_qty: false,
        use_config_qty_increments: false
      },
      website_ids: []
    },
    id: 0,
    media_gallery_entries: [
      {
        content: {
          base64_encoded_data: '',
          name: '',
          type: ''
        },
        disabled: false,
        extension_attributes: {
          video_content: {
            media_type: '',
            video_description: '',
            video_metadata: '',
            video_provider: '',
            video_title: '',
            video_url: ''
          }
        },
        file: '',
        id: 0,
        label: '',
        media_type: '',
        position: 0,
        types: []
      }
    ],
    name: '',
    options: [
      {
        extension_attributes: {
          vertex_flex_field: ''
        },
        file_extension: '',
        image_size_x: 0,
        image_size_y: 0,
        is_require: false,
        max_characters: 0,
        option_id: 0,
        price: '',
        price_type: '',
        product_sku: '',
        sku: '',
        sort_order: 0,
        title: '',
        type: '',
        values: [
          {
            option_type_id: 0,
            price: '',
            price_type: '',
            sku: '',
            sort_order: 0,
            title: ''
          }
        ]
      }
    ],
    price: '',
    product_links: [
      {
        extension_attributes: {
          qty: ''
        },
        link_type: '',
        linked_product_sku: '',
        linked_product_type: '',
        position: 0,
        sku: ''
      }
    ],
    sku: '',
    status: 0,
    tier_prices: [
      {
        customer_group_id: 0,
        extension_attributes: {
          percentage_value: '',
          website_id: 0
        },
        qty: '',
        value: ''
      }
    ],
    type_id: '',
    updated_at: '',
    visibility: 0,
    weight: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/configurable-products/variation');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/configurable-products/variation',
  headers: {'content-type': 'application/json'},
  data: {
    options: [
      {
        attribute_id: '',
        extension_attributes: {},
        id: 0,
        is_use_default: false,
        label: '',
        position: 0,
        product_id: 0,
        values: [{extension_attributes: {}, value_index: 0}]
      }
    ],
    product: {
      attribute_set_id: 0,
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {
        bundle_product_options: [
          {
            extension_attributes: {},
            option_id: 0,
            position: 0,
            product_links: [
              {
                can_change_quantity: 0,
                extension_attributes: {},
                id: '',
                is_default: false,
                option_id: 0,
                position: 0,
                price: '',
                price_type: 0,
                qty: '',
                sku: ''
              }
            ],
            required: false,
            sku: '',
            title: '',
            type: ''
          }
        ],
        category_links: [{category_id: '', extension_attributes: {}, position: 0}],
        configurable_product_links: [],
        configurable_product_options: [{}],
        downloadable_product_links: [
          {
            extension_attributes: {},
            id: 0,
            is_shareable: 0,
            link_file: '',
            link_file_content: {extension_attributes: {}, file_data: '', name: ''},
            link_type: '',
            link_url: '',
            number_of_downloads: 0,
            price: '',
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        downloadable_product_samples: [
          {
            extension_attributes: {},
            id: 0,
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        giftcard_amounts: [
          {
            attribute_id: 0,
            extension_attributes: {},
            value: '',
            website_id: 0,
            website_value: ''
          }
        ],
        stock_item: {
          backorders: 0,
          enable_qty_increments: false,
          extension_attributes: {},
          is_decimal_divided: false,
          is_in_stock: false,
          is_qty_decimal: false,
          item_id: 0,
          low_stock_date: '',
          manage_stock: false,
          max_sale_qty: '',
          min_qty: '',
          min_sale_qty: '',
          notify_stock_qty: '',
          product_id: 0,
          qty: '',
          qty_increments: '',
          show_default_notification_message: false,
          stock_id: 0,
          stock_status_changed_auto: 0,
          use_config_backorders: false,
          use_config_enable_qty_inc: false,
          use_config_manage_stock: false,
          use_config_max_sale_qty: false,
          use_config_min_qty: false,
          use_config_min_sale_qty: 0,
          use_config_notify_stock_qty: false,
          use_config_qty_increments: false
        },
        website_ids: []
      },
      id: 0,
      media_gallery_entries: [
        {
          content: {base64_encoded_data: '', name: '', type: ''},
          disabled: false,
          extension_attributes: {
            video_content: {
              media_type: '',
              video_description: '',
              video_metadata: '',
              video_provider: '',
              video_title: '',
              video_url: ''
            }
          },
          file: '',
          id: 0,
          label: '',
          media_type: '',
          position: 0,
          types: []
        }
      ],
      name: '',
      options: [
        {
          extension_attributes: {vertex_flex_field: ''},
          file_extension: '',
          image_size_x: 0,
          image_size_y: 0,
          is_require: false,
          max_characters: 0,
          option_id: 0,
          price: '',
          price_type: '',
          product_sku: '',
          sku: '',
          sort_order: 0,
          title: '',
          type: '',
          values: [
            {
              option_type_id: 0,
              price: '',
              price_type: '',
              sku: '',
              sort_order: 0,
              title: ''
            }
          ]
        }
      ],
      price: '',
      product_links: [
        {
          extension_attributes: {qty: ''},
          link_type: '',
          linked_product_sku: '',
          linked_product_type: '',
          position: 0,
          sku: ''
        }
      ],
      sku: '',
      status: 0,
      tier_prices: [
        {
          customer_group_id: 0,
          extension_attributes: {percentage_value: '', website_id: 0},
          qty: '',
          value: ''
        }
      ],
      type_id: '',
      updated_at: '',
      visibility: 0,
      weight: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/configurable-products/variation';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"options":[{"attribute_id":"","extension_attributes":{},"id":0,"is_use_default":false,"label":"","position":0,"product_id":0,"values":[{"extension_attributes":{},"value_index":0}]}],"product":{"attribute_set_id":0,"created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{"bundle_product_options":[{"extension_attributes":{},"option_id":0,"position":0,"product_links":[{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}],"required":false,"sku":"","title":"","type":""}],"category_links":[{"category_id":"","extension_attributes":{},"position":0}],"configurable_product_links":[],"configurable_product_options":[{}],"downloadable_product_links":[{"extension_attributes":{},"id":0,"is_shareable":0,"link_file":"","link_file_content":{"extension_attributes":{},"file_data":"","name":""},"link_type":"","link_url":"","number_of_downloads":0,"price":"","sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"downloadable_product_samples":[{"extension_attributes":{},"id":0,"sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"giftcard_amounts":[{"attribute_id":0,"extension_attributes":{},"value":"","website_id":0,"website_value":""}],"stock_item":{"backorders":0,"enable_qty_increments":false,"extension_attributes":{},"is_decimal_divided":false,"is_in_stock":false,"is_qty_decimal":false,"item_id":0,"low_stock_date":"","manage_stock":false,"max_sale_qty":"","min_qty":"","min_sale_qty":"","notify_stock_qty":"","product_id":0,"qty":"","qty_increments":"","show_default_notification_message":false,"stock_id":0,"stock_status_changed_auto":0,"use_config_backorders":false,"use_config_enable_qty_inc":false,"use_config_manage_stock":false,"use_config_max_sale_qty":false,"use_config_min_qty":false,"use_config_min_sale_qty":0,"use_config_notify_stock_qty":false,"use_config_qty_increments":false},"website_ids":[]},"id":0,"media_gallery_entries":[{"content":{"base64_encoded_data":"","name":"","type":""},"disabled":false,"extension_attributes":{"video_content":{"media_type":"","video_description":"","video_metadata":"","video_provider":"","video_title":"","video_url":""}},"file":"","id":0,"label":"","media_type":"","position":0,"types":[]}],"name":"","options":[{"extension_attributes":{"vertex_flex_field":""},"file_extension":"","image_size_x":0,"image_size_y":0,"is_require":false,"max_characters":0,"option_id":0,"price":"","price_type":"","product_sku":"","sku":"","sort_order":0,"title":"","type":"","values":[{"option_type_id":0,"price":"","price_type":"","sku":"","sort_order":0,"title":""}]}],"price":"","product_links":[{"extension_attributes":{"qty":""},"link_type":"","linked_product_sku":"","linked_product_type":"","position":0,"sku":""}],"sku":"","status":0,"tier_prices":[{"customer_group_id":0,"extension_attributes":{"percentage_value":"","website_id":0},"qty":"","value":""}],"type_id":"","updated_at":"","visibility":0,"weight":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/configurable-products/variation',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "options": [\n    {\n      "attribute_id": "",\n      "extension_attributes": {},\n      "id": 0,\n      "is_use_default": false,\n      "label": "",\n      "position": 0,\n      "product_id": 0,\n      "values": [\n        {\n          "extension_attributes": {},\n          "value_index": 0\n        }\n      ]\n    }\n  ],\n  "product": {\n    "attribute_set_id": 0,\n    "created_at": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "extension_attributes": {\n      "bundle_product_options": [\n        {\n          "extension_attributes": {},\n          "option_id": 0,\n          "position": 0,\n          "product_links": [\n            {\n              "can_change_quantity": 0,\n              "extension_attributes": {},\n              "id": "",\n              "is_default": false,\n              "option_id": 0,\n              "position": 0,\n              "price": "",\n              "price_type": 0,\n              "qty": "",\n              "sku": ""\n            }\n          ],\n          "required": false,\n          "sku": "",\n          "title": "",\n          "type": ""\n        }\n      ],\n      "category_links": [\n        {\n          "category_id": "",\n          "extension_attributes": {},\n          "position": 0\n        }\n      ],\n      "configurable_product_links": [],\n      "configurable_product_options": [\n        {}\n      ],\n      "downloadable_product_links": [\n        {\n          "extension_attributes": {},\n          "id": 0,\n          "is_shareable": 0,\n          "link_file": "",\n          "link_file_content": {\n            "extension_attributes": {},\n            "file_data": "",\n            "name": ""\n          },\n          "link_type": "",\n          "link_url": "",\n          "number_of_downloads": 0,\n          "price": "",\n          "sample_file": "",\n          "sample_file_content": {},\n          "sample_type": "",\n          "sample_url": "",\n          "sort_order": 0,\n          "title": ""\n        }\n      ],\n      "downloadable_product_samples": [\n        {\n          "extension_attributes": {},\n          "id": 0,\n          "sample_file": "",\n          "sample_file_content": {},\n          "sample_type": "",\n          "sample_url": "",\n          "sort_order": 0,\n          "title": ""\n        }\n      ],\n      "giftcard_amounts": [\n        {\n          "attribute_id": 0,\n          "extension_attributes": {},\n          "value": "",\n          "website_id": 0,\n          "website_value": ""\n        }\n      ],\n      "stock_item": {\n        "backorders": 0,\n        "enable_qty_increments": false,\n        "extension_attributes": {},\n        "is_decimal_divided": false,\n        "is_in_stock": false,\n        "is_qty_decimal": false,\n        "item_id": 0,\n        "low_stock_date": "",\n        "manage_stock": false,\n        "max_sale_qty": "",\n        "min_qty": "",\n        "min_sale_qty": "",\n        "notify_stock_qty": "",\n        "product_id": 0,\n        "qty": "",\n        "qty_increments": "",\n        "show_default_notification_message": false,\n        "stock_id": 0,\n        "stock_status_changed_auto": 0,\n        "use_config_backorders": false,\n        "use_config_enable_qty_inc": false,\n        "use_config_manage_stock": false,\n        "use_config_max_sale_qty": false,\n        "use_config_min_qty": false,\n        "use_config_min_sale_qty": 0,\n        "use_config_notify_stock_qty": false,\n        "use_config_qty_increments": false\n      },\n      "website_ids": []\n    },\n    "id": 0,\n    "media_gallery_entries": [\n      {\n        "content": {\n          "base64_encoded_data": "",\n          "name": "",\n          "type": ""\n        },\n        "disabled": false,\n        "extension_attributes": {\n          "video_content": {\n            "media_type": "",\n            "video_description": "",\n            "video_metadata": "",\n            "video_provider": "",\n            "video_title": "",\n            "video_url": ""\n          }\n        },\n        "file": "",\n        "id": 0,\n        "label": "",\n        "media_type": "",\n        "position": 0,\n        "types": []\n      }\n    ],\n    "name": "",\n    "options": [\n      {\n        "extension_attributes": {\n          "vertex_flex_field": ""\n        },\n        "file_extension": "",\n        "image_size_x": 0,\n        "image_size_y": 0,\n        "is_require": false,\n        "max_characters": 0,\n        "option_id": 0,\n        "price": "",\n        "price_type": "",\n        "product_sku": "",\n        "sku": "",\n        "sort_order": 0,\n        "title": "",\n        "type": "",\n        "values": [\n          {\n            "option_type_id": 0,\n            "price": "",\n            "price_type": "",\n            "sku": "",\n            "sort_order": 0,\n            "title": ""\n          }\n        ]\n      }\n    ],\n    "price": "",\n    "product_links": [\n      {\n        "extension_attributes": {\n          "qty": ""\n        },\n        "link_type": "",\n        "linked_product_sku": "",\n        "linked_product_type": "",\n        "position": 0,\n        "sku": ""\n      }\n    ],\n    "sku": "",\n    "status": 0,\n    "tier_prices": [\n      {\n        "customer_group_id": 0,\n        "extension_attributes": {\n          "percentage_value": "",\n          "website_id": 0\n        },\n        "qty": "",\n        "value": ""\n      }\n    ],\n    "type_id": "",\n    "updated_at": "",\n    "visibility": 0,\n    "weight": ""\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  \"options\": [\n    {\n      \"attribute_id\": \"\",\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"is_use_default\": false,\n      \"label\": \"\",\n      \"position\": 0,\n      \"product_id\": 0,\n      \"values\": [\n        {\n          \"extension_attributes\": {},\n          \"value_index\": 0\n        }\n      ]\n    }\n  ],\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {}\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/configurable-products/variation")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/configurable-products/variation',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  options: [
    {
      attribute_id: '',
      extension_attributes: {},
      id: 0,
      is_use_default: false,
      label: '',
      position: 0,
      product_id: 0,
      values: [{extension_attributes: {}, value_index: 0}]
    }
  ],
  product: {
    attribute_set_id: 0,
    created_at: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    extension_attributes: {
      bundle_product_options: [
        {
          extension_attributes: {},
          option_id: 0,
          position: 0,
          product_links: [
            {
              can_change_quantity: 0,
              extension_attributes: {},
              id: '',
              is_default: false,
              option_id: 0,
              position: 0,
              price: '',
              price_type: 0,
              qty: '',
              sku: ''
            }
          ],
          required: false,
          sku: '',
          title: '',
          type: ''
        }
      ],
      category_links: [{category_id: '', extension_attributes: {}, position: 0}],
      configurable_product_links: [],
      configurable_product_options: [{}],
      downloadable_product_links: [
        {
          extension_attributes: {},
          id: 0,
          is_shareable: 0,
          link_file: '',
          link_file_content: {extension_attributes: {}, file_data: '', name: ''},
          link_type: '',
          link_url: '',
          number_of_downloads: 0,
          price: '',
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      downloadable_product_samples: [
        {
          extension_attributes: {},
          id: 0,
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      giftcard_amounts: [
        {
          attribute_id: 0,
          extension_attributes: {},
          value: '',
          website_id: 0,
          website_value: ''
        }
      ],
      stock_item: {
        backorders: 0,
        enable_qty_increments: false,
        extension_attributes: {},
        is_decimal_divided: false,
        is_in_stock: false,
        is_qty_decimal: false,
        item_id: 0,
        low_stock_date: '',
        manage_stock: false,
        max_sale_qty: '',
        min_qty: '',
        min_sale_qty: '',
        notify_stock_qty: '',
        product_id: 0,
        qty: '',
        qty_increments: '',
        show_default_notification_message: false,
        stock_id: 0,
        stock_status_changed_auto: 0,
        use_config_backorders: false,
        use_config_enable_qty_inc: false,
        use_config_manage_stock: false,
        use_config_max_sale_qty: false,
        use_config_min_qty: false,
        use_config_min_sale_qty: 0,
        use_config_notify_stock_qty: false,
        use_config_qty_increments: false
      },
      website_ids: []
    },
    id: 0,
    media_gallery_entries: [
      {
        content: {base64_encoded_data: '', name: '', type: ''},
        disabled: false,
        extension_attributes: {
          video_content: {
            media_type: '',
            video_description: '',
            video_metadata: '',
            video_provider: '',
            video_title: '',
            video_url: ''
          }
        },
        file: '',
        id: 0,
        label: '',
        media_type: '',
        position: 0,
        types: []
      }
    ],
    name: '',
    options: [
      {
        extension_attributes: {vertex_flex_field: ''},
        file_extension: '',
        image_size_x: 0,
        image_size_y: 0,
        is_require: false,
        max_characters: 0,
        option_id: 0,
        price: '',
        price_type: '',
        product_sku: '',
        sku: '',
        sort_order: 0,
        title: '',
        type: '',
        values: [
          {
            option_type_id: 0,
            price: '',
            price_type: '',
            sku: '',
            sort_order: 0,
            title: ''
          }
        ]
      }
    ],
    price: '',
    product_links: [
      {
        extension_attributes: {qty: ''},
        link_type: '',
        linked_product_sku: '',
        linked_product_type: '',
        position: 0,
        sku: ''
      }
    ],
    sku: '',
    status: 0,
    tier_prices: [
      {
        customer_group_id: 0,
        extension_attributes: {percentage_value: '', website_id: 0},
        qty: '',
        value: ''
      }
    ],
    type_id: '',
    updated_at: '',
    visibility: 0,
    weight: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/configurable-products/variation',
  headers: {'content-type': 'application/json'},
  body: {
    options: [
      {
        attribute_id: '',
        extension_attributes: {},
        id: 0,
        is_use_default: false,
        label: '',
        position: 0,
        product_id: 0,
        values: [{extension_attributes: {}, value_index: 0}]
      }
    ],
    product: {
      attribute_set_id: 0,
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {
        bundle_product_options: [
          {
            extension_attributes: {},
            option_id: 0,
            position: 0,
            product_links: [
              {
                can_change_quantity: 0,
                extension_attributes: {},
                id: '',
                is_default: false,
                option_id: 0,
                position: 0,
                price: '',
                price_type: 0,
                qty: '',
                sku: ''
              }
            ],
            required: false,
            sku: '',
            title: '',
            type: ''
          }
        ],
        category_links: [{category_id: '', extension_attributes: {}, position: 0}],
        configurable_product_links: [],
        configurable_product_options: [{}],
        downloadable_product_links: [
          {
            extension_attributes: {},
            id: 0,
            is_shareable: 0,
            link_file: '',
            link_file_content: {extension_attributes: {}, file_data: '', name: ''},
            link_type: '',
            link_url: '',
            number_of_downloads: 0,
            price: '',
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        downloadable_product_samples: [
          {
            extension_attributes: {},
            id: 0,
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        giftcard_amounts: [
          {
            attribute_id: 0,
            extension_attributes: {},
            value: '',
            website_id: 0,
            website_value: ''
          }
        ],
        stock_item: {
          backorders: 0,
          enable_qty_increments: false,
          extension_attributes: {},
          is_decimal_divided: false,
          is_in_stock: false,
          is_qty_decimal: false,
          item_id: 0,
          low_stock_date: '',
          manage_stock: false,
          max_sale_qty: '',
          min_qty: '',
          min_sale_qty: '',
          notify_stock_qty: '',
          product_id: 0,
          qty: '',
          qty_increments: '',
          show_default_notification_message: false,
          stock_id: 0,
          stock_status_changed_auto: 0,
          use_config_backorders: false,
          use_config_enable_qty_inc: false,
          use_config_manage_stock: false,
          use_config_max_sale_qty: false,
          use_config_min_qty: false,
          use_config_min_sale_qty: 0,
          use_config_notify_stock_qty: false,
          use_config_qty_increments: false
        },
        website_ids: []
      },
      id: 0,
      media_gallery_entries: [
        {
          content: {base64_encoded_data: '', name: '', type: ''},
          disabled: false,
          extension_attributes: {
            video_content: {
              media_type: '',
              video_description: '',
              video_metadata: '',
              video_provider: '',
              video_title: '',
              video_url: ''
            }
          },
          file: '',
          id: 0,
          label: '',
          media_type: '',
          position: 0,
          types: []
        }
      ],
      name: '',
      options: [
        {
          extension_attributes: {vertex_flex_field: ''},
          file_extension: '',
          image_size_x: 0,
          image_size_y: 0,
          is_require: false,
          max_characters: 0,
          option_id: 0,
          price: '',
          price_type: '',
          product_sku: '',
          sku: '',
          sort_order: 0,
          title: '',
          type: '',
          values: [
            {
              option_type_id: 0,
              price: '',
              price_type: '',
              sku: '',
              sort_order: 0,
              title: ''
            }
          ]
        }
      ],
      price: '',
      product_links: [
        {
          extension_attributes: {qty: ''},
          link_type: '',
          linked_product_sku: '',
          linked_product_type: '',
          position: 0,
          sku: ''
        }
      ],
      sku: '',
      status: 0,
      tier_prices: [
        {
          customer_group_id: 0,
          extension_attributes: {percentage_value: '', website_id: 0},
          qty: '',
          value: ''
        }
      ],
      type_id: '',
      updated_at: '',
      visibility: 0,
      weight: ''
    }
  },
  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}}/V1/configurable-products/variation');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  options: [
    {
      attribute_id: '',
      extension_attributes: {},
      id: 0,
      is_use_default: false,
      label: '',
      position: 0,
      product_id: 0,
      values: [
        {
          extension_attributes: {},
          value_index: 0
        }
      ]
    }
  ],
  product: {
    attribute_set_id: 0,
    created_at: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    extension_attributes: {
      bundle_product_options: [
        {
          extension_attributes: {},
          option_id: 0,
          position: 0,
          product_links: [
            {
              can_change_quantity: 0,
              extension_attributes: {},
              id: '',
              is_default: false,
              option_id: 0,
              position: 0,
              price: '',
              price_type: 0,
              qty: '',
              sku: ''
            }
          ],
          required: false,
          sku: '',
          title: '',
          type: ''
        }
      ],
      category_links: [
        {
          category_id: '',
          extension_attributes: {},
          position: 0
        }
      ],
      configurable_product_links: [],
      configurable_product_options: [
        {}
      ],
      downloadable_product_links: [
        {
          extension_attributes: {},
          id: 0,
          is_shareable: 0,
          link_file: '',
          link_file_content: {
            extension_attributes: {},
            file_data: '',
            name: ''
          },
          link_type: '',
          link_url: '',
          number_of_downloads: 0,
          price: '',
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      downloadable_product_samples: [
        {
          extension_attributes: {},
          id: 0,
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      giftcard_amounts: [
        {
          attribute_id: 0,
          extension_attributes: {},
          value: '',
          website_id: 0,
          website_value: ''
        }
      ],
      stock_item: {
        backorders: 0,
        enable_qty_increments: false,
        extension_attributes: {},
        is_decimal_divided: false,
        is_in_stock: false,
        is_qty_decimal: false,
        item_id: 0,
        low_stock_date: '',
        manage_stock: false,
        max_sale_qty: '',
        min_qty: '',
        min_sale_qty: '',
        notify_stock_qty: '',
        product_id: 0,
        qty: '',
        qty_increments: '',
        show_default_notification_message: false,
        stock_id: 0,
        stock_status_changed_auto: 0,
        use_config_backorders: false,
        use_config_enable_qty_inc: false,
        use_config_manage_stock: false,
        use_config_max_sale_qty: false,
        use_config_min_qty: false,
        use_config_min_sale_qty: 0,
        use_config_notify_stock_qty: false,
        use_config_qty_increments: false
      },
      website_ids: []
    },
    id: 0,
    media_gallery_entries: [
      {
        content: {
          base64_encoded_data: '',
          name: '',
          type: ''
        },
        disabled: false,
        extension_attributes: {
          video_content: {
            media_type: '',
            video_description: '',
            video_metadata: '',
            video_provider: '',
            video_title: '',
            video_url: ''
          }
        },
        file: '',
        id: 0,
        label: '',
        media_type: '',
        position: 0,
        types: []
      }
    ],
    name: '',
    options: [
      {
        extension_attributes: {
          vertex_flex_field: ''
        },
        file_extension: '',
        image_size_x: 0,
        image_size_y: 0,
        is_require: false,
        max_characters: 0,
        option_id: 0,
        price: '',
        price_type: '',
        product_sku: '',
        sku: '',
        sort_order: 0,
        title: '',
        type: '',
        values: [
          {
            option_type_id: 0,
            price: '',
            price_type: '',
            sku: '',
            sort_order: 0,
            title: ''
          }
        ]
      }
    ],
    price: '',
    product_links: [
      {
        extension_attributes: {
          qty: ''
        },
        link_type: '',
        linked_product_sku: '',
        linked_product_type: '',
        position: 0,
        sku: ''
      }
    ],
    sku: '',
    status: 0,
    tier_prices: [
      {
        customer_group_id: 0,
        extension_attributes: {
          percentage_value: '',
          website_id: 0
        },
        qty: '',
        value: ''
      }
    ],
    type_id: '',
    updated_at: '',
    visibility: 0,
    weight: ''
  }
});

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}}/V1/configurable-products/variation',
  headers: {'content-type': 'application/json'},
  data: {
    options: [
      {
        attribute_id: '',
        extension_attributes: {},
        id: 0,
        is_use_default: false,
        label: '',
        position: 0,
        product_id: 0,
        values: [{extension_attributes: {}, value_index: 0}]
      }
    ],
    product: {
      attribute_set_id: 0,
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {
        bundle_product_options: [
          {
            extension_attributes: {},
            option_id: 0,
            position: 0,
            product_links: [
              {
                can_change_quantity: 0,
                extension_attributes: {},
                id: '',
                is_default: false,
                option_id: 0,
                position: 0,
                price: '',
                price_type: 0,
                qty: '',
                sku: ''
              }
            ],
            required: false,
            sku: '',
            title: '',
            type: ''
          }
        ],
        category_links: [{category_id: '', extension_attributes: {}, position: 0}],
        configurable_product_links: [],
        configurable_product_options: [{}],
        downloadable_product_links: [
          {
            extension_attributes: {},
            id: 0,
            is_shareable: 0,
            link_file: '',
            link_file_content: {extension_attributes: {}, file_data: '', name: ''},
            link_type: '',
            link_url: '',
            number_of_downloads: 0,
            price: '',
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        downloadable_product_samples: [
          {
            extension_attributes: {},
            id: 0,
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        giftcard_amounts: [
          {
            attribute_id: 0,
            extension_attributes: {},
            value: '',
            website_id: 0,
            website_value: ''
          }
        ],
        stock_item: {
          backorders: 0,
          enable_qty_increments: false,
          extension_attributes: {},
          is_decimal_divided: false,
          is_in_stock: false,
          is_qty_decimal: false,
          item_id: 0,
          low_stock_date: '',
          manage_stock: false,
          max_sale_qty: '',
          min_qty: '',
          min_sale_qty: '',
          notify_stock_qty: '',
          product_id: 0,
          qty: '',
          qty_increments: '',
          show_default_notification_message: false,
          stock_id: 0,
          stock_status_changed_auto: 0,
          use_config_backorders: false,
          use_config_enable_qty_inc: false,
          use_config_manage_stock: false,
          use_config_max_sale_qty: false,
          use_config_min_qty: false,
          use_config_min_sale_qty: 0,
          use_config_notify_stock_qty: false,
          use_config_qty_increments: false
        },
        website_ids: []
      },
      id: 0,
      media_gallery_entries: [
        {
          content: {base64_encoded_data: '', name: '', type: ''},
          disabled: false,
          extension_attributes: {
            video_content: {
              media_type: '',
              video_description: '',
              video_metadata: '',
              video_provider: '',
              video_title: '',
              video_url: ''
            }
          },
          file: '',
          id: 0,
          label: '',
          media_type: '',
          position: 0,
          types: []
        }
      ],
      name: '',
      options: [
        {
          extension_attributes: {vertex_flex_field: ''},
          file_extension: '',
          image_size_x: 0,
          image_size_y: 0,
          is_require: false,
          max_characters: 0,
          option_id: 0,
          price: '',
          price_type: '',
          product_sku: '',
          sku: '',
          sort_order: 0,
          title: '',
          type: '',
          values: [
            {
              option_type_id: 0,
              price: '',
              price_type: '',
              sku: '',
              sort_order: 0,
              title: ''
            }
          ]
        }
      ],
      price: '',
      product_links: [
        {
          extension_attributes: {qty: ''},
          link_type: '',
          linked_product_sku: '',
          linked_product_type: '',
          position: 0,
          sku: ''
        }
      ],
      sku: '',
      status: 0,
      tier_prices: [
        {
          customer_group_id: 0,
          extension_attributes: {percentage_value: '', website_id: 0},
          qty: '',
          value: ''
        }
      ],
      type_id: '',
      updated_at: '',
      visibility: 0,
      weight: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/configurable-products/variation';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"options":[{"attribute_id":"","extension_attributes":{},"id":0,"is_use_default":false,"label":"","position":0,"product_id":0,"values":[{"extension_attributes":{},"value_index":0}]}],"product":{"attribute_set_id":0,"created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{"bundle_product_options":[{"extension_attributes":{},"option_id":0,"position":0,"product_links":[{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}],"required":false,"sku":"","title":"","type":""}],"category_links":[{"category_id":"","extension_attributes":{},"position":0}],"configurable_product_links":[],"configurable_product_options":[{}],"downloadable_product_links":[{"extension_attributes":{},"id":0,"is_shareable":0,"link_file":"","link_file_content":{"extension_attributes":{},"file_data":"","name":""},"link_type":"","link_url":"","number_of_downloads":0,"price":"","sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"downloadable_product_samples":[{"extension_attributes":{},"id":0,"sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"giftcard_amounts":[{"attribute_id":0,"extension_attributes":{},"value":"","website_id":0,"website_value":""}],"stock_item":{"backorders":0,"enable_qty_increments":false,"extension_attributes":{},"is_decimal_divided":false,"is_in_stock":false,"is_qty_decimal":false,"item_id":0,"low_stock_date":"","manage_stock":false,"max_sale_qty":"","min_qty":"","min_sale_qty":"","notify_stock_qty":"","product_id":0,"qty":"","qty_increments":"","show_default_notification_message":false,"stock_id":0,"stock_status_changed_auto":0,"use_config_backorders":false,"use_config_enable_qty_inc":false,"use_config_manage_stock":false,"use_config_max_sale_qty":false,"use_config_min_qty":false,"use_config_min_sale_qty":0,"use_config_notify_stock_qty":false,"use_config_qty_increments":false},"website_ids":[]},"id":0,"media_gallery_entries":[{"content":{"base64_encoded_data":"","name":"","type":""},"disabled":false,"extension_attributes":{"video_content":{"media_type":"","video_description":"","video_metadata":"","video_provider":"","video_title":"","video_url":""}},"file":"","id":0,"label":"","media_type":"","position":0,"types":[]}],"name":"","options":[{"extension_attributes":{"vertex_flex_field":""},"file_extension":"","image_size_x":0,"image_size_y":0,"is_require":false,"max_characters":0,"option_id":0,"price":"","price_type":"","product_sku":"","sku":"","sort_order":0,"title":"","type":"","values":[{"option_type_id":0,"price":"","price_type":"","sku":"","sort_order":0,"title":""}]}],"price":"","product_links":[{"extension_attributes":{"qty":""},"link_type":"","linked_product_sku":"","linked_product_type":"","position":0,"sku":""}],"sku":"","status":0,"tier_prices":[{"customer_group_id":0,"extension_attributes":{"percentage_value":"","website_id":0},"qty":"","value":""}],"type_id":"","updated_at":"","visibility":0,"weight":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"options": @[ @{ @"attribute_id": @"", @"extension_attributes": @{  }, @"id": @0, @"is_use_default": @NO, @"label": @"", @"position": @0, @"product_id": @0, @"values": @[ @{ @"extension_attributes": @{  }, @"value_index": @0 } ] } ],
                              @"product": @{ @"attribute_set_id": @0, @"created_at": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"extension_attributes": @{ @"bundle_product_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @0, @"position": @0, @"product_links": @[ @{ @"can_change_quantity": @0, @"extension_attributes": @{  }, @"id": @"", @"is_default": @NO, @"option_id": @0, @"position": @0, @"price": @"", @"price_type": @0, @"qty": @"", @"sku": @"" } ], @"required": @NO, @"sku": @"", @"title": @"", @"type": @"" } ], @"category_links": @[ @{ @"category_id": @"", @"extension_attributes": @{  }, @"position": @0 } ], @"configurable_product_links": @[  ], @"configurable_product_options": @[ @{  } ], @"downloadable_product_links": @[ @{ @"extension_attributes": @{  }, @"id": @0, @"is_shareable": @0, @"link_file": @"", @"link_file_content": @{ @"extension_attributes": @{  }, @"file_data": @"", @"name": @"" }, @"link_type": @"", @"link_url": @"", @"number_of_downloads": @0, @"price": @"", @"sample_file": @"", @"sample_file_content": @{  }, @"sample_type": @"", @"sample_url": @"", @"sort_order": @0, @"title": @"" } ], @"downloadable_product_samples": @[ @{ @"extension_attributes": @{  }, @"id": @0, @"sample_file": @"", @"sample_file_content": @{  }, @"sample_type": @"", @"sample_url": @"", @"sort_order": @0, @"title": @"" } ], @"giftcard_amounts": @[ @{ @"attribute_id": @0, @"extension_attributes": @{  }, @"value": @"", @"website_id": @0, @"website_value": @"" } ], @"stock_item": @{ @"backorders": @0, @"enable_qty_increments": @NO, @"extension_attributes": @{  }, @"is_decimal_divided": @NO, @"is_in_stock": @NO, @"is_qty_decimal": @NO, @"item_id": @0, @"low_stock_date": @"", @"manage_stock": @NO, @"max_sale_qty": @"", @"min_qty": @"", @"min_sale_qty": @"", @"notify_stock_qty": @"", @"product_id": @0, @"qty": @"", @"qty_increments": @"", @"show_default_notification_message": @NO, @"stock_id": @0, @"stock_status_changed_auto": @0, @"use_config_backorders": @NO, @"use_config_enable_qty_inc": @NO, @"use_config_manage_stock": @NO, @"use_config_max_sale_qty": @NO, @"use_config_min_qty": @NO, @"use_config_min_sale_qty": @0, @"use_config_notify_stock_qty": @NO, @"use_config_qty_increments": @NO }, @"website_ids": @[  ] }, @"id": @0, @"media_gallery_entries": @[ @{ @"content": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" }, @"disabled": @NO, @"extension_attributes": @{ @"video_content": @{ @"media_type": @"", @"video_description": @"", @"video_metadata": @"", @"video_provider": @"", @"video_title": @"", @"video_url": @"" } }, @"file": @"", @"id": @0, @"label": @"", @"media_type": @"", @"position": @0, @"types": @[  ] } ], @"name": @"", @"options": @[ @{ @"extension_attributes": @{ @"vertex_flex_field": @"" }, @"file_extension": @"", @"image_size_x": @0, @"image_size_y": @0, @"is_require": @NO, @"max_characters": @0, @"option_id": @0, @"price": @"", @"price_type": @"", @"product_sku": @"", @"sku": @"", @"sort_order": @0, @"title": @"", @"type": @"", @"values": @[ @{ @"option_type_id": @0, @"price": @"", @"price_type": @"", @"sku": @"", @"sort_order": @0, @"title": @"" } ] } ], @"price": @"", @"product_links": @[ @{ @"extension_attributes": @{ @"qty": @"" }, @"link_type": @"", @"linked_product_sku": @"", @"linked_product_type": @"", @"position": @0, @"sku": @"" } ], @"sku": @"", @"status": @0, @"tier_prices": @[ @{ @"customer_group_id": @0, @"extension_attributes": @{ @"percentage_value": @"", @"website_id": @0 }, @"qty": @"", @"value": @"" } ], @"type_id": @"", @"updated_at": @"", @"visibility": @0, @"weight": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/configurable-products/variation"]
                                                       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}}/V1/configurable-products/variation" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"options\": [\n    {\n      \"attribute_id\": \"\",\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"is_use_default\": false,\n      \"label\": \"\",\n      \"position\": 0,\n      \"product_id\": 0,\n      \"values\": [\n        {\n          \"extension_attributes\": {},\n          \"value_index\": 0\n        }\n      ]\n    }\n  ],\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {}\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/configurable-products/variation",
  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([
    'options' => [
        [
                'attribute_id' => '',
                'extension_attributes' => [
                                
                ],
                'id' => 0,
                'is_use_default' => null,
                'label' => '',
                'position' => 0,
                'product_id' => 0,
                'values' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'value_index' => 0
                                ]
                ]
        ]
    ],
    'product' => [
        'attribute_set_id' => 0,
        'created_at' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'extension_attributes' => [
                'bundle_product_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'position' => 0,
                                                                'product_links' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'can_change_quantity' => 0,
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'id' => '',
                                                                                                                                                                                                                                                                'is_default' => null,
                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                'position' => 0,
                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                'price_type' => 0,
                                                                                                                                                                                                                                                                'qty' => '',
                                                                                                                                                                                                                                                                'sku' => ''
                                                                                                                                ]
                                                                ],
                                                                'required' => null,
                                                                'sku' => '',
                                                                'title' => '',
                                                                'type' => ''
                                ]
                ],
                'category_links' => [
                                [
                                                                'category_id' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'position' => 0
                                ]
                ],
                'configurable_product_links' => [
                                
                ],
                'configurable_product_options' => [
                                [
                                                                
                                ]
                ],
                'downloadable_product_links' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'is_shareable' => 0,
                                                                'link_file' => '',
                                                                'link_file_content' => [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'file_data' => '',
                                                                                                                                'name' => ''
                                                                ],
                                                                'link_type' => '',
                                                                'link_url' => '',
                                                                'number_of_downloads' => 0,
                                                                'price' => '',
                                                                'sample_file' => '',
                                                                'sample_file_content' => [
                                                                                                                                
                                                                ],
                                                                'sample_type' => '',
                                                                'sample_url' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ],
                'downloadable_product_samples' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'sample_file' => '',
                                                                'sample_file_content' => [
                                                                                                                                
                                                                ],
                                                                'sample_type' => '',
                                                                'sample_url' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ],
                'giftcard_amounts' => [
                                [
                                                                'attribute_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'value' => '',
                                                                'website_id' => 0,
                                                                'website_value' => ''
                                ]
                ],
                'stock_item' => [
                                'backorders' => 0,
                                'enable_qty_increments' => null,
                                'extension_attributes' => [
                                                                
                                ],
                                'is_decimal_divided' => null,
                                'is_in_stock' => null,
                                'is_qty_decimal' => null,
                                'item_id' => 0,
                                'low_stock_date' => '',
                                'manage_stock' => null,
                                'max_sale_qty' => '',
                                'min_qty' => '',
                                'min_sale_qty' => '',
                                'notify_stock_qty' => '',
                                'product_id' => 0,
                                'qty' => '',
                                'qty_increments' => '',
                                'show_default_notification_message' => null,
                                'stock_id' => 0,
                                'stock_status_changed_auto' => 0,
                                'use_config_backorders' => null,
                                'use_config_enable_qty_inc' => null,
                                'use_config_manage_stock' => null,
                                'use_config_max_sale_qty' => null,
                                'use_config_min_qty' => null,
                                'use_config_min_sale_qty' => 0,
                                'use_config_notify_stock_qty' => null,
                                'use_config_qty_increments' => null
                ],
                'website_ids' => [
                                
                ]
        ],
        'id' => 0,
        'media_gallery_entries' => [
                [
                                'content' => [
                                                                'base64_encoded_data' => '',
                                                                'name' => '',
                                                                'type' => ''
                                ],
                                'disabled' => null,
                                'extension_attributes' => [
                                                                'video_content' => [
                                                                                                                                'media_type' => '',
                                                                                                                                'video_description' => '',
                                                                                                                                'video_metadata' => '',
                                                                                                                                'video_provider' => '',
                                                                                                                                'video_title' => '',
                                                                                                                                'video_url' => ''
                                                                ]
                                ],
                                'file' => '',
                                'id' => 0,
                                'label' => '',
                                'media_type' => '',
                                'position' => 0,
                                'types' => [
                                                                
                                ]
                ]
        ],
        'name' => '',
        'options' => [
                [
                                'extension_attributes' => [
                                                                'vertex_flex_field' => ''
                                ],
                                'file_extension' => '',
                                'image_size_x' => 0,
                                'image_size_y' => 0,
                                'is_require' => null,
                                'max_characters' => 0,
                                'option_id' => 0,
                                'price' => '',
                                'price_type' => '',
                                'product_sku' => '',
                                'sku' => '',
                                'sort_order' => 0,
                                'title' => '',
                                'type' => '',
                                'values' => [
                                                                [
                                                                                                                                'option_type_id' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'price_type' => '',
                                                                                                                                'sku' => '',
                                                                                                                                'sort_order' => 0,
                                                                                                                                'title' => ''
                                                                ]
                                ]
                ]
        ],
        'price' => '',
        'product_links' => [
                [
                                'extension_attributes' => [
                                                                'qty' => ''
                                ],
                                'link_type' => '',
                                'linked_product_sku' => '',
                                'linked_product_type' => '',
                                'position' => 0,
                                'sku' => ''
                ]
        ],
        'sku' => '',
        'status' => 0,
        'tier_prices' => [
                [
                                'customer_group_id' => 0,
                                'extension_attributes' => [
                                                                'percentage_value' => '',
                                                                'website_id' => 0
                                ],
                                'qty' => '',
                                'value' => ''
                ]
        ],
        'type_id' => '',
        'updated_at' => '',
        'visibility' => 0,
        'weight' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/configurable-products/variation', [
  'body' => '{
  "options": [
    {
      "attribute_id": "",
      "extension_attributes": {},
      "id": 0,
      "is_use_default": false,
      "label": "",
      "position": 0,
      "product_id": 0,
      "values": [
        {
          "extension_attributes": {},
          "value_index": 0
        }
      ]
    }
  ],
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {}
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/configurable-products/variation');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'options' => [
    [
        'attribute_id' => '',
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'is_use_default' => null,
        'label' => '',
        'position' => 0,
        'product_id' => 0,
        'values' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'value_index' => 0
                ]
        ]
    ]
  ],
  'product' => [
    'attribute_set_id' => 0,
    'created_at' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'extension_attributes' => [
        'bundle_product_options' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'option_id' => 0,
                                'position' => 0,
                                'product_links' => [
                                                                [
                                                                                                                                'can_change_quantity' => 0,
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => '',
                                                                                                                                'is_default' => null,
                                                                                                                                'option_id' => 0,
                                                                                                                                'position' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'price_type' => 0,
                                                                                                                                'qty' => '',
                                                                                                                                'sku' => ''
                                                                ]
                                ],
                                'required' => null,
                                'sku' => '',
                                'title' => '',
                                'type' => ''
                ]
        ],
        'category_links' => [
                [
                                'category_id' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'position' => 0
                ]
        ],
        'configurable_product_links' => [
                
        ],
        'configurable_product_options' => [
                [
                                
                ]
        ],
        'downloadable_product_links' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => 0,
                                'is_shareable' => 0,
                                'link_file' => '',
                                'link_file_content' => [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'file_data' => '',
                                                                'name' => ''
                                ],
                                'link_type' => '',
                                'link_url' => '',
                                'number_of_downloads' => 0,
                                'price' => '',
                                'sample_file' => '',
                                'sample_file_content' => [
                                                                
                                ],
                                'sample_type' => '',
                                'sample_url' => '',
                                'sort_order' => 0,
                                'title' => ''
                ]
        ],
        'downloadable_product_samples' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => 0,
                                'sample_file' => '',
                                'sample_file_content' => [
                                                                
                                ],
                                'sample_type' => '',
                                'sample_url' => '',
                                'sort_order' => 0,
                                'title' => ''
                ]
        ],
        'giftcard_amounts' => [
                [
                                'attribute_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'value' => '',
                                'website_id' => 0,
                                'website_value' => ''
                ]
        ],
        'stock_item' => [
                'backorders' => 0,
                'enable_qty_increments' => null,
                'extension_attributes' => [
                                
                ],
                'is_decimal_divided' => null,
                'is_in_stock' => null,
                'is_qty_decimal' => null,
                'item_id' => 0,
                'low_stock_date' => '',
                'manage_stock' => null,
                'max_sale_qty' => '',
                'min_qty' => '',
                'min_sale_qty' => '',
                'notify_stock_qty' => '',
                'product_id' => 0,
                'qty' => '',
                'qty_increments' => '',
                'show_default_notification_message' => null,
                'stock_id' => 0,
                'stock_status_changed_auto' => 0,
                'use_config_backorders' => null,
                'use_config_enable_qty_inc' => null,
                'use_config_manage_stock' => null,
                'use_config_max_sale_qty' => null,
                'use_config_min_qty' => null,
                'use_config_min_sale_qty' => 0,
                'use_config_notify_stock_qty' => null,
                'use_config_qty_increments' => null
        ],
        'website_ids' => [
                
        ]
    ],
    'id' => 0,
    'media_gallery_entries' => [
        [
                'content' => [
                                'base64_encoded_data' => '',
                                'name' => '',
                                'type' => ''
                ],
                'disabled' => null,
                'extension_attributes' => [
                                'video_content' => [
                                                                'media_type' => '',
                                                                'video_description' => '',
                                                                'video_metadata' => '',
                                                                'video_provider' => '',
                                                                'video_title' => '',
                                                                'video_url' => ''
                                ]
                ],
                'file' => '',
                'id' => 0,
                'label' => '',
                'media_type' => '',
                'position' => 0,
                'types' => [
                                
                ]
        ]
    ],
    'name' => '',
    'options' => [
        [
                'extension_attributes' => [
                                'vertex_flex_field' => ''
                ],
                'file_extension' => '',
                'image_size_x' => 0,
                'image_size_y' => 0,
                'is_require' => null,
                'max_characters' => 0,
                'option_id' => 0,
                'price' => '',
                'price_type' => '',
                'product_sku' => '',
                'sku' => '',
                'sort_order' => 0,
                'title' => '',
                'type' => '',
                'values' => [
                                [
                                                                'option_type_id' => 0,
                                                                'price' => '',
                                                                'price_type' => '',
                                                                'sku' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ]
        ]
    ],
    'price' => '',
    'product_links' => [
        [
                'extension_attributes' => [
                                'qty' => ''
                ],
                'link_type' => '',
                'linked_product_sku' => '',
                'linked_product_type' => '',
                'position' => 0,
                'sku' => ''
        ]
    ],
    'sku' => '',
    'status' => 0,
    'tier_prices' => [
        [
                'customer_group_id' => 0,
                'extension_attributes' => [
                                'percentage_value' => '',
                                'website_id' => 0
                ],
                'qty' => '',
                'value' => ''
        ]
    ],
    'type_id' => '',
    'updated_at' => '',
    'visibility' => 0,
    'weight' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'options' => [
    [
        'attribute_id' => '',
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'is_use_default' => null,
        'label' => '',
        'position' => 0,
        'product_id' => 0,
        'values' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'value_index' => 0
                ]
        ]
    ]
  ],
  'product' => [
    'attribute_set_id' => 0,
    'created_at' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'extension_attributes' => [
        'bundle_product_options' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'option_id' => 0,
                                'position' => 0,
                                'product_links' => [
                                                                [
                                                                                                                                'can_change_quantity' => 0,
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => '',
                                                                                                                                'is_default' => null,
                                                                                                                                'option_id' => 0,
                                                                                                                                'position' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'price_type' => 0,
                                                                                                                                'qty' => '',
                                                                                                                                'sku' => ''
                                                                ]
                                ],
                                'required' => null,
                                'sku' => '',
                                'title' => '',
                                'type' => ''
                ]
        ],
        'category_links' => [
                [
                                'category_id' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'position' => 0
                ]
        ],
        'configurable_product_links' => [
                
        ],
        'configurable_product_options' => [
                [
                                
                ]
        ],
        'downloadable_product_links' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => 0,
                                'is_shareable' => 0,
                                'link_file' => '',
                                'link_file_content' => [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'file_data' => '',
                                                                'name' => ''
                                ],
                                'link_type' => '',
                                'link_url' => '',
                                'number_of_downloads' => 0,
                                'price' => '',
                                'sample_file' => '',
                                'sample_file_content' => [
                                                                
                                ],
                                'sample_type' => '',
                                'sample_url' => '',
                                'sort_order' => 0,
                                'title' => ''
                ]
        ],
        'downloadable_product_samples' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => 0,
                                'sample_file' => '',
                                'sample_file_content' => [
                                                                
                                ],
                                'sample_type' => '',
                                'sample_url' => '',
                                'sort_order' => 0,
                                'title' => ''
                ]
        ],
        'giftcard_amounts' => [
                [
                                'attribute_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'value' => '',
                                'website_id' => 0,
                                'website_value' => ''
                ]
        ],
        'stock_item' => [
                'backorders' => 0,
                'enable_qty_increments' => null,
                'extension_attributes' => [
                                
                ],
                'is_decimal_divided' => null,
                'is_in_stock' => null,
                'is_qty_decimal' => null,
                'item_id' => 0,
                'low_stock_date' => '',
                'manage_stock' => null,
                'max_sale_qty' => '',
                'min_qty' => '',
                'min_sale_qty' => '',
                'notify_stock_qty' => '',
                'product_id' => 0,
                'qty' => '',
                'qty_increments' => '',
                'show_default_notification_message' => null,
                'stock_id' => 0,
                'stock_status_changed_auto' => 0,
                'use_config_backorders' => null,
                'use_config_enable_qty_inc' => null,
                'use_config_manage_stock' => null,
                'use_config_max_sale_qty' => null,
                'use_config_min_qty' => null,
                'use_config_min_sale_qty' => 0,
                'use_config_notify_stock_qty' => null,
                'use_config_qty_increments' => null
        ],
        'website_ids' => [
                
        ]
    ],
    'id' => 0,
    'media_gallery_entries' => [
        [
                'content' => [
                                'base64_encoded_data' => '',
                                'name' => '',
                                'type' => ''
                ],
                'disabled' => null,
                'extension_attributes' => [
                                'video_content' => [
                                                                'media_type' => '',
                                                                'video_description' => '',
                                                                'video_metadata' => '',
                                                                'video_provider' => '',
                                                                'video_title' => '',
                                                                'video_url' => ''
                                ]
                ],
                'file' => '',
                'id' => 0,
                'label' => '',
                'media_type' => '',
                'position' => 0,
                'types' => [
                                
                ]
        ]
    ],
    'name' => '',
    'options' => [
        [
                'extension_attributes' => [
                                'vertex_flex_field' => ''
                ],
                'file_extension' => '',
                'image_size_x' => 0,
                'image_size_y' => 0,
                'is_require' => null,
                'max_characters' => 0,
                'option_id' => 0,
                'price' => '',
                'price_type' => '',
                'product_sku' => '',
                'sku' => '',
                'sort_order' => 0,
                'title' => '',
                'type' => '',
                'values' => [
                                [
                                                                'option_type_id' => 0,
                                                                'price' => '',
                                                                'price_type' => '',
                                                                'sku' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ]
        ]
    ],
    'price' => '',
    'product_links' => [
        [
                'extension_attributes' => [
                                'qty' => ''
                ],
                'link_type' => '',
                'linked_product_sku' => '',
                'linked_product_type' => '',
                'position' => 0,
                'sku' => ''
        ]
    ],
    'sku' => '',
    'status' => 0,
    'tier_prices' => [
        [
                'customer_group_id' => 0,
                'extension_attributes' => [
                                'percentage_value' => '',
                                'website_id' => 0
                ],
                'qty' => '',
                'value' => ''
        ]
    ],
    'type_id' => '',
    'updated_at' => '',
    'visibility' => 0,
    'weight' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/configurable-products/variation');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/configurable-products/variation' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "options": [
    {
      "attribute_id": "",
      "extension_attributes": {},
      "id": 0,
      "is_use_default": false,
      "label": "",
      "position": 0,
      "product_id": 0,
      "values": [
        {
          "extension_attributes": {},
          "value_index": 0
        }
      ]
    }
  ],
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {}
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/configurable-products/variation' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "options": [
    {
      "attribute_id": "",
      "extension_attributes": {},
      "id": 0,
      "is_use_default": false,
      "label": "",
      "position": 0,
      "product_id": 0,
      "values": [
        {
          "extension_attributes": {},
          "value_index": 0
        }
      ]
    }
  ],
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {}
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"options\": [\n    {\n      \"attribute_id\": \"\",\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"is_use_default\": false,\n      \"label\": \"\",\n      \"position\": 0,\n      \"product_id\": 0,\n      \"values\": [\n        {\n          \"extension_attributes\": {},\n          \"value_index\": 0\n        }\n      ]\n    }\n  ],\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {}\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/configurable-products/variation", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/configurable-products/variation"

payload = {
    "options": [
        {
            "attribute_id": "",
            "extension_attributes": {},
            "id": 0,
            "is_use_default": False,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": [
                {
                    "extension_attributes": {},
                    "value_index": 0
                }
            ]
        }
    ],
    "product": {
        "attribute_set_id": 0,
        "created_at": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "extension_attributes": {
            "bundle_product_options": [
                {
                    "extension_attributes": {},
                    "option_id": 0,
                    "position": 0,
                    "product_links": [
                        {
                            "can_change_quantity": 0,
                            "extension_attributes": {},
                            "id": "",
                            "is_default": False,
                            "option_id": 0,
                            "position": 0,
                            "price": "",
                            "price_type": 0,
                            "qty": "",
                            "sku": ""
                        }
                    ],
                    "required": False,
                    "sku": "",
                    "title": "",
                    "type": ""
                }
            ],
            "category_links": [
                {
                    "category_id": "",
                    "extension_attributes": {},
                    "position": 0
                }
            ],
            "configurable_product_links": [],
            "configurable_product_options": [{}],
            "downloadable_product_links": [
                {
                    "extension_attributes": {},
                    "id": 0,
                    "is_shareable": 0,
                    "link_file": "",
                    "link_file_content": {
                        "extension_attributes": {},
                        "file_data": "",
                        "name": ""
                    },
                    "link_type": "",
                    "link_url": "",
                    "number_of_downloads": 0,
                    "price": "",
                    "sample_file": "",
                    "sample_file_content": {},
                    "sample_type": "",
                    "sample_url": "",
                    "sort_order": 0,
                    "title": ""
                }
            ],
            "downloadable_product_samples": [
                {
                    "extension_attributes": {},
                    "id": 0,
                    "sample_file": "",
                    "sample_file_content": {},
                    "sample_type": "",
                    "sample_url": "",
                    "sort_order": 0,
                    "title": ""
                }
            ],
            "giftcard_amounts": [
                {
                    "attribute_id": 0,
                    "extension_attributes": {},
                    "value": "",
                    "website_id": 0,
                    "website_value": ""
                }
            ],
            "stock_item": {
                "backorders": 0,
                "enable_qty_increments": False,
                "extension_attributes": {},
                "is_decimal_divided": False,
                "is_in_stock": False,
                "is_qty_decimal": False,
                "item_id": 0,
                "low_stock_date": "",
                "manage_stock": False,
                "max_sale_qty": "",
                "min_qty": "",
                "min_sale_qty": "",
                "notify_stock_qty": "",
                "product_id": 0,
                "qty": "",
                "qty_increments": "",
                "show_default_notification_message": False,
                "stock_id": 0,
                "stock_status_changed_auto": 0,
                "use_config_backorders": False,
                "use_config_enable_qty_inc": False,
                "use_config_manage_stock": False,
                "use_config_max_sale_qty": False,
                "use_config_min_qty": False,
                "use_config_min_sale_qty": 0,
                "use_config_notify_stock_qty": False,
                "use_config_qty_increments": False
            },
            "website_ids": []
        },
        "id": 0,
        "media_gallery_entries": [
            {
                "content": {
                    "base64_encoded_data": "",
                    "name": "",
                    "type": ""
                },
                "disabled": False,
                "extension_attributes": { "video_content": {
                        "media_type": "",
                        "video_description": "",
                        "video_metadata": "",
                        "video_provider": "",
                        "video_title": "",
                        "video_url": ""
                    } },
                "file": "",
                "id": 0,
                "label": "",
                "media_type": "",
                "position": 0,
                "types": []
            }
        ],
        "name": "",
        "options": [
            {
                "extension_attributes": { "vertex_flex_field": "" },
                "file_extension": "",
                "image_size_x": 0,
                "image_size_y": 0,
                "is_require": False,
                "max_characters": 0,
                "option_id": 0,
                "price": "",
                "price_type": "",
                "product_sku": "",
                "sku": "",
                "sort_order": 0,
                "title": "",
                "type": "",
                "values": [
                    {
                        "option_type_id": 0,
                        "price": "",
                        "price_type": "",
                        "sku": "",
                        "sort_order": 0,
                        "title": ""
                    }
                ]
            }
        ],
        "price": "",
        "product_links": [
            {
                "extension_attributes": { "qty": "" },
                "link_type": "",
                "linked_product_sku": "",
                "linked_product_type": "",
                "position": 0,
                "sku": ""
            }
        ],
        "sku": "",
        "status": 0,
        "tier_prices": [
            {
                "customer_group_id": 0,
                "extension_attributes": {
                    "percentage_value": "",
                    "website_id": 0
                },
                "qty": "",
                "value": ""
            }
        ],
        "type_id": "",
        "updated_at": "",
        "visibility": 0,
        "weight": ""
    }
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/configurable-products/variation"

payload <- "{\n  \"options\": [\n    {\n      \"attribute_id\": \"\",\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"is_use_default\": false,\n      \"label\": \"\",\n      \"position\": 0,\n      \"product_id\": 0,\n      \"values\": [\n        {\n          \"extension_attributes\": {},\n          \"value_index\": 0\n        }\n      ]\n    }\n  ],\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {}\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/configurable-products/variation")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"options\": [\n    {\n      \"attribute_id\": \"\",\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"is_use_default\": false,\n      \"label\": \"\",\n      \"position\": 0,\n      \"product_id\": 0,\n      \"values\": [\n        {\n          \"extension_attributes\": {},\n          \"value_index\": 0\n        }\n      ]\n    }\n  ],\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {}\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\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/V1/configurable-products/variation') do |req|
  req.body = "{\n  \"options\": [\n    {\n      \"attribute_id\": \"\",\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"is_use_default\": false,\n      \"label\": \"\",\n      \"position\": 0,\n      \"product_id\": 0,\n      \"values\": [\n        {\n          \"extension_attributes\": {},\n          \"value_index\": 0\n        }\n      ]\n    }\n  ],\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {}\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\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}}/V1/configurable-products/variation";

    let payload = json!({
        "options": (
            json!({
                "attribute_id": "",
                "extension_attributes": json!({}),
                "id": 0,
                "is_use_default": false,
                "label": "",
                "position": 0,
                "product_id": 0,
                "values": (
                    json!({
                        "extension_attributes": json!({}),
                        "value_index": 0
                    })
                )
            })
        ),
        "product": json!({
            "attribute_set_id": 0,
            "created_at": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "extension_attributes": json!({
                "bundle_product_options": (
                    json!({
                        "extension_attributes": json!({}),
                        "option_id": 0,
                        "position": 0,
                        "product_links": (
                            json!({
                                "can_change_quantity": 0,
                                "extension_attributes": json!({}),
                                "id": "",
                                "is_default": false,
                                "option_id": 0,
                                "position": 0,
                                "price": "",
                                "price_type": 0,
                                "qty": "",
                                "sku": ""
                            })
                        ),
                        "required": false,
                        "sku": "",
                        "title": "",
                        "type": ""
                    })
                ),
                "category_links": (
                    json!({
                        "category_id": "",
                        "extension_attributes": json!({}),
                        "position": 0
                    })
                ),
                "configurable_product_links": (),
                "configurable_product_options": (json!({})),
                "downloadable_product_links": (
                    json!({
                        "extension_attributes": json!({}),
                        "id": 0,
                        "is_shareable": 0,
                        "link_file": "",
                        "link_file_content": json!({
                            "extension_attributes": json!({}),
                            "file_data": "",
                            "name": ""
                        }),
                        "link_type": "",
                        "link_url": "",
                        "number_of_downloads": 0,
                        "price": "",
                        "sample_file": "",
                        "sample_file_content": json!({}),
                        "sample_type": "",
                        "sample_url": "",
                        "sort_order": 0,
                        "title": ""
                    })
                ),
                "downloadable_product_samples": (
                    json!({
                        "extension_attributes": json!({}),
                        "id": 0,
                        "sample_file": "",
                        "sample_file_content": json!({}),
                        "sample_type": "",
                        "sample_url": "",
                        "sort_order": 0,
                        "title": ""
                    })
                ),
                "giftcard_amounts": (
                    json!({
                        "attribute_id": 0,
                        "extension_attributes": json!({}),
                        "value": "",
                        "website_id": 0,
                        "website_value": ""
                    })
                ),
                "stock_item": json!({
                    "backorders": 0,
                    "enable_qty_increments": false,
                    "extension_attributes": json!({}),
                    "is_decimal_divided": false,
                    "is_in_stock": false,
                    "is_qty_decimal": false,
                    "item_id": 0,
                    "low_stock_date": "",
                    "manage_stock": false,
                    "max_sale_qty": "",
                    "min_qty": "",
                    "min_sale_qty": "",
                    "notify_stock_qty": "",
                    "product_id": 0,
                    "qty": "",
                    "qty_increments": "",
                    "show_default_notification_message": false,
                    "stock_id": 0,
                    "stock_status_changed_auto": 0,
                    "use_config_backorders": false,
                    "use_config_enable_qty_inc": false,
                    "use_config_manage_stock": false,
                    "use_config_max_sale_qty": false,
                    "use_config_min_qty": false,
                    "use_config_min_sale_qty": 0,
                    "use_config_notify_stock_qty": false,
                    "use_config_qty_increments": false
                }),
                "website_ids": ()
            }),
            "id": 0,
            "media_gallery_entries": (
                json!({
                    "content": json!({
                        "base64_encoded_data": "",
                        "name": "",
                        "type": ""
                    }),
                    "disabled": false,
                    "extension_attributes": json!({"video_content": json!({
                            "media_type": "",
                            "video_description": "",
                            "video_metadata": "",
                            "video_provider": "",
                            "video_title": "",
                            "video_url": ""
                        })}),
                    "file": "",
                    "id": 0,
                    "label": "",
                    "media_type": "",
                    "position": 0,
                    "types": ()
                })
            ),
            "name": "",
            "options": (
                json!({
                    "extension_attributes": json!({"vertex_flex_field": ""}),
                    "file_extension": "",
                    "image_size_x": 0,
                    "image_size_y": 0,
                    "is_require": false,
                    "max_characters": 0,
                    "option_id": 0,
                    "price": "",
                    "price_type": "",
                    "product_sku": "",
                    "sku": "",
                    "sort_order": 0,
                    "title": "",
                    "type": "",
                    "values": (
                        json!({
                            "option_type_id": 0,
                            "price": "",
                            "price_type": "",
                            "sku": "",
                            "sort_order": 0,
                            "title": ""
                        })
                    )
                })
            ),
            "price": "",
            "product_links": (
                json!({
                    "extension_attributes": json!({"qty": ""}),
                    "link_type": "",
                    "linked_product_sku": "",
                    "linked_product_type": "",
                    "position": 0,
                    "sku": ""
                })
            ),
            "sku": "",
            "status": 0,
            "tier_prices": (
                json!({
                    "customer_group_id": 0,
                    "extension_attributes": json!({
                        "percentage_value": "",
                        "website_id": 0
                    }),
                    "qty": "",
                    "value": ""
                })
            ),
            "type_id": "",
            "updated_at": "",
            "visibility": 0,
            "weight": ""
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/configurable-products/variation \
  --header 'content-type: application/json' \
  --data '{
  "options": [
    {
      "attribute_id": "",
      "extension_attributes": {},
      "id": 0,
      "is_use_default": false,
      "label": "",
      "position": 0,
      "product_id": 0,
      "values": [
        {
          "extension_attributes": {},
          "value_index": 0
        }
      ]
    }
  ],
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {}
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  }
}'
echo '{
  "options": [
    {
      "attribute_id": "",
      "extension_attributes": {},
      "id": 0,
      "is_use_default": false,
      "label": "",
      "position": 0,
      "product_id": 0,
      "values": [
        {
          "extension_attributes": {},
          "value_index": 0
        }
      ]
    }
  ],
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {}
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/configurable-products/variation \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "options": [\n    {\n      "attribute_id": "",\n      "extension_attributes": {},\n      "id": 0,\n      "is_use_default": false,\n      "label": "",\n      "position": 0,\n      "product_id": 0,\n      "values": [\n        {\n          "extension_attributes": {},\n          "value_index": 0\n        }\n      ]\n    }\n  ],\n  "product": {\n    "attribute_set_id": 0,\n    "created_at": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "extension_attributes": {\n      "bundle_product_options": [\n        {\n          "extension_attributes": {},\n          "option_id": 0,\n          "position": 0,\n          "product_links": [\n            {\n              "can_change_quantity": 0,\n              "extension_attributes": {},\n              "id": "",\n              "is_default": false,\n              "option_id": 0,\n              "position": 0,\n              "price": "",\n              "price_type": 0,\n              "qty": "",\n              "sku": ""\n            }\n          ],\n          "required": false,\n          "sku": "",\n          "title": "",\n          "type": ""\n        }\n      ],\n      "category_links": [\n        {\n          "category_id": "",\n          "extension_attributes": {},\n          "position": 0\n        }\n      ],\n      "configurable_product_links": [],\n      "configurable_product_options": [\n        {}\n      ],\n      "downloadable_product_links": [\n        {\n          "extension_attributes": {},\n          "id": 0,\n          "is_shareable": 0,\n          "link_file": "",\n          "link_file_content": {\n            "extension_attributes": {},\n            "file_data": "",\n            "name": ""\n          },\n          "link_type": "",\n          "link_url": "",\n          "number_of_downloads": 0,\n          "price": "",\n          "sample_file": "",\n          "sample_file_content": {},\n          "sample_type": "",\n          "sample_url": "",\n          "sort_order": 0,\n          "title": ""\n        }\n      ],\n      "downloadable_product_samples": [\n        {\n          "extension_attributes": {},\n          "id": 0,\n          "sample_file": "",\n          "sample_file_content": {},\n          "sample_type": "",\n          "sample_url": "",\n          "sort_order": 0,\n          "title": ""\n        }\n      ],\n      "giftcard_amounts": [\n        {\n          "attribute_id": 0,\n          "extension_attributes": {},\n          "value": "",\n          "website_id": 0,\n          "website_value": ""\n        }\n      ],\n      "stock_item": {\n        "backorders": 0,\n        "enable_qty_increments": false,\n        "extension_attributes": {},\n        "is_decimal_divided": false,\n        "is_in_stock": false,\n        "is_qty_decimal": false,\n        "item_id": 0,\n        "low_stock_date": "",\n        "manage_stock": false,\n        "max_sale_qty": "",\n        "min_qty": "",\n        "min_sale_qty": "",\n        "notify_stock_qty": "",\n        "product_id": 0,\n        "qty": "",\n        "qty_increments": "",\n        "show_default_notification_message": false,\n        "stock_id": 0,\n        "stock_status_changed_auto": 0,\n        "use_config_backorders": false,\n        "use_config_enable_qty_inc": false,\n        "use_config_manage_stock": false,\n        "use_config_max_sale_qty": false,\n        "use_config_min_qty": false,\n        "use_config_min_sale_qty": 0,\n        "use_config_notify_stock_qty": false,\n        "use_config_qty_increments": false\n      },\n      "website_ids": []\n    },\n    "id": 0,\n    "media_gallery_entries": [\n      {\n        "content": {\n          "base64_encoded_data": "",\n          "name": "",\n          "type": ""\n        },\n        "disabled": false,\n        "extension_attributes": {\n          "video_content": {\n            "media_type": "",\n            "video_description": "",\n            "video_metadata": "",\n            "video_provider": "",\n            "video_title": "",\n            "video_url": ""\n          }\n        },\n        "file": "",\n        "id": 0,\n        "label": "",\n        "media_type": "",\n        "position": 0,\n        "types": []\n      }\n    ],\n    "name": "",\n    "options": [\n      {\n        "extension_attributes": {\n          "vertex_flex_field": ""\n        },\n        "file_extension": "",\n        "image_size_x": 0,\n        "image_size_y": 0,\n        "is_require": false,\n        "max_characters": 0,\n        "option_id": 0,\n        "price": "",\n        "price_type": "",\n        "product_sku": "",\n        "sku": "",\n        "sort_order": 0,\n        "title": "",\n        "type": "",\n        "values": [\n          {\n            "option_type_id": 0,\n            "price": "",\n            "price_type": "",\n            "sku": "",\n            "sort_order": 0,\n            "title": ""\n          }\n        ]\n      }\n    ],\n    "price": "",\n    "product_links": [\n      {\n        "extension_attributes": {\n          "qty": ""\n        },\n        "link_type": "",\n        "linked_product_sku": "",\n        "linked_product_type": "",\n        "position": 0,\n        "sku": ""\n      }\n    ],\n    "sku": "",\n    "status": 0,\n    "tier_prices": [\n      {\n        "customer_group_id": 0,\n        "extension_attributes": {\n          "percentage_value": "",\n          "website_id": 0\n        },\n        "qty": "",\n        "value": ""\n      }\n    ],\n    "type_id": "",\n    "updated_at": "",\n    "visibility": 0,\n    "weight": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/configurable-products/variation
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "options": [
    [
      "attribute_id": "",
      "extension_attributes": [],
      "id": 0,
      "is_use_default": false,
      "label": "",
      "position": 0,
      "product_id": 0,
      "values": [
        [
          "extension_attributes": [],
          "value_index": 0
        ]
      ]
    ]
  ],
  "product": [
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "extension_attributes": [
      "bundle_product_options": [
        [
          "extension_attributes": [],
          "option_id": 0,
          "position": 0,
          "product_links": [
            [
              "can_change_quantity": 0,
              "extension_attributes": [],
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            ]
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        ]
      ],
      "category_links": [
        [
          "category_id": "",
          "extension_attributes": [],
          "position": 0
        ]
      ],
      "configurable_product_links": [],
      "configurable_product_options": [[]],
      "downloadable_product_links": [
        [
          "extension_attributes": [],
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": [
            "extension_attributes": [],
            "file_data": "",
            "name": ""
          ],
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": [],
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        ]
      ],
      "downloadable_product_samples": [
        [
          "extension_attributes": [],
          "id": 0,
          "sample_file": "",
          "sample_file_content": [],
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        ]
      ],
      "giftcard_amounts": [
        [
          "attribute_id": 0,
          "extension_attributes": [],
          "value": "",
          "website_id": 0,
          "website_value": ""
        ]
      ],
      "stock_item": [
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": [],
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      ],
      "website_ids": []
    ],
    "id": 0,
    "media_gallery_entries": [
      [
        "content": [
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        ],
        "disabled": false,
        "extension_attributes": ["video_content": [
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          ]],
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      ]
    ],
    "name": "",
    "options": [
      [
        "extension_attributes": ["vertex_flex_field": ""],
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          [
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          ]
        ]
      ]
    ],
    "price": "",
    "product_links": [
      [
        "extension_attributes": ["qty": ""],
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      ]
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      [
        "customer_group_id": 0,
        "extension_attributes": [
          "percentage_value": "",
          "website_id": 0
        ],
        "qty": "",
        "value": ""
      ]
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/configurable-products/variation")! 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 coupons
{{baseUrl}}/V1/coupons
BODY json

{
  "coupon": {
    "code": "",
    "coupon_id": 0,
    "created_at": "",
    "expiration_date": "",
    "extension_attributes": {},
    "is_primary": false,
    "rule_id": 0,
    "times_used": 0,
    "type": 0,
    "usage_limit": 0,
    "usage_per_customer": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/coupons");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/coupons" {:content-type :json
                                                       :form-params {:coupon {:code ""
                                                                              :coupon_id 0
                                                                              :created_at ""
                                                                              :expiration_date ""
                                                                              :extension_attributes {}
                                                                              :is_primary false
                                                                              :rule_id 0
                                                                              :times_used 0
                                                                              :type 0
                                                                              :usage_limit 0
                                                                              :usage_per_customer 0}}})
require "http/client"

url = "{{baseUrl}}/V1/coupons"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\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}}/V1/coupons"),
    Content = new StringContent("{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\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}}/V1/coupons");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/coupons"

	payload := strings.NewReader("{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/coupons HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 267

{
  "coupon": {
    "code": "",
    "coupon_id": 0,
    "created_at": "",
    "expiration_date": "",
    "extension_attributes": {},
    "is_primary": false,
    "rule_id": 0,
    "times_used": 0,
    "type": 0,
    "usage_limit": 0,
    "usage_per_customer": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/coupons")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/coupons"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\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  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/coupons")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/coupons")
  .header("content-type", "application/json")
  .body("{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  coupon: {
    code: '',
    coupon_id: 0,
    created_at: '',
    expiration_date: '',
    extension_attributes: {},
    is_primary: false,
    rule_id: 0,
    times_used: 0,
    type: 0,
    usage_limit: 0,
    usage_per_customer: 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}}/V1/coupons');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/coupons',
  headers: {'content-type': 'application/json'},
  data: {
    coupon: {
      code: '',
      coupon_id: 0,
      created_at: '',
      expiration_date: '',
      extension_attributes: {},
      is_primary: false,
      rule_id: 0,
      times_used: 0,
      type: 0,
      usage_limit: 0,
      usage_per_customer: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/coupons';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"coupon":{"code":"","coupon_id":0,"created_at":"","expiration_date":"","extension_attributes":{},"is_primary":false,"rule_id":0,"times_used":0,"type":0,"usage_limit":0,"usage_per_customer":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}}/V1/coupons',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "coupon": {\n    "code": "",\n    "coupon_id": 0,\n    "created_at": "",\n    "expiration_date": "",\n    "extension_attributes": {},\n    "is_primary": false,\n    "rule_id": 0,\n    "times_used": 0,\n    "type": 0,\n    "usage_limit": 0,\n    "usage_per_customer": 0\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  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/coupons")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/coupons',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  coupon: {
    code: '',
    coupon_id: 0,
    created_at: '',
    expiration_date: '',
    extension_attributes: {},
    is_primary: false,
    rule_id: 0,
    times_used: 0,
    type: 0,
    usage_limit: 0,
    usage_per_customer: 0
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/coupons',
  headers: {'content-type': 'application/json'},
  body: {
    coupon: {
      code: '',
      coupon_id: 0,
      created_at: '',
      expiration_date: '',
      extension_attributes: {},
      is_primary: false,
      rule_id: 0,
      times_used: 0,
      type: 0,
      usage_limit: 0,
      usage_per_customer: 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}}/V1/coupons');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  coupon: {
    code: '',
    coupon_id: 0,
    created_at: '',
    expiration_date: '',
    extension_attributes: {},
    is_primary: false,
    rule_id: 0,
    times_used: 0,
    type: 0,
    usage_limit: 0,
    usage_per_customer: 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}}/V1/coupons',
  headers: {'content-type': 'application/json'},
  data: {
    coupon: {
      code: '',
      coupon_id: 0,
      created_at: '',
      expiration_date: '',
      extension_attributes: {},
      is_primary: false,
      rule_id: 0,
      times_used: 0,
      type: 0,
      usage_limit: 0,
      usage_per_customer: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/coupons';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"coupon":{"code":"","coupon_id":0,"created_at":"","expiration_date":"","extension_attributes":{},"is_primary":false,"rule_id":0,"times_used":0,"type":0,"usage_limit":0,"usage_per_customer":0}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"coupon": @{ @"code": @"", @"coupon_id": @0, @"created_at": @"", @"expiration_date": @"", @"extension_attributes": @{  }, @"is_primary": @NO, @"rule_id": @0, @"times_used": @0, @"type": @0, @"usage_limit": @0, @"usage_per_customer": @0 } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/coupons"]
                                                       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}}/V1/coupons" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/coupons",
  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([
    'coupon' => [
        'code' => '',
        'coupon_id' => 0,
        'created_at' => '',
        'expiration_date' => '',
        'extension_attributes' => [
                
        ],
        'is_primary' => null,
        'rule_id' => 0,
        'times_used' => 0,
        'type' => 0,
        'usage_limit' => 0,
        'usage_per_customer' => 0
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/coupons', [
  'body' => '{
  "coupon": {
    "code": "",
    "coupon_id": 0,
    "created_at": "",
    "expiration_date": "",
    "extension_attributes": {},
    "is_primary": false,
    "rule_id": 0,
    "times_used": 0,
    "type": 0,
    "usage_limit": 0,
    "usage_per_customer": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/coupons');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'coupon' => [
    'code' => '',
    'coupon_id' => 0,
    'created_at' => '',
    'expiration_date' => '',
    'extension_attributes' => [
        
    ],
    'is_primary' => null,
    'rule_id' => 0,
    'times_used' => 0,
    'type' => 0,
    'usage_limit' => 0,
    'usage_per_customer' => 0
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'coupon' => [
    'code' => '',
    'coupon_id' => 0,
    'created_at' => '',
    'expiration_date' => '',
    'extension_attributes' => [
        
    ],
    'is_primary' => null,
    'rule_id' => 0,
    'times_used' => 0,
    'type' => 0,
    'usage_limit' => 0,
    'usage_per_customer' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/coupons');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/coupons' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "coupon": {
    "code": "",
    "coupon_id": 0,
    "created_at": "",
    "expiration_date": "",
    "extension_attributes": {},
    "is_primary": false,
    "rule_id": 0,
    "times_used": 0,
    "type": 0,
    "usage_limit": 0,
    "usage_per_customer": 0
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/coupons' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "coupon": {
    "code": "",
    "coupon_id": 0,
    "created_at": "",
    "expiration_date": "",
    "extension_attributes": {},
    "is_primary": false,
    "rule_id": 0,
    "times_used": 0,
    "type": 0,
    "usage_limit": 0,
    "usage_per_customer": 0
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/coupons", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/coupons"

payload = { "coupon": {
        "code": "",
        "coupon_id": 0,
        "created_at": "",
        "expiration_date": "",
        "extension_attributes": {},
        "is_primary": False,
        "rule_id": 0,
        "times_used": 0,
        "type": 0,
        "usage_limit": 0,
        "usage_per_customer": 0
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/coupons"

payload <- "{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/coupons")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\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/V1/coupons') do |req|
  req.body = "{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/coupons";

    let payload = json!({"coupon": json!({
            "code": "",
            "coupon_id": 0,
            "created_at": "",
            "expiration_date": "",
            "extension_attributes": json!({}),
            "is_primary": false,
            "rule_id": 0,
            "times_used": 0,
            "type": 0,
            "usage_limit": 0,
            "usage_per_customer": 0
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/coupons \
  --header 'content-type: application/json' \
  --data '{
  "coupon": {
    "code": "",
    "coupon_id": 0,
    "created_at": "",
    "expiration_date": "",
    "extension_attributes": {},
    "is_primary": false,
    "rule_id": 0,
    "times_used": 0,
    "type": 0,
    "usage_limit": 0,
    "usage_per_customer": 0
  }
}'
echo '{
  "coupon": {
    "code": "",
    "coupon_id": 0,
    "created_at": "",
    "expiration_date": "",
    "extension_attributes": {},
    "is_primary": false,
    "rule_id": 0,
    "times_used": 0,
    "type": 0,
    "usage_limit": 0,
    "usage_per_customer": 0
  }
}' |  \
  http POST {{baseUrl}}/V1/coupons \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "coupon": {\n    "code": "",\n    "coupon_id": 0,\n    "created_at": "",\n    "expiration_date": "",\n    "extension_attributes": {},\n    "is_primary": false,\n    "rule_id": 0,\n    "times_used": 0,\n    "type": 0,\n    "usage_limit": 0,\n    "usage_per_customer": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/coupons
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["coupon": [
    "code": "",
    "coupon_id": 0,
    "created_at": "",
    "expiration_date": "",
    "extension_attributes": [],
    "is_primary": false,
    "rule_id": 0,
    "times_used": 0,
    "type": 0,
    "usage_limit": 0,
    "usage_per_customer": 0
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/coupons")! 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 coupons-{couponId} (GET)
{{baseUrl}}/V1/coupons/:couponId
QUERY PARAMS

couponId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/coupons/:couponId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/coupons/:couponId")
require "http/client"

url = "{{baseUrl}}/V1/coupons/:couponId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/coupons/:couponId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/coupons/:couponId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/coupons/:couponId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/coupons/:couponId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/coupons/:couponId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/coupons/:couponId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/coupons/:couponId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/coupons/:couponId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/coupons/:couponId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/coupons/:couponId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/coupons/:couponId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/coupons/:couponId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/coupons/:couponId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/coupons/:couponId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/coupons/:couponId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/coupons/:couponId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/coupons/:couponId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/coupons/:couponId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/coupons/:couponId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/coupons/:couponId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/coupons/:couponId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/coupons/:couponId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/coupons/:couponId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/coupons/:couponId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/coupons/:couponId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/coupons/:couponId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/coupons/:couponId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/coupons/:couponId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/coupons/:couponId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/coupons/:couponId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/coupons/:couponId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/coupons/:couponId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/coupons/:couponId
http GET {{baseUrl}}/V1/coupons/:couponId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/coupons/:couponId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/coupons/:couponId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT coupons-{couponId} (PUT)
{{baseUrl}}/V1/coupons/:couponId
QUERY PARAMS

couponId
BODY json

{
  "coupon": {
    "code": "",
    "coupon_id": 0,
    "created_at": "",
    "expiration_date": "",
    "extension_attributes": {},
    "is_primary": false,
    "rule_id": 0,
    "times_used": 0,
    "type": 0,
    "usage_limit": 0,
    "usage_per_customer": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/coupons/:couponId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/coupons/:couponId" {:content-type :json
                                                                :form-params {:coupon {:code ""
                                                                                       :coupon_id 0
                                                                                       :created_at ""
                                                                                       :expiration_date ""
                                                                                       :extension_attributes {}
                                                                                       :is_primary false
                                                                                       :rule_id 0
                                                                                       :times_used 0
                                                                                       :type 0
                                                                                       :usage_limit 0
                                                                                       :usage_per_customer 0}}})
require "http/client"

url = "{{baseUrl}}/V1/coupons/:couponId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\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}}/V1/coupons/:couponId"),
    Content = new StringContent("{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\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}}/V1/coupons/:couponId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/coupons/:couponId"

	payload := strings.NewReader("{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/coupons/:couponId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 267

{
  "coupon": {
    "code": "",
    "coupon_id": 0,
    "created_at": "",
    "expiration_date": "",
    "extension_attributes": {},
    "is_primary": false,
    "rule_id": 0,
    "times_used": 0,
    "type": 0,
    "usage_limit": 0,
    "usage_per_customer": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/coupons/:couponId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/coupons/:couponId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\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  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/coupons/:couponId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/coupons/:couponId")
  .header("content-type", "application/json")
  .body("{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  coupon: {
    code: '',
    coupon_id: 0,
    created_at: '',
    expiration_date: '',
    extension_attributes: {},
    is_primary: false,
    rule_id: 0,
    times_used: 0,
    type: 0,
    usage_limit: 0,
    usage_per_customer: 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}}/V1/coupons/:couponId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/coupons/:couponId',
  headers: {'content-type': 'application/json'},
  data: {
    coupon: {
      code: '',
      coupon_id: 0,
      created_at: '',
      expiration_date: '',
      extension_attributes: {},
      is_primary: false,
      rule_id: 0,
      times_used: 0,
      type: 0,
      usage_limit: 0,
      usage_per_customer: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/coupons/:couponId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"coupon":{"code":"","coupon_id":0,"created_at":"","expiration_date":"","extension_attributes":{},"is_primary":false,"rule_id":0,"times_used":0,"type":0,"usage_limit":0,"usage_per_customer":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}}/V1/coupons/:couponId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "coupon": {\n    "code": "",\n    "coupon_id": 0,\n    "created_at": "",\n    "expiration_date": "",\n    "extension_attributes": {},\n    "is_primary": false,\n    "rule_id": 0,\n    "times_used": 0,\n    "type": 0,\n    "usage_limit": 0,\n    "usage_per_customer": 0\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  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/coupons/:couponId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/coupons/:couponId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  coupon: {
    code: '',
    coupon_id: 0,
    created_at: '',
    expiration_date: '',
    extension_attributes: {},
    is_primary: false,
    rule_id: 0,
    times_used: 0,
    type: 0,
    usage_limit: 0,
    usage_per_customer: 0
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/coupons/:couponId',
  headers: {'content-type': 'application/json'},
  body: {
    coupon: {
      code: '',
      coupon_id: 0,
      created_at: '',
      expiration_date: '',
      extension_attributes: {},
      is_primary: false,
      rule_id: 0,
      times_used: 0,
      type: 0,
      usage_limit: 0,
      usage_per_customer: 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}}/V1/coupons/:couponId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  coupon: {
    code: '',
    coupon_id: 0,
    created_at: '',
    expiration_date: '',
    extension_attributes: {},
    is_primary: false,
    rule_id: 0,
    times_used: 0,
    type: 0,
    usage_limit: 0,
    usage_per_customer: 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}}/V1/coupons/:couponId',
  headers: {'content-type': 'application/json'},
  data: {
    coupon: {
      code: '',
      coupon_id: 0,
      created_at: '',
      expiration_date: '',
      extension_attributes: {},
      is_primary: false,
      rule_id: 0,
      times_used: 0,
      type: 0,
      usage_limit: 0,
      usage_per_customer: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/coupons/:couponId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"coupon":{"code":"","coupon_id":0,"created_at":"","expiration_date":"","extension_attributes":{},"is_primary":false,"rule_id":0,"times_used":0,"type":0,"usage_limit":0,"usage_per_customer":0}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"coupon": @{ @"code": @"", @"coupon_id": @0, @"created_at": @"", @"expiration_date": @"", @"extension_attributes": @{  }, @"is_primary": @NO, @"rule_id": @0, @"times_used": @0, @"type": @0, @"usage_limit": @0, @"usage_per_customer": @0 } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/coupons/:couponId"]
                                                       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}}/V1/coupons/:couponId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/coupons/:couponId",
  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([
    'coupon' => [
        'code' => '',
        'coupon_id' => 0,
        'created_at' => '',
        'expiration_date' => '',
        'extension_attributes' => [
                
        ],
        'is_primary' => null,
        'rule_id' => 0,
        'times_used' => 0,
        'type' => 0,
        'usage_limit' => 0,
        'usage_per_customer' => 0
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/coupons/:couponId', [
  'body' => '{
  "coupon": {
    "code": "",
    "coupon_id": 0,
    "created_at": "",
    "expiration_date": "",
    "extension_attributes": {},
    "is_primary": false,
    "rule_id": 0,
    "times_used": 0,
    "type": 0,
    "usage_limit": 0,
    "usage_per_customer": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/coupons/:couponId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'coupon' => [
    'code' => '',
    'coupon_id' => 0,
    'created_at' => '',
    'expiration_date' => '',
    'extension_attributes' => [
        
    ],
    'is_primary' => null,
    'rule_id' => 0,
    'times_used' => 0,
    'type' => 0,
    'usage_limit' => 0,
    'usage_per_customer' => 0
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'coupon' => [
    'code' => '',
    'coupon_id' => 0,
    'created_at' => '',
    'expiration_date' => '',
    'extension_attributes' => [
        
    ],
    'is_primary' => null,
    'rule_id' => 0,
    'times_used' => 0,
    'type' => 0,
    'usage_limit' => 0,
    'usage_per_customer' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/coupons/:couponId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/coupons/:couponId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "coupon": {
    "code": "",
    "coupon_id": 0,
    "created_at": "",
    "expiration_date": "",
    "extension_attributes": {},
    "is_primary": false,
    "rule_id": 0,
    "times_used": 0,
    "type": 0,
    "usage_limit": 0,
    "usage_per_customer": 0
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/coupons/:couponId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "coupon": {
    "code": "",
    "coupon_id": 0,
    "created_at": "",
    "expiration_date": "",
    "extension_attributes": {},
    "is_primary": false,
    "rule_id": 0,
    "times_used": 0,
    "type": 0,
    "usage_limit": 0,
    "usage_per_customer": 0
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/coupons/:couponId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/coupons/:couponId"

payload = { "coupon": {
        "code": "",
        "coupon_id": 0,
        "created_at": "",
        "expiration_date": "",
        "extension_attributes": {},
        "is_primary": False,
        "rule_id": 0,
        "times_used": 0,
        "type": 0,
        "usage_limit": 0,
        "usage_per_customer": 0
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/coupons/:couponId"

payload <- "{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/coupons/:couponId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\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/V1/coupons/:couponId') do |req|
  req.body = "{\n  \"coupon\": {\n    \"code\": \"\",\n    \"coupon_id\": 0,\n    \"created_at\": \"\",\n    \"expiration_date\": \"\",\n    \"extension_attributes\": {},\n    \"is_primary\": false,\n    \"rule_id\": 0,\n    \"times_used\": 0,\n    \"type\": 0,\n    \"usage_limit\": 0,\n    \"usage_per_customer\": 0\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}}/V1/coupons/:couponId";

    let payload = json!({"coupon": json!({
            "code": "",
            "coupon_id": 0,
            "created_at": "",
            "expiration_date": "",
            "extension_attributes": json!({}),
            "is_primary": false,
            "rule_id": 0,
            "times_used": 0,
            "type": 0,
            "usage_limit": 0,
            "usage_per_customer": 0
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/coupons/:couponId \
  --header 'content-type: application/json' \
  --data '{
  "coupon": {
    "code": "",
    "coupon_id": 0,
    "created_at": "",
    "expiration_date": "",
    "extension_attributes": {},
    "is_primary": false,
    "rule_id": 0,
    "times_used": 0,
    "type": 0,
    "usage_limit": 0,
    "usage_per_customer": 0
  }
}'
echo '{
  "coupon": {
    "code": "",
    "coupon_id": 0,
    "created_at": "",
    "expiration_date": "",
    "extension_attributes": {},
    "is_primary": false,
    "rule_id": 0,
    "times_used": 0,
    "type": 0,
    "usage_limit": 0,
    "usage_per_customer": 0
  }
}' |  \
  http PUT {{baseUrl}}/V1/coupons/:couponId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "coupon": {\n    "code": "",\n    "coupon_id": 0,\n    "created_at": "",\n    "expiration_date": "",\n    "extension_attributes": {},\n    "is_primary": false,\n    "rule_id": 0,\n    "times_used": 0,\n    "type": 0,\n    "usage_limit": 0,\n    "usage_per_customer": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/coupons/:couponId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["coupon": [
    "code": "",
    "coupon_id": 0,
    "created_at": "",
    "expiration_date": "",
    "extension_attributes": [],
    "is_primary": false,
    "rule_id": 0,
    "times_used": 0,
    "type": 0,
    "usage_limit": 0,
    "usage_per_customer": 0
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/coupons/:couponId")! 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()
DELETE coupons-{couponId}
{{baseUrl}}/V1/coupons/:couponId
QUERY PARAMS

couponId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/coupons/:couponId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/coupons/:couponId")
require "http/client"

url = "{{baseUrl}}/V1/coupons/:couponId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/coupons/:couponId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/coupons/:couponId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/coupons/:couponId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/coupons/:couponId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/coupons/:couponId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/coupons/:couponId"))
    .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}}/V1/coupons/:couponId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/coupons/:couponId")
  .asString();
const 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}}/V1/coupons/:couponId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/coupons/:couponId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/coupons/:couponId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/coupons/:couponId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/coupons/:couponId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/coupons/:couponId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/coupons/:couponId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/coupons/:couponId');

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}}/V1/coupons/:couponId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/coupons/:couponId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/coupons/:couponId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/coupons/:couponId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/coupons/:couponId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/coupons/:couponId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/coupons/:couponId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/coupons/:couponId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/coupons/:couponId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/coupons/:couponId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/coupons/:couponId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/coupons/:couponId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/coupons/:couponId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/coupons/:couponId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/coupons/:couponId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/coupons/:couponId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/coupons/:couponId
http DELETE {{baseUrl}}/V1/coupons/:couponId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/coupons/:couponId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/coupons/:couponId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST coupons-deleteByCodes
{{baseUrl}}/V1/coupons/deleteByCodes
BODY json

{
  "codes": [],
  "ignoreInvalidCoupons": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/coupons/deleteByCodes");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"codes\": [],\n  \"ignoreInvalidCoupons\": false\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/coupons/deleteByCodes" {:content-type :json
                                                                     :form-params {:codes []
                                                                                   :ignoreInvalidCoupons false}})
require "http/client"

url = "{{baseUrl}}/V1/coupons/deleteByCodes"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"codes\": [],\n  \"ignoreInvalidCoupons\": 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}}/V1/coupons/deleteByCodes"),
    Content = new StringContent("{\n  \"codes\": [],\n  \"ignoreInvalidCoupons\": 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}}/V1/coupons/deleteByCodes");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"codes\": [],\n  \"ignoreInvalidCoupons\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/coupons/deleteByCodes"

	payload := strings.NewReader("{\n  \"codes\": [],\n  \"ignoreInvalidCoupons\": false\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/coupons/deleteByCodes HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 50

{
  "codes": [],
  "ignoreInvalidCoupons": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/coupons/deleteByCodes")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"codes\": [],\n  \"ignoreInvalidCoupons\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/coupons/deleteByCodes"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"codes\": [],\n  \"ignoreInvalidCoupons\": 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  \"codes\": [],\n  \"ignoreInvalidCoupons\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/coupons/deleteByCodes")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/coupons/deleteByCodes")
  .header("content-type", "application/json")
  .body("{\n  \"codes\": [],\n  \"ignoreInvalidCoupons\": false\n}")
  .asString();
const data = JSON.stringify({
  codes: [],
  ignoreInvalidCoupons: 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}}/V1/coupons/deleteByCodes');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/coupons/deleteByCodes',
  headers: {'content-type': 'application/json'},
  data: {codes: [], ignoreInvalidCoupons: false}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/coupons/deleteByCodes';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"codes":[],"ignoreInvalidCoupons":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}}/V1/coupons/deleteByCodes',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "codes": [],\n  "ignoreInvalidCoupons": 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  \"codes\": [],\n  \"ignoreInvalidCoupons\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/coupons/deleteByCodes")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/coupons/deleteByCodes',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({codes: [], ignoreInvalidCoupons: false}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/coupons/deleteByCodes',
  headers: {'content-type': 'application/json'},
  body: {codes: [], ignoreInvalidCoupons: 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}}/V1/coupons/deleteByCodes');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  codes: [],
  ignoreInvalidCoupons: 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}}/V1/coupons/deleteByCodes',
  headers: {'content-type': 'application/json'},
  data: {codes: [], ignoreInvalidCoupons: false}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/coupons/deleteByCodes';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"codes":[],"ignoreInvalidCoupons":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"codes": @[  ],
                              @"ignoreInvalidCoupons": @NO };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/coupons/deleteByCodes"]
                                                       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}}/V1/coupons/deleteByCodes" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"codes\": [],\n  \"ignoreInvalidCoupons\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/coupons/deleteByCodes",
  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([
    'codes' => [
        
    ],
    'ignoreInvalidCoupons' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/coupons/deleteByCodes', [
  'body' => '{
  "codes": [],
  "ignoreInvalidCoupons": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/coupons/deleteByCodes');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'codes' => [
    
  ],
  'ignoreInvalidCoupons' => null
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'codes' => [
    
  ],
  'ignoreInvalidCoupons' => null
]));
$request->setRequestUrl('{{baseUrl}}/V1/coupons/deleteByCodes');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/coupons/deleteByCodes' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "codes": [],
  "ignoreInvalidCoupons": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/coupons/deleteByCodes' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "codes": [],
  "ignoreInvalidCoupons": false
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"codes\": [],\n  \"ignoreInvalidCoupons\": false\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/coupons/deleteByCodes", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/coupons/deleteByCodes"

payload = {
    "codes": [],
    "ignoreInvalidCoupons": False
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/coupons/deleteByCodes"

payload <- "{\n  \"codes\": [],\n  \"ignoreInvalidCoupons\": false\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/coupons/deleteByCodes")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"codes\": [],\n  \"ignoreInvalidCoupons\": 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/V1/coupons/deleteByCodes') do |req|
  req.body = "{\n  \"codes\": [],\n  \"ignoreInvalidCoupons\": false\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/coupons/deleteByCodes";

    let payload = json!({
        "codes": (),
        "ignoreInvalidCoupons": false
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/coupons/deleteByCodes \
  --header 'content-type: application/json' \
  --data '{
  "codes": [],
  "ignoreInvalidCoupons": false
}'
echo '{
  "codes": [],
  "ignoreInvalidCoupons": false
}' |  \
  http POST {{baseUrl}}/V1/coupons/deleteByCodes \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "codes": [],\n  "ignoreInvalidCoupons": false\n}' \
  --output-document \
  - {{baseUrl}}/V1/coupons/deleteByCodes
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "codes": [],
  "ignoreInvalidCoupons": false
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/coupons/deleteByCodes")! 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 coupons-deleteByIds
{{baseUrl}}/V1/coupons/deleteByIds
BODY json

{
  "ids": [],
  "ignoreInvalidCoupons": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/coupons/deleteByIds");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"ids\": [],\n  \"ignoreInvalidCoupons\": false\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/coupons/deleteByIds" {:content-type :json
                                                                   :form-params {:ids []
                                                                                 :ignoreInvalidCoupons false}})
require "http/client"

url = "{{baseUrl}}/V1/coupons/deleteByIds"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"ids\": [],\n  \"ignoreInvalidCoupons\": 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}}/V1/coupons/deleteByIds"),
    Content = new StringContent("{\n  \"ids\": [],\n  \"ignoreInvalidCoupons\": 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}}/V1/coupons/deleteByIds");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"ids\": [],\n  \"ignoreInvalidCoupons\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/coupons/deleteByIds"

	payload := strings.NewReader("{\n  \"ids\": [],\n  \"ignoreInvalidCoupons\": false\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/coupons/deleteByIds HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 48

{
  "ids": [],
  "ignoreInvalidCoupons": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/coupons/deleteByIds")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"ids\": [],\n  \"ignoreInvalidCoupons\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/coupons/deleteByIds"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"ids\": [],\n  \"ignoreInvalidCoupons\": 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  \"ids\": [],\n  \"ignoreInvalidCoupons\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/coupons/deleteByIds")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/coupons/deleteByIds")
  .header("content-type", "application/json")
  .body("{\n  \"ids\": [],\n  \"ignoreInvalidCoupons\": false\n}")
  .asString();
const data = JSON.stringify({
  ids: [],
  ignoreInvalidCoupons: 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}}/V1/coupons/deleteByIds');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/coupons/deleteByIds',
  headers: {'content-type': 'application/json'},
  data: {ids: [], ignoreInvalidCoupons: false}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/coupons/deleteByIds';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"ids":[],"ignoreInvalidCoupons":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}}/V1/coupons/deleteByIds',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "ids": [],\n  "ignoreInvalidCoupons": 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  \"ids\": [],\n  \"ignoreInvalidCoupons\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/coupons/deleteByIds")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/coupons/deleteByIds',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({ids: [], ignoreInvalidCoupons: false}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/coupons/deleteByIds',
  headers: {'content-type': 'application/json'},
  body: {ids: [], ignoreInvalidCoupons: 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}}/V1/coupons/deleteByIds');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  ids: [],
  ignoreInvalidCoupons: 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}}/V1/coupons/deleteByIds',
  headers: {'content-type': 'application/json'},
  data: {ids: [], ignoreInvalidCoupons: false}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/coupons/deleteByIds';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"ids":[],"ignoreInvalidCoupons":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"ids": @[  ],
                              @"ignoreInvalidCoupons": @NO };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/coupons/deleteByIds"]
                                                       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}}/V1/coupons/deleteByIds" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"ids\": [],\n  \"ignoreInvalidCoupons\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/coupons/deleteByIds",
  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([
    'ids' => [
        
    ],
    'ignoreInvalidCoupons' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/coupons/deleteByIds', [
  'body' => '{
  "ids": [],
  "ignoreInvalidCoupons": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/coupons/deleteByIds');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'ids' => [
    
  ],
  'ignoreInvalidCoupons' => null
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'ids' => [
    
  ],
  'ignoreInvalidCoupons' => null
]));
$request->setRequestUrl('{{baseUrl}}/V1/coupons/deleteByIds');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/coupons/deleteByIds' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "ids": [],
  "ignoreInvalidCoupons": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/coupons/deleteByIds' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "ids": [],
  "ignoreInvalidCoupons": false
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"ids\": [],\n  \"ignoreInvalidCoupons\": false\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/coupons/deleteByIds", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/coupons/deleteByIds"

payload = {
    "ids": [],
    "ignoreInvalidCoupons": False
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/coupons/deleteByIds"

payload <- "{\n  \"ids\": [],\n  \"ignoreInvalidCoupons\": false\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/coupons/deleteByIds")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"ids\": [],\n  \"ignoreInvalidCoupons\": 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/V1/coupons/deleteByIds') do |req|
  req.body = "{\n  \"ids\": [],\n  \"ignoreInvalidCoupons\": false\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/coupons/deleteByIds";

    let payload = json!({
        "ids": (),
        "ignoreInvalidCoupons": false
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/coupons/deleteByIds \
  --header 'content-type: application/json' \
  --data '{
  "ids": [],
  "ignoreInvalidCoupons": false
}'
echo '{
  "ids": [],
  "ignoreInvalidCoupons": false
}' |  \
  http POST {{baseUrl}}/V1/coupons/deleteByIds \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "ids": [],\n  "ignoreInvalidCoupons": false\n}' \
  --output-document \
  - {{baseUrl}}/V1/coupons/deleteByIds
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "ids": [],
  "ignoreInvalidCoupons": false
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/coupons/deleteByIds")! 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 coupons-generate
{{baseUrl}}/V1/coupons/generate
BODY json

{
  "couponSpec": {
    "delimiter": "",
    "delimiter_at_every": 0,
    "extension_attributes": {},
    "format": "",
    "length": 0,
    "prefix": "",
    "quantity": 0,
    "rule_id": 0,
    "suffix": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/coupons/generate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"couponSpec\": {\n    \"delimiter\": \"\",\n    \"delimiter_at_every\": 0,\n    \"extension_attributes\": {},\n    \"format\": \"\",\n    \"length\": 0,\n    \"prefix\": \"\",\n    \"quantity\": 0,\n    \"rule_id\": 0,\n    \"suffix\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/coupons/generate" {:content-type :json
                                                                :form-params {:couponSpec {:delimiter ""
                                                                                           :delimiter_at_every 0
                                                                                           :extension_attributes {}
                                                                                           :format ""
                                                                                           :length 0
                                                                                           :prefix ""
                                                                                           :quantity 0
                                                                                           :rule_id 0
                                                                                           :suffix ""}}})
require "http/client"

url = "{{baseUrl}}/V1/coupons/generate"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"couponSpec\": {\n    \"delimiter\": \"\",\n    \"delimiter_at_every\": 0,\n    \"extension_attributes\": {},\n    \"format\": \"\",\n    \"length\": 0,\n    \"prefix\": \"\",\n    \"quantity\": 0,\n    \"rule_id\": 0,\n    \"suffix\": \"\"\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}}/V1/coupons/generate"),
    Content = new StringContent("{\n  \"couponSpec\": {\n    \"delimiter\": \"\",\n    \"delimiter_at_every\": 0,\n    \"extension_attributes\": {},\n    \"format\": \"\",\n    \"length\": 0,\n    \"prefix\": \"\",\n    \"quantity\": 0,\n    \"rule_id\": 0,\n    \"suffix\": \"\"\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}}/V1/coupons/generate");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"couponSpec\": {\n    \"delimiter\": \"\",\n    \"delimiter_at_every\": 0,\n    \"extension_attributes\": {},\n    \"format\": \"\",\n    \"length\": 0,\n    \"prefix\": \"\",\n    \"quantity\": 0,\n    \"rule_id\": 0,\n    \"suffix\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/coupons/generate"

	payload := strings.NewReader("{\n  \"couponSpec\": {\n    \"delimiter\": \"\",\n    \"delimiter_at_every\": 0,\n    \"extension_attributes\": {},\n    \"format\": \"\",\n    \"length\": 0,\n    \"prefix\": \"\",\n    \"quantity\": 0,\n    \"rule_id\": 0,\n    \"suffix\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/coupons/generate HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 214

{
  "couponSpec": {
    "delimiter": "",
    "delimiter_at_every": 0,
    "extension_attributes": {},
    "format": "",
    "length": 0,
    "prefix": "",
    "quantity": 0,
    "rule_id": 0,
    "suffix": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/coupons/generate")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"couponSpec\": {\n    \"delimiter\": \"\",\n    \"delimiter_at_every\": 0,\n    \"extension_attributes\": {},\n    \"format\": \"\",\n    \"length\": 0,\n    \"prefix\": \"\",\n    \"quantity\": 0,\n    \"rule_id\": 0,\n    \"suffix\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/coupons/generate"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"couponSpec\": {\n    \"delimiter\": \"\",\n    \"delimiter_at_every\": 0,\n    \"extension_attributes\": {},\n    \"format\": \"\",\n    \"length\": 0,\n    \"prefix\": \"\",\n    \"quantity\": 0,\n    \"rule_id\": 0,\n    \"suffix\": \"\"\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  \"couponSpec\": {\n    \"delimiter\": \"\",\n    \"delimiter_at_every\": 0,\n    \"extension_attributes\": {},\n    \"format\": \"\",\n    \"length\": 0,\n    \"prefix\": \"\",\n    \"quantity\": 0,\n    \"rule_id\": 0,\n    \"suffix\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/coupons/generate")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/coupons/generate")
  .header("content-type", "application/json")
  .body("{\n  \"couponSpec\": {\n    \"delimiter\": \"\",\n    \"delimiter_at_every\": 0,\n    \"extension_attributes\": {},\n    \"format\": \"\",\n    \"length\": 0,\n    \"prefix\": \"\",\n    \"quantity\": 0,\n    \"rule_id\": 0,\n    \"suffix\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  couponSpec: {
    delimiter: '',
    delimiter_at_every: 0,
    extension_attributes: {},
    format: '',
    length: 0,
    prefix: '',
    quantity: 0,
    rule_id: 0,
    suffix: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/coupons/generate');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/coupons/generate',
  headers: {'content-type': 'application/json'},
  data: {
    couponSpec: {
      delimiter: '',
      delimiter_at_every: 0,
      extension_attributes: {},
      format: '',
      length: 0,
      prefix: '',
      quantity: 0,
      rule_id: 0,
      suffix: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/coupons/generate';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"couponSpec":{"delimiter":"","delimiter_at_every":0,"extension_attributes":{},"format":"","length":0,"prefix":"","quantity":0,"rule_id":0,"suffix":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/coupons/generate',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "couponSpec": {\n    "delimiter": "",\n    "delimiter_at_every": 0,\n    "extension_attributes": {},\n    "format": "",\n    "length": 0,\n    "prefix": "",\n    "quantity": 0,\n    "rule_id": 0,\n    "suffix": ""\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  \"couponSpec\": {\n    \"delimiter\": \"\",\n    \"delimiter_at_every\": 0,\n    \"extension_attributes\": {},\n    \"format\": \"\",\n    \"length\": 0,\n    \"prefix\": \"\",\n    \"quantity\": 0,\n    \"rule_id\": 0,\n    \"suffix\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/coupons/generate")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/coupons/generate',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  couponSpec: {
    delimiter: '',
    delimiter_at_every: 0,
    extension_attributes: {},
    format: '',
    length: 0,
    prefix: '',
    quantity: 0,
    rule_id: 0,
    suffix: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/coupons/generate',
  headers: {'content-type': 'application/json'},
  body: {
    couponSpec: {
      delimiter: '',
      delimiter_at_every: 0,
      extension_attributes: {},
      format: '',
      length: 0,
      prefix: '',
      quantity: 0,
      rule_id: 0,
      suffix: ''
    }
  },
  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}}/V1/coupons/generate');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  couponSpec: {
    delimiter: '',
    delimiter_at_every: 0,
    extension_attributes: {},
    format: '',
    length: 0,
    prefix: '',
    quantity: 0,
    rule_id: 0,
    suffix: ''
  }
});

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}}/V1/coupons/generate',
  headers: {'content-type': 'application/json'},
  data: {
    couponSpec: {
      delimiter: '',
      delimiter_at_every: 0,
      extension_attributes: {},
      format: '',
      length: 0,
      prefix: '',
      quantity: 0,
      rule_id: 0,
      suffix: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/coupons/generate';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"couponSpec":{"delimiter":"","delimiter_at_every":0,"extension_attributes":{},"format":"","length":0,"prefix":"","quantity":0,"rule_id":0,"suffix":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"couponSpec": @{ @"delimiter": @"", @"delimiter_at_every": @0, @"extension_attributes": @{  }, @"format": @"", @"length": @0, @"prefix": @"", @"quantity": @0, @"rule_id": @0, @"suffix": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/coupons/generate"]
                                                       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}}/V1/coupons/generate" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"couponSpec\": {\n    \"delimiter\": \"\",\n    \"delimiter_at_every\": 0,\n    \"extension_attributes\": {},\n    \"format\": \"\",\n    \"length\": 0,\n    \"prefix\": \"\",\n    \"quantity\": 0,\n    \"rule_id\": 0,\n    \"suffix\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/coupons/generate",
  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([
    'couponSpec' => [
        'delimiter' => '',
        'delimiter_at_every' => 0,
        'extension_attributes' => [
                
        ],
        'format' => '',
        'length' => 0,
        'prefix' => '',
        'quantity' => 0,
        'rule_id' => 0,
        'suffix' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/coupons/generate', [
  'body' => '{
  "couponSpec": {
    "delimiter": "",
    "delimiter_at_every": 0,
    "extension_attributes": {},
    "format": "",
    "length": 0,
    "prefix": "",
    "quantity": 0,
    "rule_id": 0,
    "suffix": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/coupons/generate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'couponSpec' => [
    'delimiter' => '',
    'delimiter_at_every' => 0,
    'extension_attributes' => [
        
    ],
    'format' => '',
    'length' => 0,
    'prefix' => '',
    'quantity' => 0,
    'rule_id' => 0,
    'suffix' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'couponSpec' => [
    'delimiter' => '',
    'delimiter_at_every' => 0,
    'extension_attributes' => [
        
    ],
    'format' => '',
    'length' => 0,
    'prefix' => '',
    'quantity' => 0,
    'rule_id' => 0,
    'suffix' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/coupons/generate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/coupons/generate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "couponSpec": {
    "delimiter": "",
    "delimiter_at_every": 0,
    "extension_attributes": {},
    "format": "",
    "length": 0,
    "prefix": "",
    "quantity": 0,
    "rule_id": 0,
    "suffix": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/coupons/generate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "couponSpec": {
    "delimiter": "",
    "delimiter_at_every": 0,
    "extension_attributes": {},
    "format": "",
    "length": 0,
    "prefix": "",
    "quantity": 0,
    "rule_id": 0,
    "suffix": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"couponSpec\": {\n    \"delimiter\": \"\",\n    \"delimiter_at_every\": 0,\n    \"extension_attributes\": {},\n    \"format\": \"\",\n    \"length\": 0,\n    \"prefix\": \"\",\n    \"quantity\": 0,\n    \"rule_id\": 0,\n    \"suffix\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/coupons/generate", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/coupons/generate"

payload = { "couponSpec": {
        "delimiter": "",
        "delimiter_at_every": 0,
        "extension_attributes": {},
        "format": "",
        "length": 0,
        "prefix": "",
        "quantity": 0,
        "rule_id": 0,
        "suffix": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/coupons/generate"

payload <- "{\n  \"couponSpec\": {\n    \"delimiter\": \"\",\n    \"delimiter_at_every\": 0,\n    \"extension_attributes\": {},\n    \"format\": \"\",\n    \"length\": 0,\n    \"prefix\": \"\",\n    \"quantity\": 0,\n    \"rule_id\": 0,\n    \"suffix\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/coupons/generate")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"couponSpec\": {\n    \"delimiter\": \"\",\n    \"delimiter_at_every\": 0,\n    \"extension_attributes\": {},\n    \"format\": \"\",\n    \"length\": 0,\n    \"prefix\": \"\",\n    \"quantity\": 0,\n    \"rule_id\": 0,\n    \"suffix\": \"\"\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/V1/coupons/generate') do |req|
  req.body = "{\n  \"couponSpec\": {\n    \"delimiter\": \"\",\n    \"delimiter_at_every\": 0,\n    \"extension_attributes\": {},\n    \"format\": \"\",\n    \"length\": 0,\n    \"prefix\": \"\",\n    \"quantity\": 0,\n    \"rule_id\": 0,\n    \"suffix\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/coupons/generate";

    let payload = json!({"couponSpec": json!({
            "delimiter": "",
            "delimiter_at_every": 0,
            "extension_attributes": json!({}),
            "format": "",
            "length": 0,
            "prefix": "",
            "quantity": 0,
            "rule_id": 0,
            "suffix": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/coupons/generate \
  --header 'content-type: application/json' \
  --data '{
  "couponSpec": {
    "delimiter": "",
    "delimiter_at_every": 0,
    "extension_attributes": {},
    "format": "",
    "length": 0,
    "prefix": "",
    "quantity": 0,
    "rule_id": 0,
    "suffix": ""
  }
}'
echo '{
  "couponSpec": {
    "delimiter": "",
    "delimiter_at_every": 0,
    "extension_attributes": {},
    "format": "",
    "length": 0,
    "prefix": "",
    "quantity": 0,
    "rule_id": 0,
    "suffix": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/coupons/generate \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "couponSpec": {\n    "delimiter": "",\n    "delimiter_at_every": 0,\n    "extension_attributes": {},\n    "format": "",\n    "length": 0,\n    "prefix": "",\n    "quantity": 0,\n    "rule_id": 0,\n    "suffix": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/coupons/generate
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["couponSpec": [
    "delimiter": "",
    "delimiter_at_every": 0,
    "extension_attributes": [],
    "format": "",
    "length": 0,
    "prefix": "",
    "quantity": 0,
    "rule_id": 0,
    "suffix": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/coupons/generate")! 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}}/V1/coupons/search");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/coupons/search")
require "http/client"

url = "{{baseUrl}}/V1/coupons/search"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/coupons/search"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/coupons/search");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/coupons/search"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/coupons/search HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/coupons/search")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/coupons/search"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/coupons/search")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/coupons/search")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/coupons/search');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/coupons/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/coupons/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/coupons/search',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/coupons/search")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/coupons/search',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/coupons/search'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/coupons/search');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/coupons/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/coupons/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/coupons/search"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/coupons/search" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/coupons/search",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/coupons/search');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/coupons/search');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/coupons/search');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/coupons/search' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/coupons/search' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/coupons/search")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/coupons/search"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/coupons/search"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/coupons/search")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/coupons/search') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/coupons/search";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/coupons/search
http GET {{baseUrl}}/V1/coupons/search
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/coupons/search
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/coupons/search")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST creditmemo
{{baseUrl}}/V1/creditmemo
BODY json

{
  "entity": {
    "adjustment": "",
    "adjustment_negative": "",
    "adjustment_positive": "",
    "base_adjustment": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "creditmemo_status": 0,
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": ""
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "invoice_id": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "base_weee_tax_applied_amount": "",
        "base_weee_tax_applied_row_amnt": "",
        "base_weee_tax_disposition": "",
        "base_weee_tax_row_disposition": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": "",
        "weee_tax_applied": "",
        "weee_tax_applied_amount": "",
        "weee_tax_applied_row_amount": "",
        "weee_tax_disposition": "",
        "weee_tax_row_disposition": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "transaction_id": "",
    "updated_at": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/creditmemo");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"entity\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/creditmemo" {:content-type :json
                                                          :form-params {:entity {:adjustment ""
                                                                                 :adjustment_negative ""
                                                                                 :adjustment_positive ""
                                                                                 :base_adjustment ""
                                                                                 :base_adjustment_negative ""
                                                                                 :base_adjustment_positive ""
                                                                                 :base_currency_code ""
                                                                                 :base_discount_amount ""
                                                                                 :base_discount_tax_compensation_amount ""
                                                                                 :base_grand_total ""
                                                                                 :base_shipping_amount ""
                                                                                 :base_shipping_discount_tax_compensation_amnt ""
                                                                                 :base_shipping_incl_tax ""
                                                                                 :base_shipping_tax_amount ""
                                                                                 :base_subtotal ""
                                                                                 :base_subtotal_incl_tax ""
                                                                                 :base_tax_amount ""
                                                                                 :base_to_global_rate ""
                                                                                 :base_to_order_rate ""
                                                                                 :billing_address_id 0
                                                                                 :comments [{:comment ""
                                                                                             :created_at ""
                                                                                             :entity_id 0
                                                                                             :extension_attributes {}
                                                                                             :is_customer_notified 0
                                                                                             :is_visible_on_front 0
                                                                                             :parent_id 0}]
                                                                                 :created_at ""
                                                                                 :creditmemo_status 0
                                                                                 :discount_amount ""
                                                                                 :discount_description ""
                                                                                 :discount_tax_compensation_amount ""
                                                                                 :email_sent 0
                                                                                 :entity_id 0
                                                                                 :extension_attributes {:base_customer_balance_amount ""
                                                                                                        :base_gift_cards_amount ""
                                                                                                        :customer_balance_amount ""
                                                                                                        :gift_cards_amount ""
                                                                                                        :gw_base_price ""
                                                                                                        :gw_base_tax_amount ""
                                                                                                        :gw_card_base_price ""
                                                                                                        :gw_card_base_tax_amount ""
                                                                                                        :gw_card_price ""
                                                                                                        :gw_card_tax_amount ""
                                                                                                        :gw_items_base_price ""
                                                                                                        :gw_items_base_tax_amount ""
                                                                                                        :gw_items_price ""
                                                                                                        :gw_items_tax_amount ""
                                                                                                        :gw_price ""
                                                                                                        :gw_tax_amount ""}
                                                                                 :global_currency_code ""
                                                                                 :grand_total ""
                                                                                 :increment_id ""
                                                                                 :invoice_id 0
                                                                                 :items [{:additional_data ""
                                                                                          :base_cost ""
                                                                                          :base_discount_amount ""
                                                                                          :base_discount_tax_compensation_amount ""
                                                                                          :base_price ""
                                                                                          :base_price_incl_tax ""
                                                                                          :base_row_total ""
                                                                                          :base_row_total_incl_tax ""
                                                                                          :base_tax_amount ""
                                                                                          :base_weee_tax_applied_amount ""
                                                                                          :base_weee_tax_applied_row_amnt ""
                                                                                          :base_weee_tax_disposition ""
                                                                                          :base_weee_tax_row_disposition ""
                                                                                          :description ""
                                                                                          :discount_amount ""
                                                                                          :discount_tax_compensation_amount ""
                                                                                          :entity_id 0
                                                                                          :extension_attributes {:invoice_text_codes []
                                                                                                                 :tax_codes []
                                                                                                                 :vertex_tax_codes []}
                                                                                          :name ""
                                                                                          :order_item_id 0
                                                                                          :parent_id 0
                                                                                          :price ""
                                                                                          :price_incl_tax ""
                                                                                          :product_id 0
                                                                                          :qty ""
                                                                                          :row_total ""
                                                                                          :row_total_incl_tax ""
                                                                                          :sku ""
                                                                                          :tax_amount ""
                                                                                          :weee_tax_applied ""
                                                                                          :weee_tax_applied_amount ""
                                                                                          :weee_tax_applied_row_amount ""
                                                                                          :weee_tax_disposition ""
                                                                                          :weee_tax_row_disposition ""}]
                                                                                 :order_currency_code ""
                                                                                 :order_id 0
                                                                                 :shipping_address_id 0
                                                                                 :shipping_amount ""
                                                                                 :shipping_discount_tax_compensation_amount ""
                                                                                 :shipping_incl_tax ""
                                                                                 :shipping_tax_amount ""
                                                                                 :state 0
                                                                                 :store_currency_code ""
                                                                                 :store_id 0
                                                                                 :store_to_base_rate ""
                                                                                 :store_to_order_rate ""
                                                                                 :subtotal ""
                                                                                 :subtotal_incl_tax ""
                                                                                 :tax_amount ""
                                                                                 :transaction_id ""
                                                                                 :updated_at ""}}})
require "http/client"

url = "{{baseUrl}}/V1/creditmemo"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"entity\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\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}}/V1/creditmemo"),
    Content = new StringContent("{\n  \"entity\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\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}}/V1/creditmemo");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"entity\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/creditmemo"

	payload := strings.NewReader("{\n  \"entity\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/creditmemo HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 3479

{
  "entity": {
    "adjustment": "",
    "adjustment_negative": "",
    "adjustment_positive": "",
    "base_adjustment": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "creditmemo_status": 0,
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": ""
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "invoice_id": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "base_weee_tax_applied_amount": "",
        "base_weee_tax_applied_row_amnt": "",
        "base_weee_tax_disposition": "",
        "base_weee_tax_row_disposition": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": "",
        "weee_tax_applied": "",
        "weee_tax_applied_amount": "",
        "weee_tax_applied_row_amount": "",
        "weee_tax_disposition": "",
        "weee_tax_row_disposition": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "transaction_id": "",
    "updated_at": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/creditmemo")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"entity\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/creditmemo"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"entity\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\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  \"entity\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/creditmemo")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/creditmemo")
  .header("content-type", "application/json")
  .body("{\n  \"entity\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  entity: {
    adjustment: '',
    adjustment_negative: '',
    adjustment_positive: '',
    base_adjustment: '',
    base_adjustment_negative: '',
    base_adjustment_positive: '',
    base_currency_code: '',
    base_discount_amount: '',
    base_discount_tax_compensation_amount: '',
    base_grand_total: '',
    base_shipping_amount: '',
    base_shipping_discount_tax_compensation_amnt: '',
    base_shipping_incl_tax: '',
    base_shipping_tax_amount: '',
    base_subtotal: '',
    base_subtotal_incl_tax: '',
    base_tax_amount: '',
    base_to_global_rate: '',
    base_to_order_rate: '',
    billing_address_id: 0,
    comments: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0
      }
    ],
    created_at: '',
    creditmemo_status: 0,
    discount_amount: '',
    discount_description: '',
    discount_tax_compensation_amount: '',
    email_sent: 0,
    entity_id: 0,
    extension_attributes: {
      base_customer_balance_amount: '',
      base_gift_cards_amount: '',
      customer_balance_amount: '',
      gift_cards_amount: '',
      gw_base_price: '',
      gw_base_tax_amount: '',
      gw_card_base_price: '',
      gw_card_base_tax_amount: '',
      gw_card_price: '',
      gw_card_tax_amount: '',
      gw_items_base_price: '',
      gw_items_base_tax_amount: '',
      gw_items_price: '',
      gw_items_tax_amount: '',
      gw_price: '',
      gw_tax_amount: ''
    },
    global_currency_code: '',
    grand_total: '',
    increment_id: '',
    invoice_id: 0,
    items: [
      {
        additional_data: '',
        base_cost: '',
        base_discount_amount: '',
        base_discount_tax_compensation_amount: '',
        base_price: '',
        base_price_incl_tax: '',
        base_row_total: '',
        base_row_total_incl_tax: '',
        base_tax_amount: '',
        base_weee_tax_applied_amount: '',
        base_weee_tax_applied_row_amnt: '',
        base_weee_tax_disposition: '',
        base_weee_tax_row_disposition: '',
        description: '',
        discount_amount: '',
        discount_tax_compensation_amount: '',
        entity_id: 0,
        extension_attributes: {
          invoice_text_codes: [],
          tax_codes: [],
          vertex_tax_codes: []
        },
        name: '',
        order_item_id: 0,
        parent_id: 0,
        price: '',
        price_incl_tax: '',
        product_id: 0,
        qty: '',
        row_total: '',
        row_total_incl_tax: '',
        sku: '',
        tax_amount: '',
        weee_tax_applied: '',
        weee_tax_applied_amount: '',
        weee_tax_applied_row_amount: '',
        weee_tax_disposition: '',
        weee_tax_row_disposition: ''
      }
    ],
    order_currency_code: '',
    order_id: 0,
    shipping_address_id: 0,
    shipping_amount: '',
    shipping_discount_tax_compensation_amount: '',
    shipping_incl_tax: '',
    shipping_tax_amount: '',
    state: 0,
    store_currency_code: '',
    store_id: 0,
    store_to_base_rate: '',
    store_to_order_rate: '',
    subtotal: '',
    subtotal_incl_tax: '',
    tax_amount: '',
    transaction_id: '',
    updated_at: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/creditmemo');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/creditmemo',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      adjustment: '',
      adjustment_negative: '',
      adjustment_positive: '',
      base_adjustment: '',
      base_adjustment_negative: '',
      base_adjustment_positive: '',
      base_currency_code: '',
      base_discount_amount: '',
      base_discount_tax_compensation_amount: '',
      base_grand_total: '',
      base_shipping_amount: '',
      base_shipping_discount_tax_compensation_amnt: '',
      base_shipping_incl_tax: '',
      base_shipping_tax_amount: '',
      base_subtotal: '',
      base_subtotal_incl_tax: '',
      base_tax_amount: '',
      base_to_global_rate: '',
      base_to_order_rate: '',
      billing_address_id: 0,
      comments: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0
        }
      ],
      created_at: '',
      creditmemo_status: 0,
      discount_amount: '',
      discount_description: '',
      discount_tax_compensation_amount: '',
      email_sent: 0,
      entity_id: 0,
      extension_attributes: {
        base_customer_balance_amount: '',
        base_gift_cards_amount: '',
        customer_balance_amount: '',
        gift_cards_amount: '',
        gw_base_price: '',
        gw_base_tax_amount: '',
        gw_card_base_price: '',
        gw_card_base_tax_amount: '',
        gw_card_price: '',
        gw_card_tax_amount: '',
        gw_items_base_price: '',
        gw_items_base_tax_amount: '',
        gw_items_price: '',
        gw_items_tax_amount: '',
        gw_price: '',
        gw_tax_amount: ''
      },
      global_currency_code: '',
      grand_total: '',
      increment_id: '',
      invoice_id: 0,
      items: [
        {
          additional_data: '',
          base_cost: '',
          base_discount_amount: '',
          base_discount_tax_compensation_amount: '',
          base_price: '',
          base_price_incl_tax: '',
          base_row_total: '',
          base_row_total_incl_tax: '',
          base_tax_amount: '',
          base_weee_tax_applied_amount: '',
          base_weee_tax_applied_row_amnt: '',
          base_weee_tax_disposition: '',
          base_weee_tax_row_disposition: '',
          description: '',
          discount_amount: '',
          discount_tax_compensation_amount: '',
          entity_id: 0,
          extension_attributes: {invoice_text_codes: [], tax_codes: [], vertex_tax_codes: []},
          name: '',
          order_item_id: 0,
          parent_id: 0,
          price: '',
          price_incl_tax: '',
          product_id: 0,
          qty: '',
          row_total: '',
          row_total_incl_tax: '',
          sku: '',
          tax_amount: '',
          weee_tax_applied: '',
          weee_tax_applied_amount: '',
          weee_tax_applied_row_amount: '',
          weee_tax_disposition: '',
          weee_tax_row_disposition: ''
        }
      ],
      order_currency_code: '',
      order_id: 0,
      shipping_address_id: 0,
      shipping_amount: '',
      shipping_discount_tax_compensation_amount: '',
      shipping_incl_tax: '',
      shipping_tax_amount: '',
      state: 0,
      store_currency_code: '',
      store_id: 0,
      store_to_base_rate: '',
      store_to_order_rate: '',
      subtotal: '',
      subtotal_incl_tax: '',
      tax_amount: '',
      transaction_id: '',
      updated_at: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/creditmemo';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"adjustment":"","adjustment_negative":"","adjustment_positive":"","base_adjustment":"","base_adjustment_negative":"","base_adjustment_positive":"","base_currency_code":"","base_discount_amount":"","base_discount_tax_compensation_amount":"","base_grand_total":"","base_shipping_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_tax_amount":"","base_subtotal":"","base_subtotal_incl_tax":"","base_tax_amount":"","base_to_global_rate":"","base_to_order_rate":"","billing_address_id":0,"comments":[{"comment":"","created_at":"","entity_id":0,"extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_id":0}],"created_at":"","creditmemo_status":0,"discount_amount":"","discount_description":"","discount_tax_compensation_amount":"","email_sent":0,"entity_id":0,"extension_attributes":{"base_customer_balance_amount":"","base_gift_cards_amount":"","customer_balance_amount":"","gift_cards_amount":"","gw_base_price":"","gw_base_tax_amount":"","gw_card_base_price":"","gw_card_base_tax_amount":"","gw_card_price":"","gw_card_tax_amount":"","gw_items_base_price":"","gw_items_base_tax_amount":"","gw_items_price":"","gw_items_tax_amount":"","gw_price":"","gw_tax_amount":""},"global_currency_code":"","grand_total":"","increment_id":"","invoice_id":0,"items":[{"additional_data":"","base_cost":"","base_discount_amount":"","base_discount_tax_compensation_amount":"","base_price":"","base_price_incl_tax":"","base_row_total":"","base_row_total_incl_tax":"","base_tax_amount":"","base_weee_tax_applied_amount":"","base_weee_tax_applied_row_amnt":"","base_weee_tax_disposition":"","base_weee_tax_row_disposition":"","description":"","discount_amount":"","discount_tax_compensation_amount":"","entity_id":0,"extension_attributes":{"invoice_text_codes":[],"tax_codes":[],"vertex_tax_codes":[]},"name":"","order_item_id":0,"parent_id":0,"price":"","price_incl_tax":"","product_id":0,"qty":"","row_total":"","row_total_incl_tax":"","sku":"","tax_amount":"","weee_tax_applied":"","weee_tax_applied_amount":"","weee_tax_applied_row_amount":"","weee_tax_disposition":"","weee_tax_row_disposition":""}],"order_currency_code":"","order_id":0,"shipping_address_id":0,"shipping_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_tax_amount":"","state":0,"store_currency_code":"","store_id":0,"store_to_base_rate":"","store_to_order_rate":"","subtotal":"","subtotal_incl_tax":"","tax_amount":"","transaction_id":"","updated_at":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/creditmemo',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "entity": {\n    "adjustment": "",\n    "adjustment_negative": "",\n    "adjustment_positive": "",\n    "base_adjustment": "",\n    "base_adjustment_negative": "",\n    "base_adjustment_positive": "",\n    "base_currency_code": "",\n    "base_discount_amount": "",\n    "base_discount_tax_compensation_amount": "",\n    "base_grand_total": "",\n    "base_shipping_amount": "",\n    "base_shipping_discount_tax_compensation_amnt": "",\n    "base_shipping_incl_tax": "",\n    "base_shipping_tax_amount": "",\n    "base_subtotal": "",\n    "base_subtotal_incl_tax": "",\n    "base_tax_amount": "",\n    "base_to_global_rate": "",\n    "base_to_order_rate": "",\n    "billing_address_id": 0,\n    "comments": [\n      {\n        "comment": "",\n        "created_at": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "is_customer_notified": 0,\n        "is_visible_on_front": 0,\n        "parent_id": 0\n      }\n    ],\n    "created_at": "",\n    "creditmemo_status": 0,\n    "discount_amount": "",\n    "discount_description": "",\n    "discount_tax_compensation_amount": "",\n    "email_sent": 0,\n    "entity_id": 0,\n    "extension_attributes": {\n      "base_customer_balance_amount": "",\n      "base_gift_cards_amount": "",\n      "customer_balance_amount": "",\n      "gift_cards_amount": "",\n      "gw_base_price": "",\n      "gw_base_tax_amount": "",\n      "gw_card_base_price": "",\n      "gw_card_base_tax_amount": "",\n      "gw_card_price": "",\n      "gw_card_tax_amount": "",\n      "gw_items_base_price": "",\n      "gw_items_base_tax_amount": "",\n      "gw_items_price": "",\n      "gw_items_tax_amount": "",\n      "gw_price": "",\n      "gw_tax_amount": ""\n    },\n    "global_currency_code": "",\n    "grand_total": "",\n    "increment_id": "",\n    "invoice_id": 0,\n    "items": [\n      {\n        "additional_data": "",\n        "base_cost": "",\n        "base_discount_amount": "",\n        "base_discount_tax_compensation_amount": "",\n        "base_price": "",\n        "base_price_incl_tax": "",\n        "base_row_total": "",\n        "base_row_total_incl_tax": "",\n        "base_tax_amount": "",\n        "base_weee_tax_applied_amount": "",\n        "base_weee_tax_applied_row_amnt": "",\n        "base_weee_tax_disposition": "",\n        "base_weee_tax_row_disposition": "",\n        "description": "",\n        "discount_amount": "",\n        "discount_tax_compensation_amount": "",\n        "entity_id": 0,\n        "extension_attributes": {\n          "invoice_text_codes": [],\n          "tax_codes": [],\n          "vertex_tax_codes": []\n        },\n        "name": "",\n        "order_item_id": 0,\n        "parent_id": 0,\n        "price": "",\n        "price_incl_tax": "",\n        "product_id": 0,\n        "qty": "",\n        "row_total": "",\n        "row_total_incl_tax": "",\n        "sku": "",\n        "tax_amount": "",\n        "weee_tax_applied": "",\n        "weee_tax_applied_amount": "",\n        "weee_tax_applied_row_amount": "",\n        "weee_tax_disposition": "",\n        "weee_tax_row_disposition": ""\n      }\n    ],\n    "order_currency_code": "",\n    "order_id": 0,\n    "shipping_address_id": 0,\n    "shipping_amount": "",\n    "shipping_discount_tax_compensation_amount": "",\n    "shipping_incl_tax": "",\n    "shipping_tax_amount": "",\n    "state": 0,\n    "store_currency_code": "",\n    "store_id": 0,\n    "store_to_base_rate": "",\n    "store_to_order_rate": "",\n    "subtotal": "",\n    "subtotal_incl_tax": "",\n    "tax_amount": "",\n    "transaction_id": "",\n    "updated_at": ""\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  \"entity\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/creditmemo")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/creditmemo',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  entity: {
    adjustment: '',
    adjustment_negative: '',
    adjustment_positive: '',
    base_adjustment: '',
    base_adjustment_negative: '',
    base_adjustment_positive: '',
    base_currency_code: '',
    base_discount_amount: '',
    base_discount_tax_compensation_amount: '',
    base_grand_total: '',
    base_shipping_amount: '',
    base_shipping_discount_tax_compensation_amnt: '',
    base_shipping_incl_tax: '',
    base_shipping_tax_amount: '',
    base_subtotal: '',
    base_subtotal_incl_tax: '',
    base_tax_amount: '',
    base_to_global_rate: '',
    base_to_order_rate: '',
    billing_address_id: 0,
    comments: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0
      }
    ],
    created_at: '',
    creditmemo_status: 0,
    discount_amount: '',
    discount_description: '',
    discount_tax_compensation_amount: '',
    email_sent: 0,
    entity_id: 0,
    extension_attributes: {
      base_customer_balance_amount: '',
      base_gift_cards_amount: '',
      customer_balance_amount: '',
      gift_cards_amount: '',
      gw_base_price: '',
      gw_base_tax_amount: '',
      gw_card_base_price: '',
      gw_card_base_tax_amount: '',
      gw_card_price: '',
      gw_card_tax_amount: '',
      gw_items_base_price: '',
      gw_items_base_tax_amount: '',
      gw_items_price: '',
      gw_items_tax_amount: '',
      gw_price: '',
      gw_tax_amount: ''
    },
    global_currency_code: '',
    grand_total: '',
    increment_id: '',
    invoice_id: 0,
    items: [
      {
        additional_data: '',
        base_cost: '',
        base_discount_amount: '',
        base_discount_tax_compensation_amount: '',
        base_price: '',
        base_price_incl_tax: '',
        base_row_total: '',
        base_row_total_incl_tax: '',
        base_tax_amount: '',
        base_weee_tax_applied_amount: '',
        base_weee_tax_applied_row_amnt: '',
        base_weee_tax_disposition: '',
        base_weee_tax_row_disposition: '',
        description: '',
        discount_amount: '',
        discount_tax_compensation_amount: '',
        entity_id: 0,
        extension_attributes: {invoice_text_codes: [], tax_codes: [], vertex_tax_codes: []},
        name: '',
        order_item_id: 0,
        parent_id: 0,
        price: '',
        price_incl_tax: '',
        product_id: 0,
        qty: '',
        row_total: '',
        row_total_incl_tax: '',
        sku: '',
        tax_amount: '',
        weee_tax_applied: '',
        weee_tax_applied_amount: '',
        weee_tax_applied_row_amount: '',
        weee_tax_disposition: '',
        weee_tax_row_disposition: ''
      }
    ],
    order_currency_code: '',
    order_id: 0,
    shipping_address_id: 0,
    shipping_amount: '',
    shipping_discount_tax_compensation_amount: '',
    shipping_incl_tax: '',
    shipping_tax_amount: '',
    state: 0,
    store_currency_code: '',
    store_id: 0,
    store_to_base_rate: '',
    store_to_order_rate: '',
    subtotal: '',
    subtotal_incl_tax: '',
    tax_amount: '',
    transaction_id: '',
    updated_at: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/creditmemo',
  headers: {'content-type': 'application/json'},
  body: {
    entity: {
      adjustment: '',
      adjustment_negative: '',
      adjustment_positive: '',
      base_adjustment: '',
      base_adjustment_negative: '',
      base_adjustment_positive: '',
      base_currency_code: '',
      base_discount_amount: '',
      base_discount_tax_compensation_amount: '',
      base_grand_total: '',
      base_shipping_amount: '',
      base_shipping_discount_tax_compensation_amnt: '',
      base_shipping_incl_tax: '',
      base_shipping_tax_amount: '',
      base_subtotal: '',
      base_subtotal_incl_tax: '',
      base_tax_amount: '',
      base_to_global_rate: '',
      base_to_order_rate: '',
      billing_address_id: 0,
      comments: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0
        }
      ],
      created_at: '',
      creditmemo_status: 0,
      discount_amount: '',
      discount_description: '',
      discount_tax_compensation_amount: '',
      email_sent: 0,
      entity_id: 0,
      extension_attributes: {
        base_customer_balance_amount: '',
        base_gift_cards_amount: '',
        customer_balance_amount: '',
        gift_cards_amount: '',
        gw_base_price: '',
        gw_base_tax_amount: '',
        gw_card_base_price: '',
        gw_card_base_tax_amount: '',
        gw_card_price: '',
        gw_card_tax_amount: '',
        gw_items_base_price: '',
        gw_items_base_tax_amount: '',
        gw_items_price: '',
        gw_items_tax_amount: '',
        gw_price: '',
        gw_tax_amount: ''
      },
      global_currency_code: '',
      grand_total: '',
      increment_id: '',
      invoice_id: 0,
      items: [
        {
          additional_data: '',
          base_cost: '',
          base_discount_amount: '',
          base_discount_tax_compensation_amount: '',
          base_price: '',
          base_price_incl_tax: '',
          base_row_total: '',
          base_row_total_incl_tax: '',
          base_tax_amount: '',
          base_weee_tax_applied_amount: '',
          base_weee_tax_applied_row_amnt: '',
          base_weee_tax_disposition: '',
          base_weee_tax_row_disposition: '',
          description: '',
          discount_amount: '',
          discount_tax_compensation_amount: '',
          entity_id: 0,
          extension_attributes: {invoice_text_codes: [], tax_codes: [], vertex_tax_codes: []},
          name: '',
          order_item_id: 0,
          parent_id: 0,
          price: '',
          price_incl_tax: '',
          product_id: 0,
          qty: '',
          row_total: '',
          row_total_incl_tax: '',
          sku: '',
          tax_amount: '',
          weee_tax_applied: '',
          weee_tax_applied_amount: '',
          weee_tax_applied_row_amount: '',
          weee_tax_disposition: '',
          weee_tax_row_disposition: ''
        }
      ],
      order_currency_code: '',
      order_id: 0,
      shipping_address_id: 0,
      shipping_amount: '',
      shipping_discount_tax_compensation_amount: '',
      shipping_incl_tax: '',
      shipping_tax_amount: '',
      state: 0,
      store_currency_code: '',
      store_id: 0,
      store_to_base_rate: '',
      store_to_order_rate: '',
      subtotal: '',
      subtotal_incl_tax: '',
      tax_amount: '',
      transaction_id: '',
      updated_at: ''
    }
  },
  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}}/V1/creditmemo');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  entity: {
    adjustment: '',
    adjustment_negative: '',
    adjustment_positive: '',
    base_adjustment: '',
    base_adjustment_negative: '',
    base_adjustment_positive: '',
    base_currency_code: '',
    base_discount_amount: '',
    base_discount_tax_compensation_amount: '',
    base_grand_total: '',
    base_shipping_amount: '',
    base_shipping_discount_tax_compensation_amnt: '',
    base_shipping_incl_tax: '',
    base_shipping_tax_amount: '',
    base_subtotal: '',
    base_subtotal_incl_tax: '',
    base_tax_amount: '',
    base_to_global_rate: '',
    base_to_order_rate: '',
    billing_address_id: 0,
    comments: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0
      }
    ],
    created_at: '',
    creditmemo_status: 0,
    discount_amount: '',
    discount_description: '',
    discount_tax_compensation_amount: '',
    email_sent: 0,
    entity_id: 0,
    extension_attributes: {
      base_customer_balance_amount: '',
      base_gift_cards_amount: '',
      customer_balance_amount: '',
      gift_cards_amount: '',
      gw_base_price: '',
      gw_base_tax_amount: '',
      gw_card_base_price: '',
      gw_card_base_tax_amount: '',
      gw_card_price: '',
      gw_card_tax_amount: '',
      gw_items_base_price: '',
      gw_items_base_tax_amount: '',
      gw_items_price: '',
      gw_items_tax_amount: '',
      gw_price: '',
      gw_tax_amount: ''
    },
    global_currency_code: '',
    grand_total: '',
    increment_id: '',
    invoice_id: 0,
    items: [
      {
        additional_data: '',
        base_cost: '',
        base_discount_amount: '',
        base_discount_tax_compensation_amount: '',
        base_price: '',
        base_price_incl_tax: '',
        base_row_total: '',
        base_row_total_incl_tax: '',
        base_tax_amount: '',
        base_weee_tax_applied_amount: '',
        base_weee_tax_applied_row_amnt: '',
        base_weee_tax_disposition: '',
        base_weee_tax_row_disposition: '',
        description: '',
        discount_amount: '',
        discount_tax_compensation_amount: '',
        entity_id: 0,
        extension_attributes: {
          invoice_text_codes: [],
          tax_codes: [],
          vertex_tax_codes: []
        },
        name: '',
        order_item_id: 0,
        parent_id: 0,
        price: '',
        price_incl_tax: '',
        product_id: 0,
        qty: '',
        row_total: '',
        row_total_incl_tax: '',
        sku: '',
        tax_amount: '',
        weee_tax_applied: '',
        weee_tax_applied_amount: '',
        weee_tax_applied_row_amount: '',
        weee_tax_disposition: '',
        weee_tax_row_disposition: ''
      }
    ],
    order_currency_code: '',
    order_id: 0,
    shipping_address_id: 0,
    shipping_amount: '',
    shipping_discount_tax_compensation_amount: '',
    shipping_incl_tax: '',
    shipping_tax_amount: '',
    state: 0,
    store_currency_code: '',
    store_id: 0,
    store_to_base_rate: '',
    store_to_order_rate: '',
    subtotal: '',
    subtotal_incl_tax: '',
    tax_amount: '',
    transaction_id: '',
    updated_at: ''
  }
});

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}}/V1/creditmemo',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      adjustment: '',
      adjustment_negative: '',
      adjustment_positive: '',
      base_adjustment: '',
      base_adjustment_negative: '',
      base_adjustment_positive: '',
      base_currency_code: '',
      base_discount_amount: '',
      base_discount_tax_compensation_amount: '',
      base_grand_total: '',
      base_shipping_amount: '',
      base_shipping_discount_tax_compensation_amnt: '',
      base_shipping_incl_tax: '',
      base_shipping_tax_amount: '',
      base_subtotal: '',
      base_subtotal_incl_tax: '',
      base_tax_amount: '',
      base_to_global_rate: '',
      base_to_order_rate: '',
      billing_address_id: 0,
      comments: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0
        }
      ],
      created_at: '',
      creditmemo_status: 0,
      discount_amount: '',
      discount_description: '',
      discount_tax_compensation_amount: '',
      email_sent: 0,
      entity_id: 0,
      extension_attributes: {
        base_customer_balance_amount: '',
        base_gift_cards_amount: '',
        customer_balance_amount: '',
        gift_cards_amount: '',
        gw_base_price: '',
        gw_base_tax_amount: '',
        gw_card_base_price: '',
        gw_card_base_tax_amount: '',
        gw_card_price: '',
        gw_card_tax_amount: '',
        gw_items_base_price: '',
        gw_items_base_tax_amount: '',
        gw_items_price: '',
        gw_items_tax_amount: '',
        gw_price: '',
        gw_tax_amount: ''
      },
      global_currency_code: '',
      grand_total: '',
      increment_id: '',
      invoice_id: 0,
      items: [
        {
          additional_data: '',
          base_cost: '',
          base_discount_amount: '',
          base_discount_tax_compensation_amount: '',
          base_price: '',
          base_price_incl_tax: '',
          base_row_total: '',
          base_row_total_incl_tax: '',
          base_tax_amount: '',
          base_weee_tax_applied_amount: '',
          base_weee_tax_applied_row_amnt: '',
          base_weee_tax_disposition: '',
          base_weee_tax_row_disposition: '',
          description: '',
          discount_amount: '',
          discount_tax_compensation_amount: '',
          entity_id: 0,
          extension_attributes: {invoice_text_codes: [], tax_codes: [], vertex_tax_codes: []},
          name: '',
          order_item_id: 0,
          parent_id: 0,
          price: '',
          price_incl_tax: '',
          product_id: 0,
          qty: '',
          row_total: '',
          row_total_incl_tax: '',
          sku: '',
          tax_amount: '',
          weee_tax_applied: '',
          weee_tax_applied_amount: '',
          weee_tax_applied_row_amount: '',
          weee_tax_disposition: '',
          weee_tax_row_disposition: ''
        }
      ],
      order_currency_code: '',
      order_id: 0,
      shipping_address_id: 0,
      shipping_amount: '',
      shipping_discount_tax_compensation_amount: '',
      shipping_incl_tax: '',
      shipping_tax_amount: '',
      state: 0,
      store_currency_code: '',
      store_id: 0,
      store_to_base_rate: '',
      store_to_order_rate: '',
      subtotal: '',
      subtotal_incl_tax: '',
      tax_amount: '',
      transaction_id: '',
      updated_at: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/creditmemo';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"adjustment":"","adjustment_negative":"","adjustment_positive":"","base_adjustment":"","base_adjustment_negative":"","base_adjustment_positive":"","base_currency_code":"","base_discount_amount":"","base_discount_tax_compensation_amount":"","base_grand_total":"","base_shipping_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_tax_amount":"","base_subtotal":"","base_subtotal_incl_tax":"","base_tax_amount":"","base_to_global_rate":"","base_to_order_rate":"","billing_address_id":0,"comments":[{"comment":"","created_at":"","entity_id":0,"extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_id":0}],"created_at":"","creditmemo_status":0,"discount_amount":"","discount_description":"","discount_tax_compensation_amount":"","email_sent":0,"entity_id":0,"extension_attributes":{"base_customer_balance_amount":"","base_gift_cards_amount":"","customer_balance_amount":"","gift_cards_amount":"","gw_base_price":"","gw_base_tax_amount":"","gw_card_base_price":"","gw_card_base_tax_amount":"","gw_card_price":"","gw_card_tax_amount":"","gw_items_base_price":"","gw_items_base_tax_amount":"","gw_items_price":"","gw_items_tax_amount":"","gw_price":"","gw_tax_amount":""},"global_currency_code":"","grand_total":"","increment_id":"","invoice_id":0,"items":[{"additional_data":"","base_cost":"","base_discount_amount":"","base_discount_tax_compensation_amount":"","base_price":"","base_price_incl_tax":"","base_row_total":"","base_row_total_incl_tax":"","base_tax_amount":"","base_weee_tax_applied_amount":"","base_weee_tax_applied_row_amnt":"","base_weee_tax_disposition":"","base_weee_tax_row_disposition":"","description":"","discount_amount":"","discount_tax_compensation_amount":"","entity_id":0,"extension_attributes":{"invoice_text_codes":[],"tax_codes":[],"vertex_tax_codes":[]},"name":"","order_item_id":0,"parent_id":0,"price":"","price_incl_tax":"","product_id":0,"qty":"","row_total":"","row_total_incl_tax":"","sku":"","tax_amount":"","weee_tax_applied":"","weee_tax_applied_amount":"","weee_tax_applied_row_amount":"","weee_tax_disposition":"","weee_tax_row_disposition":""}],"order_currency_code":"","order_id":0,"shipping_address_id":0,"shipping_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_tax_amount":"","state":0,"store_currency_code":"","store_id":0,"store_to_base_rate":"","store_to_order_rate":"","subtotal":"","subtotal_incl_tax":"","tax_amount":"","transaction_id":"","updated_at":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"entity": @{ @"adjustment": @"", @"adjustment_negative": @"", @"adjustment_positive": @"", @"base_adjustment": @"", @"base_adjustment_negative": @"", @"base_adjustment_positive": @"", @"base_currency_code": @"", @"base_discount_amount": @"", @"base_discount_tax_compensation_amount": @"", @"base_grand_total": @"", @"base_shipping_amount": @"", @"base_shipping_discount_tax_compensation_amnt": @"", @"base_shipping_incl_tax": @"", @"base_shipping_tax_amount": @"", @"base_subtotal": @"", @"base_subtotal_incl_tax": @"", @"base_tax_amount": @"", @"base_to_global_rate": @"", @"base_to_order_rate": @"", @"billing_address_id": @0, @"comments": @[ @{ @"comment": @"", @"created_at": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"is_customer_notified": @0, @"is_visible_on_front": @0, @"parent_id": @0 } ], @"created_at": @"", @"creditmemo_status": @0, @"discount_amount": @"", @"discount_description": @"", @"discount_tax_compensation_amount": @"", @"email_sent": @0, @"entity_id": @0, @"extension_attributes": @{ @"base_customer_balance_amount": @"", @"base_gift_cards_amount": @"", @"customer_balance_amount": @"", @"gift_cards_amount": @"", @"gw_base_price": @"", @"gw_base_tax_amount": @"", @"gw_card_base_price": @"", @"gw_card_base_tax_amount": @"", @"gw_card_price": @"", @"gw_card_tax_amount": @"", @"gw_items_base_price": @"", @"gw_items_base_tax_amount": @"", @"gw_items_price": @"", @"gw_items_tax_amount": @"", @"gw_price": @"", @"gw_tax_amount": @"" }, @"global_currency_code": @"", @"grand_total": @"", @"increment_id": @"", @"invoice_id": @0, @"items": @[ @{ @"additional_data": @"", @"base_cost": @"", @"base_discount_amount": @"", @"base_discount_tax_compensation_amount": @"", @"base_price": @"", @"base_price_incl_tax": @"", @"base_row_total": @"", @"base_row_total_incl_tax": @"", @"base_tax_amount": @"", @"base_weee_tax_applied_amount": @"", @"base_weee_tax_applied_row_amnt": @"", @"base_weee_tax_disposition": @"", @"base_weee_tax_row_disposition": @"", @"description": @"", @"discount_amount": @"", @"discount_tax_compensation_amount": @"", @"entity_id": @0, @"extension_attributes": @{ @"invoice_text_codes": @[  ], @"tax_codes": @[  ], @"vertex_tax_codes": @[  ] }, @"name": @"", @"order_item_id": @0, @"parent_id": @0, @"price": @"", @"price_incl_tax": @"", @"product_id": @0, @"qty": @"", @"row_total": @"", @"row_total_incl_tax": @"", @"sku": @"", @"tax_amount": @"", @"weee_tax_applied": @"", @"weee_tax_applied_amount": @"", @"weee_tax_applied_row_amount": @"", @"weee_tax_disposition": @"", @"weee_tax_row_disposition": @"" } ], @"order_currency_code": @"", @"order_id": @0, @"shipping_address_id": @0, @"shipping_amount": @"", @"shipping_discount_tax_compensation_amount": @"", @"shipping_incl_tax": @"", @"shipping_tax_amount": @"", @"state": @0, @"store_currency_code": @"", @"store_id": @0, @"store_to_base_rate": @"", @"store_to_order_rate": @"", @"subtotal": @"", @"subtotal_incl_tax": @"", @"tax_amount": @"", @"transaction_id": @"", @"updated_at": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/creditmemo"]
                                                       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}}/V1/creditmemo" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"entity\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/creditmemo",
  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([
    'entity' => [
        'adjustment' => '',
        'adjustment_negative' => '',
        'adjustment_positive' => '',
        'base_adjustment' => '',
        'base_adjustment_negative' => '',
        'base_adjustment_positive' => '',
        'base_currency_code' => '',
        'base_discount_amount' => '',
        'base_discount_tax_compensation_amount' => '',
        'base_grand_total' => '',
        'base_shipping_amount' => '',
        'base_shipping_discount_tax_compensation_amnt' => '',
        'base_shipping_incl_tax' => '',
        'base_shipping_tax_amount' => '',
        'base_subtotal' => '',
        'base_subtotal_incl_tax' => '',
        'base_tax_amount' => '',
        'base_to_global_rate' => '',
        'base_to_order_rate' => '',
        'billing_address_id' => 0,
        'comments' => [
                [
                                'comment' => '',
                                'created_at' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'is_customer_notified' => 0,
                                'is_visible_on_front' => 0,
                                'parent_id' => 0
                ]
        ],
        'created_at' => '',
        'creditmemo_status' => 0,
        'discount_amount' => '',
        'discount_description' => '',
        'discount_tax_compensation_amount' => '',
        'email_sent' => 0,
        'entity_id' => 0,
        'extension_attributes' => [
                'base_customer_balance_amount' => '',
                'base_gift_cards_amount' => '',
                'customer_balance_amount' => '',
                'gift_cards_amount' => '',
                'gw_base_price' => '',
                'gw_base_tax_amount' => '',
                'gw_card_base_price' => '',
                'gw_card_base_tax_amount' => '',
                'gw_card_price' => '',
                'gw_card_tax_amount' => '',
                'gw_items_base_price' => '',
                'gw_items_base_tax_amount' => '',
                'gw_items_price' => '',
                'gw_items_tax_amount' => '',
                'gw_price' => '',
                'gw_tax_amount' => ''
        ],
        'global_currency_code' => '',
        'grand_total' => '',
        'increment_id' => '',
        'invoice_id' => 0,
        'items' => [
                [
                                'additional_data' => '',
                                'base_cost' => '',
                                'base_discount_amount' => '',
                                'base_discount_tax_compensation_amount' => '',
                                'base_price' => '',
                                'base_price_incl_tax' => '',
                                'base_row_total' => '',
                                'base_row_total_incl_tax' => '',
                                'base_tax_amount' => '',
                                'base_weee_tax_applied_amount' => '',
                                'base_weee_tax_applied_row_amnt' => '',
                                'base_weee_tax_disposition' => '',
                                'base_weee_tax_row_disposition' => '',
                                'description' => '',
                                'discount_amount' => '',
                                'discount_tax_compensation_amount' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                'invoice_text_codes' => [
                                                                                                                                
                                                                ],
                                                                'tax_codes' => [
                                                                                                                                
                                                                ],
                                                                'vertex_tax_codes' => [
                                                                                                                                
                                                                ]
                                ],
                                'name' => '',
                                'order_item_id' => 0,
                                'parent_id' => 0,
                                'price' => '',
                                'price_incl_tax' => '',
                                'product_id' => 0,
                                'qty' => '',
                                'row_total' => '',
                                'row_total_incl_tax' => '',
                                'sku' => '',
                                'tax_amount' => '',
                                'weee_tax_applied' => '',
                                'weee_tax_applied_amount' => '',
                                'weee_tax_applied_row_amount' => '',
                                'weee_tax_disposition' => '',
                                'weee_tax_row_disposition' => ''
                ]
        ],
        'order_currency_code' => '',
        'order_id' => 0,
        'shipping_address_id' => 0,
        'shipping_amount' => '',
        'shipping_discount_tax_compensation_amount' => '',
        'shipping_incl_tax' => '',
        'shipping_tax_amount' => '',
        'state' => 0,
        'store_currency_code' => '',
        'store_id' => 0,
        'store_to_base_rate' => '',
        'store_to_order_rate' => '',
        'subtotal' => '',
        'subtotal_incl_tax' => '',
        'tax_amount' => '',
        'transaction_id' => '',
        'updated_at' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/creditmemo', [
  'body' => '{
  "entity": {
    "adjustment": "",
    "adjustment_negative": "",
    "adjustment_positive": "",
    "base_adjustment": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "creditmemo_status": 0,
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": ""
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "invoice_id": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "base_weee_tax_applied_amount": "",
        "base_weee_tax_applied_row_amnt": "",
        "base_weee_tax_disposition": "",
        "base_weee_tax_row_disposition": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": "",
        "weee_tax_applied": "",
        "weee_tax_applied_amount": "",
        "weee_tax_applied_row_amount": "",
        "weee_tax_disposition": "",
        "weee_tax_row_disposition": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "transaction_id": "",
    "updated_at": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/creditmemo');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'entity' => [
    'adjustment' => '',
    'adjustment_negative' => '',
    'adjustment_positive' => '',
    'base_adjustment' => '',
    'base_adjustment_negative' => '',
    'base_adjustment_positive' => '',
    'base_currency_code' => '',
    'base_discount_amount' => '',
    'base_discount_tax_compensation_amount' => '',
    'base_grand_total' => '',
    'base_shipping_amount' => '',
    'base_shipping_discount_tax_compensation_amnt' => '',
    'base_shipping_incl_tax' => '',
    'base_shipping_tax_amount' => '',
    'base_subtotal' => '',
    'base_subtotal_incl_tax' => '',
    'base_tax_amount' => '',
    'base_to_global_rate' => '',
    'base_to_order_rate' => '',
    'billing_address_id' => 0,
    'comments' => [
        [
                'comment' => '',
                'created_at' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'is_customer_notified' => 0,
                'is_visible_on_front' => 0,
                'parent_id' => 0
        ]
    ],
    'created_at' => '',
    'creditmemo_status' => 0,
    'discount_amount' => '',
    'discount_description' => '',
    'discount_tax_compensation_amount' => '',
    'email_sent' => 0,
    'entity_id' => 0,
    'extension_attributes' => [
        'base_customer_balance_amount' => '',
        'base_gift_cards_amount' => '',
        'customer_balance_amount' => '',
        'gift_cards_amount' => '',
        'gw_base_price' => '',
        'gw_base_tax_amount' => '',
        'gw_card_base_price' => '',
        'gw_card_base_tax_amount' => '',
        'gw_card_price' => '',
        'gw_card_tax_amount' => '',
        'gw_items_base_price' => '',
        'gw_items_base_tax_amount' => '',
        'gw_items_price' => '',
        'gw_items_tax_amount' => '',
        'gw_price' => '',
        'gw_tax_amount' => ''
    ],
    'global_currency_code' => '',
    'grand_total' => '',
    'increment_id' => '',
    'invoice_id' => 0,
    'items' => [
        [
                'additional_data' => '',
                'base_cost' => '',
                'base_discount_amount' => '',
                'base_discount_tax_compensation_amount' => '',
                'base_price' => '',
                'base_price_incl_tax' => '',
                'base_row_total' => '',
                'base_row_total_incl_tax' => '',
                'base_tax_amount' => '',
                'base_weee_tax_applied_amount' => '',
                'base_weee_tax_applied_row_amnt' => '',
                'base_weee_tax_disposition' => '',
                'base_weee_tax_row_disposition' => '',
                'description' => '',
                'discount_amount' => '',
                'discount_tax_compensation_amount' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                'invoice_text_codes' => [
                                                                
                                ],
                                'tax_codes' => [
                                                                
                                ],
                                'vertex_tax_codes' => [
                                                                
                                ]
                ],
                'name' => '',
                'order_item_id' => 0,
                'parent_id' => 0,
                'price' => '',
                'price_incl_tax' => '',
                'product_id' => 0,
                'qty' => '',
                'row_total' => '',
                'row_total_incl_tax' => '',
                'sku' => '',
                'tax_amount' => '',
                'weee_tax_applied' => '',
                'weee_tax_applied_amount' => '',
                'weee_tax_applied_row_amount' => '',
                'weee_tax_disposition' => '',
                'weee_tax_row_disposition' => ''
        ]
    ],
    'order_currency_code' => '',
    'order_id' => 0,
    'shipping_address_id' => 0,
    'shipping_amount' => '',
    'shipping_discount_tax_compensation_amount' => '',
    'shipping_incl_tax' => '',
    'shipping_tax_amount' => '',
    'state' => 0,
    'store_currency_code' => '',
    'store_id' => 0,
    'store_to_base_rate' => '',
    'store_to_order_rate' => '',
    'subtotal' => '',
    'subtotal_incl_tax' => '',
    'tax_amount' => '',
    'transaction_id' => '',
    'updated_at' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'entity' => [
    'adjustment' => '',
    'adjustment_negative' => '',
    'adjustment_positive' => '',
    'base_adjustment' => '',
    'base_adjustment_negative' => '',
    'base_adjustment_positive' => '',
    'base_currency_code' => '',
    'base_discount_amount' => '',
    'base_discount_tax_compensation_amount' => '',
    'base_grand_total' => '',
    'base_shipping_amount' => '',
    'base_shipping_discount_tax_compensation_amnt' => '',
    'base_shipping_incl_tax' => '',
    'base_shipping_tax_amount' => '',
    'base_subtotal' => '',
    'base_subtotal_incl_tax' => '',
    'base_tax_amount' => '',
    'base_to_global_rate' => '',
    'base_to_order_rate' => '',
    'billing_address_id' => 0,
    'comments' => [
        [
                'comment' => '',
                'created_at' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'is_customer_notified' => 0,
                'is_visible_on_front' => 0,
                'parent_id' => 0
        ]
    ],
    'created_at' => '',
    'creditmemo_status' => 0,
    'discount_amount' => '',
    'discount_description' => '',
    'discount_tax_compensation_amount' => '',
    'email_sent' => 0,
    'entity_id' => 0,
    'extension_attributes' => [
        'base_customer_balance_amount' => '',
        'base_gift_cards_amount' => '',
        'customer_balance_amount' => '',
        'gift_cards_amount' => '',
        'gw_base_price' => '',
        'gw_base_tax_amount' => '',
        'gw_card_base_price' => '',
        'gw_card_base_tax_amount' => '',
        'gw_card_price' => '',
        'gw_card_tax_amount' => '',
        'gw_items_base_price' => '',
        'gw_items_base_tax_amount' => '',
        'gw_items_price' => '',
        'gw_items_tax_amount' => '',
        'gw_price' => '',
        'gw_tax_amount' => ''
    ],
    'global_currency_code' => '',
    'grand_total' => '',
    'increment_id' => '',
    'invoice_id' => 0,
    'items' => [
        [
                'additional_data' => '',
                'base_cost' => '',
                'base_discount_amount' => '',
                'base_discount_tax_compensation_amount' => '',
                'base_price' => '',
                'base_price_incl_tax' => '',
                'base_row_total' => '',
                'base_row_total_incl_tax' => '',
                'base_tax_amount' => '',
                'base_weee_tax_applied_amount' => '',
                'base_weee_tax_applied_row_amnt' => '',
                'base_weee_tax_disposition' => '',
                'base_weee_tax_row_disposition' => '',
                'description' => '',
                'discount_amount' => '',
                'discount_tax_compensation_amount' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                'invoice_text_codes' => [
                                                                
                                ],
                                'tax_codes' => [
                                                                
                                ],
                                'vertex_tax_codes' => [
                                                                
                                ]
                ],
                'name' => '',
                'order_item_id' => 0,
                'parent_id' => 0,
                'price' => '',
                'price_incl_tax' => '',
                'product_id' => 0,
                'qty' => '',
                'row_total' => '',
                'row_total_incl_tax' => '',
                'sku' => '',
                'tax_amount' => '',
                'weee_tax_applied' => '',
                'weee_tax_applied_amount' => '',
                'weee_tax_applied_row_amount' => '',
                'weee_tax_disposition' => '',
                'weee_tax_row_disposition' => ''
        ]
    ],
    'order_currency_code' => '',
    'order_id' => 0,
    'shipping_address_id' => 0,
    'shipping_amount' => '',
    'shipping_discount_tax_compensation_amount' => '',
    'shipping_incl_tax' => '',
    'shipping_tax_amount' => '',
    'state' => 0,
    'store_currency_code' => '',
    'store_id' => 0,
    'store_to_base_rate' => '',
    'store_to_order_rate' => '',
    'subtotal' => '',
    'subtotal_incl_tax' => '',
    'tax_amount' => '',
    'transaction_id' => '',
    'updated_at' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/creditmemo');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/creditmemo' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "adjustment": "",
    "adjustment_negative": "",
    "adjustment_positive": "",
    "base_adjustment": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "creditmemo_status": 0,
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": ""
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "invoice_id": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "base_weee_tax_applied_amount": "",
        "base_weee_tax_applied_row_amnt": "",
        "base_weee_tax_disposition": "",
        "base_weee_tax_row_disposition": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": "",
        "weee_tax_applied": "",
        "weee_tax_applied_amount": "",
        "weee_tax_applied_row_amount": "",
        "weee_tax_disposition": "",
        "weee_tax_row_disposition": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "transaction_id": "",
    "updated_at": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/creditmemo' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "adjustment": "",
    "adjustment_negative": "",
    "adjustment_positive": "",
    "base_adjustment": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "creditmemo_status": 0,
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": ""
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "invoice_id": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "base_weee_tax_applied_amount": "",
        "base_weee_tax_applied_row_amnt": "",
        "base_weee_tax_disposition": "",
        "base_weee_tax_row_disposition": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": "",
        "weee_tax_applied": "",
        "weee_tax_applied_amount": "",
        "weee_tax_applied_row_amount": "",
        "weee_tax_disposition": "",
        "weee_tax_row_disposition": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "transaction_id": "",
    "updated_at": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"entity\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/creditmemo", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/creditmemo"

payload = { "entity": {
        "adjustment": "",
        "adjustment_negative": "",
        "adjustment_positive": "",
        "base_adjustment": "",
        "base_adjustment_negative": "",
        "base_adjustment_positive": "",
        "base_currency_code": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_grand_total": "",
        "base_shipping_amount": "",
        "base_shipping_discount_tax_compensation_amnt": "",
        "base_shipping_incl_tax": "",
        "base_shipping_tax_amount": "",
        "base_subtotal": "",
        "base_subtotal_incl_tax": "",
        "base_tax_amount": "",
        "base_to_global_rate": "",
        "base_to_order_rate": "",
        "billing_address_id": 0,
        "comments": [
            {
                "comment": "",
                "created_at": "",
                "entity_id": 0,
                "extension_attributes": {},
                "is_customer_notified": 0,
                "is_visible_on_front": 0,
                "parent_id": 0
            }
        ],
        "created_at": "",
        "creditmemo_status": 0,
        "discount_amount": "",
        "discount_description": "",
        "discount_tax_compensation_amount": "",
        "email_sent": 0,
        "entity_id": 0,
        "extension_attributes": {
            "base_customer_balance_amount": "",
            "base_gift_cards_amount": "",
            "customer_balance_amount": "",
            "gift_cards_amount": "",
            "gw_base_price": "",
            "gw_base_tax_amount": "",
            "gw_card_base_price": "",
            "gw_card_base_tax_amount": "",
            "gw_card_price": "",
            "gw_card_tax_amount": "",
            "gw_items_base_price": "",
            "gw_items_base_tax_amount": "",
            "gw_items_price": "",
            "gw_items_tax_amount": "",
            "gw_price": "",
            "gw_tax_amount": ""
        },
        "global_currency_code": "",
        "grand_total": "",
        "increment_id": "",
        "invoice_id": 0,
        "items": [
            {
                "additional_data": "",
                "base_cost": "",
                "base_discount_amount": "",
                "base_discount_tax_compensation_amount": "",
                "base_price": "",
                "base_price_incl_tax": "",
                "base_row_total": "",
                "base_row_total_incl_tax": "",
                "base_tax_amount": "",
                "base_weee_tax_applied_amount": "",
                "base_weee_tax_applied_row_amnt": "",
                "base_weee_tax_disposition": "",
                "base_weee_tax_row_disposition": "",
                "description": "",
                "discount_amount": "",
                "discount_tax_compensation_amount": "",
                "entity_id": 0,
                "extension_attributes": {
                    "invoice_text_codes": [],
                    "tax_codes": [],
                    "vertex_tax_codes": []
                },
                "name": "",
                "order_item_id": 0,
                "parent_id": 0,
                "price": "",
                "price_incl_tax": "",
                "product_id": 0,
                "qty": "",
                "row_total": "",
                "row_total_incl_tax": "",
                "sku": "",
                "tax_amount": "",
                "weee_tax_applied": "",
                "weee_tax_applied_amount": "",
                "weee_tax_applied_row_amount": "",
                "weee_tax_disposition": "",
                "weee_tax_row_disposition": ""
            }
        ],
        "order_currency_code": "",
        "order_id": 0,
        "shipping_address_id": 0,
        "shipping_amount": "",
        "shipping_discount_tax_compensation_amount": "",
        "shipping_incl_tax": "",
        "shipping_tax_amount": "",
        "state": 0,
        "store_currency_code": "",
        "store_id": 0,
        "store_to_base_rate": "",
        "store_to_order_rate": "",
        "subtotal": "",
        "subtotal_incl_tax": "",
        "tax_amount": "",
        "transaction_id": "",
        "updated_at": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/creditmemo"

payload <- "{\n  \"entity\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/creditmemo")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"entity\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\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/V1/creditmemo') do |req|
  req.body = "{\n  \"entity\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/creditmemo";

    let payload = json!({"entity": json!({
            "adjustment": "",
            "adjustment_negative": "",
            "adjustment_positive": "",
            "base_adjustment": "",
            "base_adjustment_negative": "",
            "base_adjustment_positive": "",
            "base_currency_code": "",
            "base_discount_amount": "",
            "base_discount_tax_compensation_amount": "",
            "base_grand_total": "",
            "base_shipping_amount": "",
            "base_shipping_discount_tax_compensation_amnt": "",
            "base_shipping_incl_tax": "",
            "base_shipping_tax_amount": "",
            "base_subtotal": "",
            "base_subtotal_incl_tax": "",
            "base_tax_amount": "",
            "base_to_global_rate": "",
            "base_to_order_rate": "",
            "billing_address_id": 0,
            "comments": (
                json!({
                    "comment": "",
                    "created_at": "",
                    "entity_id": 0,
                    "extension_attributes": json!({}),
                    "is_customer_notified": 0,
                    "is_visible_on_front": 0,
                    "parent_id": 0
                })
            ),
            "created_at": "",
            "creditmemo_status": 0,
            "discount_amount": "",
            "discount_description": "",
            "discount_tax_compensation_amount": "",
            "email_sent": 0,
            "entity_id": 0,
            "extension_attributes": json!({
                "base_customer_balance_amount": "",
                "base_gift_cards_amount": "",
                "customer_balance_amount": "",
                "gift_cards_amount": "",
                "gw_base_price": "",
                "gw_base_tax_amount": "",
                "gw_card_base_price": "",
                "gw_card_base_tax_amount": "",
                "gw_card_price": "",
                "gw_card_tax_amount": "",
                "gw_items_base_price": "",
                "gw_items_base_tax_amount": "",
                "gw_items_price": "",
                "gw_items_tax_amount": "",
                "gw_price": "",
                "gw_tax_amount": ""
            }),
            "global_currency_code": "",
            "grand_total": "",
            "increment_id": "",
            "invoice_id": 0,
            "items": (
                json!({
                    "additional_data": "",
                    "base_cost": "",
                    "base_discount_amount": "",
                    "base_discount_tax_compensation_amount": "",
                    "base_price": "",
                    "base_price_incl_tax": "",
                    "base_row_total": "",
                    "base_row_total_incl_tax": "",
                    "base_tax_amount": "",
                    "base_weee_tax_applied_amount": "",
                    "base_weee_tax_applied_row_amnt": "",
                    "base_weee_tax_disposition": "",
                    "base_weee_tax_row_disposition": "",
                    "description": "",
                    "discount_amount": "",
                    "discount_tax_compensation_amount": "",
                    "entity_id": 0,
                    "extension_attributes": json!({
                        "invoice_text_codes": (),
                        "tax_codes": (),
                        "vertex_tax_codes": ()
                    }),
                    "name": "",
                    "order_item_id": 0,
                    "parent_id": 0,
                    "price": "",
                    "price_incl_tax": "",
                    "product_id": 0,
                    "qty": "",
                    "row_total": "",
                    "row_total_incl_tax": "",
                    "sku": "",
                    "tax_amount": "",
                    "weee_tax_applied": "",
                    "weee_tax_applied_amount": "",
                    "weee_tax_applied_row_amount": "",
                    "weee_tax_disposition": "",
                    "weee_tax_row_disposition": ""
                })
            ),
            "order_currency_code": "",
            "order_id": 0,
            "shipping_address_id": 0,
            "shipping_amount": "",
            "shipping_discount_tax_compensation_amount": "",
            "shipping_incl_tax": "",
            "shipping_tax_amount": "",
            "state": 0,
            "store_currency_code": "",
            "store_id": 0,
            "store_to_base_rate": "",
            "store_to_order_rate": "",
            "subtotal": "",
            "subtotal_incl_tax": "",
            "tax_amount": "",
            "transaction_id": "",
            "updated_at": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/creditmemo \
  --header 'content-type: application/json' \
  --data '{
  "entity": {
    "adjustment": "",
    "adjustment_negative": "",
    "adjustment_positive": "",
    "base_adjustment": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "creditmemo_status": 0,
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": ""
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "invoice_id": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "base_weee_tax_applied_amount": "",
        "base_weee_tax_applied_row_amnt": "",
        "base_weee_tax_disposition": "",
        "base_weee_tax_row_disposition": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": "",
        "weee_tax_applied": "",
        "weee_tax_applied_amount": "",
        "weee_tax_applied_row_amount": "",
        "weee_tax_disposition": "",
        "weee_tax_row_disposition": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "transaction_id": "",
    "updated_at": ""
  }
}'
echo '{
  "entity": {
    "adjustment": "",
    "adjustment_negative": "",
    "adjustment_positive": "",
    "base_adjustment": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "creditmemo_status": 0,
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": ""
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "invoice_id": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "base_weee_tax_applied_amount": "",
        "base_weee_tax_applied_row_amnt": "",
        "base_weee_tax_disposition": "",
        "base_weee_tax_row_disposition": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": "",
        "weee_tax_applied": "",
        "weee_tax_applied_amount": "",
        "weee_tax_applied_row_amount": "",
        "weee_tax_disposition": "",
        "weee_tax_row_disposition": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "transaction_id": "",
    "updated_at": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/creditmemo \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "entity": {\n    "adjustment": "",\n    "adjustment_negative": "",\n    "adjustment_positive": "",\n    "base_adjustment": "",\n    "base_adjustment_negative": "",\n    "base_adjustment_positive": "",\n    "base_currency_code": "",\n    "base_discount_amount": "",\n    "base_discount_tax_compensation_amount": "",\n    "base_grand_total": "",\n    "base_shipping_amount": "",\n    "base_shipping_discount_tax_compensation_amnt": "",\n    "base_shipping_incl_tax": "",\n    "base_shipping_tax_amount": "",\n    "base_subtotal": "",\n    "base_subtotal_incl_tax": "",\n    "base_tax_amount": "",\n    "base_to_global_rate": "",\n    "base_to_order_rate": "",\n    "billing_address_id": 0,\n    "comments": [\n      {\n        "comment": "",\n        "created_at": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "is_customer_notified": 0,\n        "is_visible_on_front": 0,\n        "parent_id": 0\n      }\n    ],\n    "created_at": "",\n    "creditmemo_status": 0,\n    "discount_amount": "",\n    "discount_description": "",\n    "discount_tax_compensation_amount": "",\n    "email_sent": 0,\n    "entity_id": 0,\n    "extension_attributes": {\n      "base_customer_balance_amount": "",\n      "base_gift_cards_amount": "",\n      "customer_balance_amount": "",\n      "gift_cards_amount": "",\n      "gw_base_price": "",\n      "gw_base_tax_amount": "",\n      "gw_card_base_price": "",\n      "gw_card_base_tax_amount": "",\n      "gw_card_price": "",\n      "gw_card_tax_amount": "",\n      "gw_items_base_price": "",\n      "gw_items_base_tax_amount": "",\n      "gw_items_price": "",\n      "gw_items_tax_amount": "",\n      "gw_price": "",\n      "gw_tax_amount": ""\n    },\n    "global_currency_code": "",\n    "grand_total": "",\n    "increment_id": "",\n    "invoice_id": 0,\n    "items": [\n      {\n        "additional_data": "",\n        "base_cost": "",\n        "base_discount_amount": "",\n        "base_discount_tax_compensation_amount": "",\n        "base_price": "",\n        "base_price_incl_tax": "",\n        "base_row_total": "",\n        "base_row_total_incl_tax": "",\n        "base_tax_amount": "",\n        "base_weee_tax_applied_amount": "",\n        "base_weee_tax_applied_row_amnt": "",\n        "base_weee_tax_disposition": "",\n        "base_weee_tax_row_disposition": "",\n        "description": "",\n        "discount_amount": "",\n        "discount_tax_compensation_amount": "",\n        "entity_id": 0,\n        "extension_attributes": {\n          "invoice_text_codes": [],\n          "tax_codes": [],\n          "vertex_tax_codes": []\n        },\n        "name": "",\n        "order_item_id": 0,\n        "parent_id": 0,\n        "price": "",\n        "price_incl_tax": "",\n        "product_id": 0,\n        "qty": "",\n        "row_total": "",\n        "row_total_incl_tax": "",\n        "sku": "",\n        "tax_amount": "",\n        "weee_tax_applied": "",\n        "weee_tax_applied_amount": "",\n        "weee_tax_applied_row_amount": "",\n        "weee_tax_disposition": "",\n        "weee_tax_row_disposition": ""\n      }\n    ],\n    "order_currency_code": "",\n    "order_id": 0,\n    "shipping_address_id": 0,\n    "shipping_amount": "",\n    "shipping_discount_tax_compensation_amount": "",\n    "shipping_incl_tax": "",\n    "shipping_tax_amount": "",\n    "state": 0,\n    "store_currency_code": "",\n    "store_id": 0,\n    "store_to_base_rate": "",\n    "store_to_order_rate": "",\n    "subtotal": "",\n    "subtotal_incl_tax": "",\n    "tax_amount": "",\n    "transaction_id": "",\n    "updated_at": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/creditmemo
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["entity": [
    "adjustment": "",
    "adjustment_negative": "",
    "adjustment_positive": "",
    "base_adjustment": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "billing_address_id": 0,
    "comments": [
      [
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": [],
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      ]
    ],
    "created_at": "",
    "creditmemo_status": 0,
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": [
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": ""
    ],
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "invoice_id": 0,
    "items": [
      [
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "base_weee_tax_applied_amount": "",
        "base_weee_tax_applied_row_amnt": "",
        "base_weee_tax_disposition": "",
        "base_weee_tax_row_disposition": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": [
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        ],
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": "",
        "weee_tax_applied": "",
        "weee_tax_applied_amount": "",
        "weee_tax_applied_row_amount": "",
        "weee_tax_disposition": "",
        "weee_tax_row_disposition": ""
      ]
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "transaction_id": "",
    "updated_at": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/creditmemo")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT creditmemo-{id} (PUT)
{{baseUrl}}/V1/creditmemo/:id
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/creditmemo/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/creditmemo/:id")
require "http/client"

url = "{{baseUrl}}/V1/creditmemo/:id"

response = HTTP::Client.put url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/V1/creditmemo/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/creditmemo/:id");
var request = new RestRequest("", Method.Put);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/creditmemo/:id"

	req, _ := http.NewRequest("PUT", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/creditmemo/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/creditmemo/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/creditmemo/:id"))
    .method("PUT", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/creditmemo/:id")
  .put(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/creditmemo/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/creditmemo/:id');

xhr.send(data);
import axios from 'axios';

const options = {method: 'PUT', url: '{{baseUrl}}/V1/creditmemo/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/creditmemo/:id';
const options = {method: 'PUT'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/creditmemo/:id',
  method: 'PUT',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/creditmemo/:id")
  .put(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/creditmemo/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'PUT', url: '{{baseUrl}}/V1/creditmemo/:id'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/creditmemo/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'PUT', url: '{{baseUrl}}/V1/creditmemo/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/creditmemo/:id';
const options = {method: 'PUT'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/creditmemo/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/creditmemo/:id" in

Client.call `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/creditmemo/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/creditmemo/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/creditmemo/:id');
$request->setMethod(HTTP_METH_PUT);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/creditmemo/:id');
$request->setRequestMethod('PUT');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/creditmemo/:id' -Method PUT 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/creditmemo/:id' -Method PUT 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("PUT", "/baseUrl/V1/creditmemo/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/creditmemo/:id"

response = requests.put(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/creditmemo/:id"

response <- VERB("PUT", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/creditmemo/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/V1/creditmemo/:id') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/creditmemo/:id";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/creditmemo/:id
http PUT {{baseUrl}}/V1/creditmemo/:id
wget --quiet \
  --method PUT \
  --output-document \
  - {{baseUrl}}/V1/creditmemo/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/creditmemo/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET creditmemo-{id}
{{baseUrl}}/V1/creditmemo/:id
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/creditmemo/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/creditmemo/:id")
require "http/client"

url = "{{baseUrl}}/V1/creditmemo/:id"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/creditmemo/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/creditmemo/:id");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/creditmemo/:id"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/creditmemo/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/creditmemo/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/creditmemo/:id"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/creditmemo/:id")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/creditmemo/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/creditmemo/:id');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/creditmemo/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/creditmemo/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/creditmemo/:id',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/creditmemo/:id")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/creditmemo/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/creditmemo/:id'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/creditmemo/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/creditmemo/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/creditmemo/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/creditmemo/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/creditmemo/:id" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/creditmemo/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/creditmemo/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/creditmemo/:id');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/creditmemo/:id');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/creditmemo/:id' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/creditmemo/:id' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/creditmemo/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/creditmemo/:id"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/creditmemo/:id"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/creditmemo/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/creditmemo/:id') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/creditmemo/:id";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/creditmemo/:id
http GET {{baseUrl}}/V1/creditmemo/:id
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/creditmemo/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/creditmemo/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST creditmemo-{id}-comments (POST)
{{baseUrl}}/V1/creditmemo/:id/comments
QUERY PARAMS

id
BODY json

{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/creditmemo/:id/comments");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/creditmemo/:id/comments" {:content-type :json
                                                                       :form-params {:entity {:comment ""
                                                                                              :created_at ""
                                                                                              :entity_id 0
                                                                                              :extension_attributes {}
                                                                                              :is_customer_notified 0
                                                                                              :is_visible_on_front 0
                                                                                              :parent_id 0}}})
require "http/client"

url = "{{baseUrl}}/V1/creditmemo/:id/comments"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\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}}/V1/creditmemo/:id/comments"),
    Content = new StringContent("{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\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}}/V1/creditmemo/:id/comments");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/creditmemo/:id/comments"

	payload := strings.NewReader("{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/creditmemo/:id/comments HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 194

{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/creditmemo/:id/comments")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/creditmemo/:id/comments"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\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  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/creditmemo/:id/comments")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/creditmemo/:id/comments")
  .header("content-type", "application/json")
  .body("{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  entity: {
    comment: '',
    created_at: '',
    entity_id: 0,
    extension_attributes: {},
    is_customer_notified: 0,
    is_visible_on_front: 0,
    parent_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}}/V1/creditmemo/:id/comments');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/creditmemo/:id/comments',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      comment: '',
      created_at: '',
      entity_id: 0,
      extension_attributes: {},
      is_customer_notified: 0,
      is_visible_on_front: 0,
      parent_id: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/creditmemo/:id/comments';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"comment":"","created_at":"","entity_id":0,"extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_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}}/V1/creditmemo/:id/comments',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "entity": {\n    "comment": "",\n    "created_at": "",\n    "entity_id": 0,\n    "extension_attributes": {},\n    "is_customer_notified": 0,\n    "is_visible_on_front": 0,\n    "parent_id": 0\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  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/creditmemo/:id/comments")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/creditmemo/:id/comments',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  entity: {
    comment: '',
    created_at: '',
    entity_id: 0,
    extension_attributes: {},
    is_customer_notified: 0,
    is_visible_on_front: 0,
    parent_id: 0
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/creditmemo/:id/comments',
  headers: {'content-type': 'application/json'},
  body: {
    entity: {
      comment: '',
      created_at: '',
      entity_id: 0,
      extension_attributes: {},
      is_customer_notified: 0,
      is_visible_on_front: 0,
      parent_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}}/V1/creditmemo/:id/comments');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  entity: {
    comment: '',
    created_at: '',
    entity_id: 0,
    extension_attributes: {},
    is_customer_notified: 0,
    is_visible_on_front: 0,
    parent_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}}/V1/creditmemo/:id/comments',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      comment: '',
      created_at: '',
      entity_id: 0,
      extension_attributes: {},
      is_customer_notified: 0,
      is_visible_on_front: 0,
      parent_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}}/V1/creditmemo/:id/comments';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"comment":"","created_at":"","entity_id":0,"extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_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 = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"entity": @{ @"comment": @"", @"created_at": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"is_customer_notified": @0, @"is_visible_on_front": @0, @"parent_id": @0 } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/creditmemo/:id/comments"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/creditmemo/:id/comments" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/creditmemo/:id/comments",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'entity' => [
        'comment' => '',
        'created_at' => '',
        'entity_id' => 0,
        'extension_attributes' => [
                
        ],
        'is_customer_notified' => 0,
        'is_visible_on_front' => 0,
        'parent_id' => 0
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/creditmemo/:id/comments', [
  'body' => '{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/creditmemo/:id/comments');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'entity' => [
    'comment' => '',
    'created_at' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'is_customer_notified' => 0,
    'is_visible_on_front' => 0,
    'parent_id' => 0
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'entity' => [
    'comment' => '',
    'created_at' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'is_customer_notified' => 0,
    'is_visible_on_front' => 0,
    'parent_id' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/creditmemo/:id/comments');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/creditmemo/:id/comments' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/creditmemo/:id/comments' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/creditmemo/:id/comments", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/creditmemo/:id/comments"

payload = { "entity": {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/creditmemo/:id/comments"

payload <- "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/creditmemo/:id/comments")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\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/V1/creditmemo/:id/comments') do |req|
  req.body = "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/creditmemo/:id/comments";

    let payload = json!({"entity": json!({
            "comment": "",
            "created_at": "",
            "entity_id": 0,
            "extension_attributes": json!({}),
            "is_customer_notified": 0,
            "is_visible_on_front": 0,
            "parent_id": 0
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/creditmemo/:id/comments \
  --header 'content-type: application/json' \
  --data '{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}'
echo '{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}' |  \
  http POST {{baseUrl}}/V1/creditmemo/:id/comments \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "entity": {\n    "comment": "",\n    "created_at": "",\n    "entity_id": 0,\n    "extension_attributes": {},\n    "is_customer_notified": 0,\n    "is_visible_on_front": 0,\n    "parent_id": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/creditmemo/:id/comments
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["entity": [
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": [],
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/creditmemo/:id/comments")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET creditmemo-{id}-comments
{{baseUrl}}/V1/creditmemo/:id/comments
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/creditmemo/:id/comments");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/creditmemo/:id/comments")
require "http/client"

url = "{{baseUrl}}/V1/creditmemo/:id/comments"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/creditmemo/:id/comments"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/creditmemo/:id/comments");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/creditmemo/:id/comments"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/creditmemo/:id/comments HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/creditmemo/:id/comments")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/creditmemo/:id/comments"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/creditmemo/:id/comments")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/creditmemo/:id/comments")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/creditmemo/:id/comments');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/creditmemo/:id/comments'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/creditmemo/:id/comments';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/creditmemo/:id/comments',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/creditmemo/:id/comments")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/creditmemo/:id/comments',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/creditmemo/:id/comments'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/creditmemo/:id/comments');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/creditmemo/:id/comments'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/creditmemo/:id/comments';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/creditmemo/:id/comments"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/creditmemo/:id/comments" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/creditmemo/:id/comments",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/creditmemo/:id/comments');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/creditmemo/:id/comments');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/creditmemo/:id/comments');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/creditmemo/:id/comments' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/creditmemo/:id/comments' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/creditmemo/:id/comments")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/creditmemo/:id/comments"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/creditmemo/:id/comments"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/creditmemo/:id/comments")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/creditmemo/:id/comments') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/creditmemo/:id/comments";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/creditmemo/:id/comments
http GET {{baseUrl}}/V1/creditmemo/:id/comments
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/creditmemo/:id/comments
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/creditmemo/:id/comments")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST creditmemo-{id}-emails
{{baseUrl}}/V1/creditmemo/:id/emails
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/creditmemo/:id/emails");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/creditmemo/:id/emails")
require "http/client"

url = "{{baseUrl}}/V1/creditmemo/:id/emails"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/creditmemo/:id/emails"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/creditmemo/:id/emails");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/creditmemo/:id/emails"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/creditmemo/:id/emails HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/creditmemo/:id/emails")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/creditmemo/:id/emails"))
    .method("POST", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/creditmemo/:id/emails")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/creditmemo/:id/emails")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/creditmemo/:id/emails');

xhr.send(data);
import axios from 'axios';

const options = {method: 'POST', url: '{{baseUrl}}/V1/creditmemo/:id/emails'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/creditmemo/:id/emails';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/creditmemo/:id/emails',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/creditmemo/:id/emails")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/creditmemo/:id/emails',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'POST', url: '{{baseUrl}}/V1/creditmemo/:id/emails'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/creditmemo/:id/emails');

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}}/V1/creditmemo/:id/emails'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/creditmemo/:id/emails';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/creditmemo/:id/emails"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/creditmemo/:id/emails" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/creditmemo/:id/emails",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/creditmemo/:id/emails');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/creditmemo/:id/emails');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/creditmemo/:id/emails');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/creditmemo/:id/emails' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/creditmemo/:id/emails' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/V1/creditmemo/:id/emails")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/creditmemo/:id/emails"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/creditmemo/:id/emails"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/creditmemo/:id/emails")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/V1/creditmemo/:id/emails') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/creditmemo/:id/emails";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/creditmemo/:id/emails
http POST {{baseUrl}}/V1/creditmemo/:id/emails
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/V1/creditmemo/:id/emails
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/creditmemo/:id/emails")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST creditmemo-refund
{{baseUrl}}/V1/creditmemo/refund
BODY json

{
  "creditmemo": {
    "adjustment": "",
    "adjustment_negative": "",
    "adjustment_positive": "",
    "base_adjustment": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "creditmemo_status": 0,
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": ""
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "invoice_id": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "base_weee_tax_applied_amount": "",
        "base_weee_tax_applied_row_amnt": "",
        "base_weee_tax_disposition": "",
        "base_weee_tax_row_disposition": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": "",
        "weee_tax_applied": "",
        "weee_tax_applied_amount": "",
        "weee_tax_applied_row_amount": "",
        "weee_tax_disposition": "",
        "weee_tax_row_disposition": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "transaction_id": "",
    "updated_at": ""
  },
  "offlineRequested": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/creditmemo/refund");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"creditmemo\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  },\n  \"offlineRequested\": false\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/creditmemo/refund" {:content-type :json
                                                                 :form-params {:creditmemo {:adjustment ""
                                                                                            :adjustment_negative ""
                                                                                            :adjustment_positive ""
                                                                                            :base_adjustment ""
                                                                                            :base_adjustment_negative ""
                                                                                            :base_adjustment_positive ""
                                                                                            :base_currency_code ""
                                                                                            :base_discount_amount ""
                                                                                            :base_discount_tax_compensation_amount ""
                                                                                            :base_grand_total ""
                                                                                            :base_shipping_amount ""
                                                                                            :base_shipping_discount_tax_compensation_amnt ""
                                                                                            :base_shipping_incl_tax ""
                                                                                            :base_shipping_tax_amount ""
                                                                                            :base_subtotal ""
                                                                                            :base_subtotal_incl_tax ""
                                                                                            :base_tax_amount ""
                                                                                            :base_to_global_rate ""
                                                                                            :base_to_order_rate ""
                                                                                            :billing_address_id 0
                                                                                            :comments [{:comment ""
                                                                                                        :created_at ""
                                                                                                        :entity_id 0
                                                                                                        :extension_attributes {}
                                                                                                        :is_customer_notified 0
                                                                                                        :is_visible_on_front 0
                                                                                                        :parent_id 0}]
                                                                                            :created_at ""
                                                                                            :creditmemo_status 0
                                                                                            :discount_amount ""
                                                                                            :discount_description ""
                                                                                            :discount_tax_compensation_amount ""
                                                                                            :email_sent 0
                                                                                            :entity_id 0
                                                                                            :extension_attributes {:base_customer_balance_amount ""
                                                                                                                   :base_gift_cards_amount ""
                                                                                                                   :customer_balance_amount ""
                                                                                                                   :gift_cards_amount ""
                                                                                                                   :gw_base_price ""
                                                                                                                   :gw_base_tax_amount ""
                                                                                                                   :gw_card_base_price ""
                                                                                                                   :gw_card_base_tax_amount ""
                                                                                                                   :gw_card_price ""
                                                                                                                   :gw_card_tax_amount ""
                                                                                                                   :gw_items_base_price ""
                                                                                                                   :gw_items_base_tax_amount ""
                                                                                                                   :gw_items_price ""
                                                                                                                   :gw_items_tax_amount ""
                                                                                                                   :gw_price ""
                                                                                                                   :gw_tax_amount ""}
                                                                                            :global_currency_code ""
                                                                                            :grand_total ""
                                                                                            :increment_id ""
                                                                                            :invoice_id 0
                                                                                            :items [{:additional_data ""
                                                                                                     :base_cost ""
                                                                                                     :base_discount_amount ""
                                                                                                     :base_discount_tax_compensation_amount ""
                                                                                                     :base_price ""
                                                                                                     :base_price_incl_tax ""
                                                                                                     :base_row_total ""
                                                                                                     :base_row_total_incl_tax ""
                                                                                                     :base_tax_amount ""
                                                                                                     :base_weee_tax_applied_amount ""
                                                                                                     :base_weee_tax_applied_row_amnt ""
                                                                                                     :base_weee_tax_disposition ""
                                                                                                     :base_weee_tax_row_disposition ""
                                                                                                     :description ""
                                                                                                     :discount_amount ""
                                                                                                     :discount_tax_compensation_amount ""
                                                                                                     :entity_id 0
                                                                                                     :extension_attributes {:invoice_text_codes []
                                                                                                                            :tax_codes []
                                                                                                                            :vertex_tax_codes []}
                                                                                                     :name ""
                                                                                                     :order_item_id 0
                                                                                                     :parent_id 0
                                                                                                     :price ""
                                                                                                     :price_incl_tax ""
                                                                                                     :product_id 0
                                                                                                     :qty ""
                                                                                                     :row_total ""
                                                                                                     :row_total_incl_tax ""
                                                                                                     :sku ""
                                                                                                     :tax_amount ""
                                                                                                     :weee_tax_applied ""
                                                                                                     :weee_tax_applied_amount ""
                                                                                                     :weee_tax_applied_row_amount ""
                                                                                                     :weee_tax_disposition ""
                                                                                                     :weee_tax_row_disposition ""}]
                                                                                            :order_currency_code ""
                                                                                            :order_id 0
                                                                                            :shipping_address_id 0
                                                                                            :shipping_amount ""
                                                                                            :shipping_discount_tax_compensation_amount ""
                                                                                            :shipping_incl_tax ""
                                                                                            :shipping_tax_amount ""
                                                                                            :state 0
                                                                                            :store_currency_code ""
                                                                                            :store_id 0
                                                                                            :store_to_base_rate ""
                                                                                            :store_to_order_rate ""
                                                                                            :subtotal ""
                                                                                            :subtotal_incl_tax ""
                                                                                            :tax_amount ""
                                                                                            :transaction_id ""
                                                                                            :updated_at ""}
                                                                               :offlineRequested false}})
require "http/client"

url = "{{baseUrl}}/V1/creditmemo/refund"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"creditmemo\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  },\n  \"offlineRequested\": 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}}/V1/creditmemo/refund"),
    Content = new StringContent("{\n  \"creditmemo\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  },\n  \"offlineRequested\": 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}}/V1/creditmemo/refund");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"creditmemo\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  },\n  \"offlineRequested\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/creditmemo/refund"

	payload := strings.NewReader("{\n  \"creditmemo\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  },\n  \"offlineRequested\": false\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/creditmemo/refund HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 3512

{
  "creditmemo": {
    "adjustment": "",
    "adjustment_negative": "",
    "adjustment_positive": "",
    "base_adjustment": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "creditmemo_status": 0,
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": ""
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "invoice_id": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "base_weee_tax_applied_amount": "",
        "base_weee_tax_applied_row_amnt": "",
        "base_weee_tax_disposition": "",
        "base_weee_tax_row_disposition": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": "",
        "weee_tax_applied": "",
        "weee_tax_applied_amount": "",
        "weee_tax_applied_row_amount": "",
        "weee_tax_disposition": "",
        "weee_tax_row_disposition": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "transaction_id": "",
    "updated_at": ""
  },
  "offlineRequested": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/creditmemo/refund")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"creditmemo\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  },\n  \"offlineRequested\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/creditmemo/refund"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"creditmemo\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  },\n  \"offlineRequested\": 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  \"creditmemo\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  },\n  \"offlineRequested\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/creditmemo/refund")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/creditmemo/refund")
  .header("content-type", "application/json")
  .body("{\n  \"creditmemo\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  },\n  \"offlineRequested\": false\n}")
  .asString();
const data = JSON.stringify({
  creditmemo: {
    adjustment: '',
    adjustment_negative: '',
    adjustment_positive: '',
    base_adjustment: '',
    base_adjustment_negative: '',
    base_adjustment_positive: '',
    base_currency_code: '',
    base_discount_amount: '',
    base_discount_tax_compensation_amount: '',
    base_grand_total: '',
    base_shipping_amount: '',
    base_shipping_discount_tax_compensation_amnt: '',
    base_shipping_incl_tax: '',
    base_shipping_tax_amount: '',
    base_subtotal: '',
    base_subtotal_incl_tax: '',
    base_tax_amount: '',
    base_to_global_rate: '',
    base_to_order_rate: '',
    billing_address_id: 0,
    comments: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0
      }
    ],
    created_at: '',
    creditmemo_status: 0,
    discount_amount: '',
    discount_description: '',
    discount_tax_compensation_amount: '',
    email_sent: 0,
    entity_id: 0,
    extension_attributes: {
      base_customer_balance_amount: '',
      base_gift_cards_amount: '',
      customer_balance_amount: '',
      gift_cards_amount: '',
      gw_base_price: '',
      gw_base_tax_amount: '',
      gw_card_base_price: '',
      gw_card_base_tax_amount: '',
      gw_card_price: '',
      gw_card_tax_amount: '',
      gw_items_base_price: '',
      gw_items_base_tax_amount: '',
      gw_items_price: '',
      gw_items_tax_amount: '',
      gw_price: '',
      gw_tax_amount: ''
    },
    global_currency_code: '',
    grand_total: '',
    increment_id: '',
    invoice_id: 0,
    items: [
      {
        additional_data: '',
        base_cost: '',
        base_discount_amount: '',
        base_discount_tax_compensation_amount: '',
        base_price: '',
        base_price_incl_tax: '',
        base_row_total: '',
        base_row_total_incl_tax: '',
        base_tax_amount: '',
        base_weee_tax_applied_amount: '',
        base_weee_tax_applied_row_amnt: '',
        base_weee_tax_disposition: '',
        base_weee_tax_row_disposition: '',
        description: '',
        discount_amount: '',
        discount_tax_compensation_amount: '',
        entity_id: 0,
        extension_attributes: {
          invoice_text_codes: [],
          tax_codes: [],
          vertex_tax_codes: []
        },
        name: '',
        order_item_id: 0,
        parent_id: 0,
        price: '',
        price_incl_tax: '',
        product_id: 0,
        qty: '',
        row_total: '',
        row_total_incl_tax: '',
        sku: '',
        tax_amount: '',
        weee_tax_applied: '',
        weee_tax_applied_amount: '',
        weee_tax_applied_row_amount: '',
        weee_tax_disposition: '',
        weee_tax_row_disposition: ''
      }
    ],
    order_currency_code: '',
    order_id: 0,
    shipping_address_id: 0,
    shipping_amount: '',
    shipping_discount_tax_compensation_amount: '',
    shipping_incl_tax: '',
    shipping_tax_amount: '',
    state: 0,
    store_currency_code: '',
    store_id: 0,
    store_to_base_rate: '',
    store_to_order_rate: '',
    subtotal: '',
    subtotal_incl_tax: '',
    tax_amount: '',
    transaction_id: '',
    updated_at: ''
  },
  offlineRequested: 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}}/V1/creditmemo/refund');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/creditmemo/refund',
  headers: {'content-type': 'application/json'},
  data: {
    creditmemo: {
      adjustment: '',
      adjustment_negative: '',
      adjustment_positive: '',
      base_adjustment: '',
      base_adjustment_negative: '',
      base_adjustment_positive: '',
      base_currency_code: '',
      base_discount_amount: '',
      base_discount_tax_compensation_amount: '',
      base_grand_total: '',
      base_shipping_amount: '',
      base_shipping_discount_tax_compensation_amnt: '',
      base_shipping_incl_tax: '',
      base_shipping_tax_amount: '',
      base_subtotal: '',
      base_subtotal_incl_tax: '',
      base_tax_amount: '',
      base_to_global_rate: '',
      base_to_order_rate: '',
      billing_address_id: 0,
      comments: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0
        }
      ],
      created_at: '',
      creditmemo_status: 0,
      discount_amount: '',
      discount_description: '',
      discount_tax_compensation_amount: '',
      email_sent: 0,
      entity_id: 0,
      extension_attributes: {
        base_customer_balance_amount: '',
        base_gift_cards_amount: '',
        customer_balance_amount: '',
        gift_cards_amount: '',
        gw_base_price: '',
        gw_base_tax_amount: '',
        gw_card_base_price: '',
        gw_card_base_tax_amount: '',
        gw_card_price: '',
        gw_card_tax_amount: '',
        gw_items_base_price: '',
        gw_items_base_tax_amount: '',
        gw_items_price: '',
        gw_items_tax_amount: '',
        gw_price: '',
        gw_tax_amount: ''
      },
      global_currency_code: '',
      grand_total: '',
      increment_id: '',
      invoice_id: 0,
      items: [
        {
          additional_data: '',
          base_cost: '',
          base_discount_amount: '',
          base_discount_tax_compensation_amount: '',
          base_price: '',
          base_price_incl_tax: '',
          base_row_total: '',
          base_row_total_incl_tax: '',
          base_tax_amount: '',
          base_weee_tax_applied_amount: '',
          base_weee_tax_applied_row_amnt: '',
          base_weee_tax_disposition: '',
          base_weee_tax_row_disposition: '',
          description: '',
          discount_amount: '',
          discount_tax_compensation_amount: '',
          entity_id: 0,
          extension_attributes: {invoice_text_codes: [], tax_codes: [], vertex_tax_codes: []},
          name: '',
          order_item_id: 0,
          parent_id: 0,
          price: '',
          price_incl_tax: '',
          product_id: 0,
          qty: '',
          row_total: '',
          row_total_incl_tax: '',
          sku: '',
          tax_amount: '',
          weee_tax_applied: '',
          weee_tax_applied_amount: '',
          weee_tax_applied_row_amount: '',
          weee_tax_disposition: '',
          weee_tax_row_disposition: ''
        }
      ],
      order_currency_code: '',
      order_id: 0,
      shipping_address_id: 0,
      shipping_amount: '',
      shipping_discount_tax_compensation_amount: '',
      shipping_incl_tax: '',
      shipping_tax_amount: '',
      state: 0,
      store_currency_code: '',
      store_id: 0,
      store_to_base_rate: '',
      store_to_order_rate: '',
      subtotal: '',
      subtotal_incl_tax: '',
      tax_amount: '',
      transaction_id: '',
      updated_at: ''
    },
    offlineRequested: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/creditmemo/refund';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"creditmemo":{"adjustment":"","adjustment_negative":"","adjustment_positive":"","base_adjustment":"","base_adjustment_negative":"","base_adjustment_positive":"","base_currency_code":"","base_discount_amount":"","base_discount_tax_compensation_amount":"","base_grand_total":"","base_shipping_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_tax_amount":"","base_subtotal":"","base_subtotal_incl_tax":"","base_tax_amount":"","base_to_global_rate":"","base_to_order_rate":"","billing_address_id":0,"comments":[{"comment":"","created_at":"","entity_id":0,"extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_id":0}],"created_at":"","creditmemo_status":0,"discount_amount":"","discount_description":"","discount_tax_compensation_amount":"","email_sent":0,"entity_id":0,"extension_attributes":{"base_customer_balance_amount":"","base_gift_cards_amount":"","customer_balance_amount":"","gift_cards_amount":"","gw_base_price":"","gw_base_tax_amount":"","gw_card_base_price":"","gw_card_base_tax_amount":"","gw_card_price":"","gw_card_tax_amount":"","gw_items_base_price":"","gw_items_base_tax_amount":"","gw_items_price":"","gw_items_tax_amount":"","gw_price":"","gw_tax_amount":""},"global_currency_code":"","grand_total":"","increment_id":"","invoice_id":0,"items":[{"additional_data":"","base_cost":"","base_discount_amount":"","base_discount_tax_compensation_amount":"","base_price":"","base_price_incl_tax":"","base_row_total":"","base_row_total_incl_tax":"","base_tax_amount":"","base_weee_tax_applied_amount":"","base_weee_tax_applied_row_amnt":"","base_weee_tax_disposition":"","base_weee_tax_row_disposition":"","description":"","discount_amount":"","discount_tax_compensation_amount":"","entity_id":0,"extension_attributes":{"invoice_text_codes":[],"tax_codes":[],"vertex_tax_codes":[]},"name":"","order_item_id":0,"parent_id":0,"price":"","price_incl_tax":"","product_id":0,"qty":"","row_total":"","row_total_incl_tax":"","sku":"","tax_amount":"","weee_tax_applied":"","weee_tax_applied_amount":"","weee_tax_applied_row_amount":"","weee_tax_disposition":"","weee_tax_row_disposition":""}],"order_currency_code":"","order_id":0,"shipping_address_id":0,"shipping_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_tax_amount":"","state":0,"store_currency_code":"","store_id":0,"store_to_base_rate":"","store_to_order_rate":"","subtotal":"","subtotal_incl_tax":"","tax_amount":"","transaction_id":"","updated_at":""},"offlineRequested":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}}/V1/creditmemo/refund',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "creditmemo": {\n    "adjustment": "",\n    "adjustment_negative": "",\n    "adjustment_positive": "",\n    "base_adjustment": "",\n    "base_adjustment_negative": "",\n    "base_adjustment_positive": "",\n    "base_currency_code": "",\n    "base_discount_amount": "",\n    "base_discount_tax_compensation_amount": "",\n    "base_grand_total": "",\n    "base_shipping_amount": "",\n    "base_shipping_discount_tax_compensation_amnt": "",\n    "base_shipping_incl_tax": "",\n    "base_shipping_tax_amount": "",\n    "base_subtotal": "",\n    "base_subtotal_incl_tax": "",\n    "base_tax_amount": "",\n    "base_to_global_rate": "",\n    "base_to_order_rate": "",\n    "billing_address_id": 0,\n    "comments": [\n      {\n        "comment": "",\n        "created_at": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "is_customer_notified": 0,\n        "is_visible_on_front": 0,\n        "parent_id": 0\n      }\n    ],\n    "created_at": "",\n    "creditmemo_status": 0,\n    "discount_amount": "",\n    "discount_description": "",\n    "discount_tax_compensation_amount": "",\n    "email_sent": 0,\n    "entity_id": 0,\n    "extension_attributes": {\n      "base_customer_balance_amount": "",\n      "base_gift_cards_amount": "",\n      "customer_balance_amount": "",\n      "gift_cards_amount": "",\n      "gw_base_price": "",\n      "gw_base_tax_amount": "",\n      "gw_card_base_price": "",\n      "gw_card_base_tax_amount": "",\n      "gw_card_price": "",\n      "gw_card_tax_amount": "",\n      "gw_items_base_price": "",\n      "gw_items_base_tax_amount": "",\n      "gw_items_price": "",\n      "gw_items_tax_amount": "",\n      "gw_price": "",\n      "gw_tax_amount": ""\n    },\n    "global_currency_code": "",\n    "grand_total": "",\n    "increment_id": "",\n    "invoice_id": 0,\n    "items": [\n      {\n        "additional_data": "",\n        "base_cost": "",\n        "base_discount_amount": "",\n        "base_discount_tax_compensation_amount": "",\n        "base_price": "",\n        "base_price_incl_tax": "",\n        "base_row_total": "",\n        "base_row_total_incl_tax": "",\n        "base_tax_amount": "",\n        "base_weee_tax_applied_amount": "",\n        "base_weee_tax_applied_row_amnt": "",\n        "base_weee_tax_disposition": "",\n        "base_weee_tax_row_disposition": "",\n        "description": "",\n        "discount_amount": "",\n        "discount_tax_compensation_amount": "",\n        "entity_id": 0,\n        "extension_attributes": {\n          "invoice_text_codes": [],\n          "tax_codes": [],\n          "vertex_tax_codes": []\n        },\n        "name": "",\n        "order_item_id": 0,\n        "parent_id": 0,\n        "price": "",\n        "price_incl_tax": "",\n        "product_id": 0,\n        "qty": "",\n        "row_total": "",\n        "row_total_incl_tax": "",\n        "sku": "",\n        "tax_amount": "",\n        "weee_tax_applied": "",\n        "weee_tax_applied_amount": "",\n        "weee_tax_applied_row_amount": "",\n        "weee_tax_disposition": "",\n        "weee_tax_row_disposition": ""\n      }\n    ],\n    "order_currency_code": "",\n    "order_id": 0,\n    "shipping_address_id": 0,\n    "shipping_amount": "",\n    "shipping_discount_tax_compensation_amount": "",\n    "shipping_incl_tax": "",\n    "shipping_tax_amount": "",\n    "state": 0,\n    "store_currency_code": "",\n    "store_id": 0,\n    "store_to_base_rate": "",\n    "store_to_order_rate": "",\n    "subtotal": "",\n    "subtotal_incl_tax": "",\n    "tax_amount": "",\n    "transaction_id": "",\n    "updated_at": ""\n  },\n  "offlineRequested": 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  \"creditmemo\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  },\n  \"offlineRequested\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/creditmemo/refund")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/creditmemo/refund',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  creditmemo: {
    adjustment: '',
    adjustment_negative: '',
    adjustment_positive: '',
    base_adjustment: '',
    base_adjustment_negative: '',
    base_adjustment_positive: '',
    base_currency_code: '',
    base_discount_amount: '',
    base_discount_tax_compensation_amount: '',
    base_grand_total: '',
    base_shipping_amount: '',
    base_shipping_discount_tax_compensation_amnt: '',
    base_shipping_incl_tax: '',
    base_shipping_tax_amount: '',
    base_subtotal: '',
    base_subtotal_incl_tax: '',
    base_tax_amount: '',
    base_to_global_rate: '',
    base_to_order_rate: '',
    billing_address_id: 0,
    comments: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0
      }
    ],
    created_at: '',
    creditmemo_status: 0,
    discount_amount: '',
    discount_description: '',
    discount_tax_compensation_amount: '',
    email_sent: 0,
    entity_id: 0,
    extension_attributes: {
      base_customer_balance_amount: '',
      base_gift_cards_amount: '',
      customer_balance_amount: '',
      gift_cards_amount: '',
      gw_base_price: '',
      gw_base_tax_amount: '',
      gw_card_base_price: '',
      gw_card_base_tax_amount: '',
      gw_card_price: '',
      gw_card_tax_amount: '',
      gw_items_base_price: '',
      gw_items_base_tax_amount: '',
      gw_items_price: '',
      gw_items_tax_amount: '',
      gw_price: '',
      gw_tax_amount: ''
    },
    global_currency_code: '',
    grand_total: '',
    increment_id: '',
    invoice_id: 0,
    items: [
      {
        additional_data: '',
        base_cost: '',
        base_discount_amount: '',
        base_discount_tax_compensation_amount: '',
        base_price: '',
        base_price_incl_tax: '',
        base_row_total: '',
        base_row_total_incl_tax: '',
        base_tax_amount: '',
        base_weee_tax_applied_amount: '',
        base_weee_tax_applied_row_amnt: '',
        base_weee_tax_disposition: '',
        base_weee_tax_row_disposition: '',
        description: '',
        discount_amount: '',
        discount_tax_compensation_amount: '',
        entity_id: 0,
        extension_attributes: {invoice_text_codes: [], tax_codes: [], vertex_tax_codes: []},
        name: '',
        order_item_id: 0,
        parent_id: 0,
        price: '',
        price_incl_tax: '',
        product_id: 0,
        qty: '',
        row_total: '',
        row_total_incl_tax: '',
        sku: '',
        tax_amount: '',
        weee_tax_applied: '',
        weee_tax_applied_amount: '',
        weee_tax_applied_row_amount: '',
        weee_tax_disposition: '',
        weee_tax_row_disposition: ''
      }
    ],
    order_currency_code: '',
    order_id: 0,
    shipping_address_id: 0,
    shipping_amount: '',
    shipping_discount_tax_compensation_amount: '',
    shipping_incl_tax: '',
    shipping_tax_amount: '',
    state: 0,
    store_currency_code: '',
    store_id: 0,
    store_to_base_rate: '',
    store_to_order_rate: '',
    subtotal: '',
    subtotal_incl_tax: '',
    tax_amount: '',
    transaction_id: '',
    updated_at: ''
  },
  offlineRequested: false
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/creditmemo/refund',
  headers: {'content-type': 'application/json'},
  body: {
    creditmemo: {
      adjustment: '',
      adjustment_negative: '',
      adjustment_positive: '',
      base_adjustment: '',
      base_adjustment_negative: '',
      base_adjustment_positive: '',
      base_currency_code: '',
      base_discount_amount: '',
      base_discount_tax_compensation_amount: '',
      base_grand_total: '',
      base_shipping_amount: '',
      base_shipping_discount_tax_compensation_amnt: '',
      base_shipping_incl_tax: '',
      base_shipping_tax_amount: '',
      base_subtotal: '',
      base_subtotal_incl_tax: '',
      base_tax_amount: '',
      base_to_global_rate: '',
      base_to_order_rate: '',
      billing_address_id: 0,
      comments: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0
        }
      ],
      created_at: '',
      creditmemo_status: 0,
      discount_amount: '',
      discount_description: '',
      discount_tax_compensation_amount: '',
      email_sent: 0,
      entity_id: 0,
      extension_attributes: {
        base_customer_balance_amount: '',
        base_gift_cards_amount: '',
        customer_balance_amount: '',
        gift_cards_amount: '',
        gw_base_price: '',
        gw_base_tax_amount: '',
        gw_card_base_price: '',
        gw_card_base_tax_amount: '',
        gw_card_price: '',
        gw_card_tax_amount: '',
        gw_items_base_price: '',
        gw_items_base_tax_amount: '',
        gw_items_price: '',
        gw_items_tax_amount: '',
        gw_price: '',
        gw_tax_amount: ''
      },
      global_currency_code: '',
      grand_total: '',
      increment_id: '',
      invoice_id: 0,
      items: [
        {
          additional_data: '',
          base_cost: '',
          base_discount_amount: '',
          base_discount_tax_compensation_amount: '',
          base_price: '',
          base_price_incl_tax: '',
          base_row_total: '',
          base_row_total_incl_tax: '',
          base_tax_amount: '',
          base_weee_tax_applied_amount: '',
          base_weee_tax_applied_row_amnt: '',
          base_weee_tax_disposition: '',
          base_weee_tax_row_disposition: '',
          description: '',
          discount_amount: '',
          discount_tax_compensation_amount: '',
          entity_id: 0,
          extension_attributes: {invoice_text_codes: [], tax_codes: [], vertex_tax_codes: []},
          name: '',
          order_item_id: 0,
          parent_id: 0,
          price: '',
          price_incl_tax: '',
          product_id: 0,
          qty: '',
          row_total: '',
          row_total_incl_tax: '',
          sku: '',
          tax_amount: '',
          weee_tax_applied: '',
          weee_tax_applied_amount: '',
          weee_tax_applied_row_amount: '',
          weee_tax_disposition: '',
          weee_tax_row_disposition: ''
        }
      ],
      order_currency_code: '',
      order_id: 0,
      shipping_address_id: 0,
      shipping_amount: '',
      shipping_discount_tax_compensation_amount: '',
      shipping_incl_tax: '',
      shipping_tax_amount: '',
      state: 0,
      store_currency_code: '',
      store_id: 0,
      store_to_base_rate: '',
      store_to_order_rate: '',
      subtotal: '',
      subtotal_incl_tax: '',
      tax_amount: '',
      transaction_id: '',
      updated_at: ''
    },
    offlineRequested: 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}}/V1/creditmemo/refund');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  creditmemo: {
    adjustment: '',
    adjustment_negative: '',
    adjustment_positive: '',
    base_adjustment: '',
    base_adjustment_negative: '',
    base_adjustment_positive: '',
    base_currency_code: '',
    base_discount_amount: '',
    base_discount_tax_compensation_amount: '',
    base_grand_total: '',
    base_shipping_amount: '',
    base_shipping_discount_tax_compensation_amnt: '',
    base_shipping_incl_tax: '',
    base_shipping_tax_amount: '',
    base_subtotal: '',
    base_subtotal_incl_tax: '',
    base_tax_amount: '',
    base_to_global_rate: '',
    base_to_order_rate: '',
    billing_address_id: 0,
    comments: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0
      }
    ],
    created_at: '',
    creditmemo_status: 0,
    discount_amount: '',
    discount_description: '',
    discount_tax_compensation_amount: '',
    email_sent: 0,
    entity_id: 0,
    extension_attributes: {
      base_customer_balance_amount: '',
      base_gift_cards_amount: '',
      customer_balance_amount: '',
      gift_cards_amount: '',
      gw_base_price: '',
      gw_base_tax_amount: '',
      gw_card_base_price: '',
      gw_card_base_tax_amount: '',
      gw_card_price: '',
      gw_card_tax_amount: '',
      gw_items_base_price: '',
      gw_items_base_tax_amount: '',
      gw_items_price: '',
      gw_items_tax_amount: '',
      gw_price: '',
      gw_tax_amount: ''
    },
    global_currency_code: '',
    grand_total: '',
    increment_id: '',
    invoice_id: 0,
    items: [
      {
        additional_data: '',
        base_cost: '',
        base_discount_amount: '',
        base_discount_tax_compensation_amount: '',
        base_price: '',
        base_price_incl_tax: '',
        base_row_total: '',
        base_row_total_incl_tax: '',
        base_tax_amount: '',
        base_weee_tax_applied_amount: '',
        base_weee_tax_applied_row_amnt: '',
        base_weee_tax_disposition: '',
        base_weee_tax_row_disposition: '',
        description: '',
        discount_amount: '',
        discount_tax_compensation_amount: '',
        entity_id: 0,
        extension_attributes: {
          invoice_text_codes: [],
          tax_codes: [],
          vertex_tax_codes: []
        },
        name: '',
        order_item_id: 0,
        parent_id: 0,
        price: '',
        price_incl_tax: '',
        product_id: 0,
        qty: '',
        row_total: '',
        row_total_incl_tax: '',
        sku: '',
        tax_amount: '',
        weee_tax_applied: '',
        weee_tax_applied_amount: '',
        weee_tax_applied_row_amount: '',
        weee_tax_disposition: '',
        weee_tax_row_disposition: ''
      }
    ],
    order_currency_code: '',
    order_id: 0,
    shipping_address_id: 0,
    shipping_amount: '',
    shipping_discount_tax_compensation_amount: '',
    shipping_incl_tax: '',
    shipping_tax_amount: '',
    state: 0,
    store_currency_code: '',
    store_id: 0,
    store_to_base_rate: '',
    store_to_order_rate: '',
    subtotal: '',
    subtotal_incl_tax: '',
    tax_amount: '',
    transaction_id: '',
    updated_at: ''
  },
  offlineRequested: 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}}/V1/creditmemo/refund',
  headers: {'content-type': 'application/json'},
  data: {
    creditmemo: {
      adjustment: '',
      adjustment_negative: '',
      adjustment_positive: '',
      base_adjustment: '',
      base_adjustment_negative: '',
      base_adjustment_positive: '',
      base_currency_code: '',
      base_discount_amount: '',
      base_discount_tax_compensation_amount: '',
      base_grand_total: '',
      base_shipping_amount: '',
      base_shipping_discount_tax_compensation_amnt: '',
      base_shipping_incl_tax: '',
      base_shipping_tax_amount: '',
      base_subtotal: '',
      base_subtotal_incl_tax: '',
      base_tax_amount: '',
      base_to_global_rate: '',
      base_to_order_rate: '',
      billing_address_id: 0,
      comments: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0
        }
      ],
      created_at: '',
      creditmemo_status: 0,
      discount_amount: '',
      discount_description: '',
      discount_tax_compensation_amount: '',
      email_sent: 0,
      entity_id: 0,
      extension_attributes: {
        base_customer_balance_amount: '',
        base_gift_cards_amount: '',
        customer_balance_amount: '',
        gift_cards_amount: '',
        gw_base_price: '',
        gw_base_tax_amount: '',
        gw_card_base_price: '',
        gw_card_base_tax_amount: '',
        gw_card_price: '',
        gw_card_tax_amount: '',
        gw_items_base_price: '',
        gw_items_base_tax_amount: '',
        gw_items_price: '',
        gw_items_tax_amount: '',
        gw_price: '',
        gw_tax_amount: ''
      },
      global_currency_code: '',
      grand_total: '',
      increment_id: '',
      invoice_id: 0,
      items: [
        {
          additional_data: '',
          base_cost: '',
          base_discount_amount: '',
          base_discount_tax_compensation_amount: '',
          base_price: '',
          base_price_incl_tax: '',
          base_row_total: '',
          base_row_total_incl_tax: '',
          base_tax_amount: '',
          base_weee_tax_applied_amount: '',
          base_weee_tax_applied_row_amnt: '',
          base_weee_tax_disposition: '',
          base_weee_tax_row_disposition: '',
          description: '',
          discount_amount: '',
          discount_tax_compensation_amount: '',
          entity_id: 0,
          extension_attributes: {invoice_text_codes: [], tax_codes: [], vertex_tax_codes: []},
          name: '',
          order_item_id: 0,
          parent_id: 0,
          price: '',
          price_incl_tax: '',
          product_id: 0,
          qty: '',
          row_total: '',
          row_total_incl_tax: '',
          sku: '',
          tax_amount: '',
          weee_tax_applied: '',
          weee_tax_applied_amount: '',
          weee_tax_applied_row_amount: '',
          weee_tax_disposition: '',
          weee_tax_row_disposition: ''
        }
      ],
      order_currency_code: '',
      order_id: 0,
      shipping_address_id: 0,
      shipping_amount: '',
      shipping_discount_tax_compensation_amount: '',
      shipping_incl_tax: '',
      shipping_tax_amount: '',
      state: 0,
      store_currency_code: '',
      store_id: 0,
      store_to_base_rate: '',
      store_to_order_rate: '',
      subtotal: '',
      subtotal_incl_tax: '',
      tax_amount: '',
      transaction_id: '',
      updated_at: ''
    },
    offlineRequested: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/creditmemo/refund';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"creditmemo":{"adjustment":"","adjustment_negative":"","adjustment_positive":"","base_adjustment":"","base_adjustment_negative":"","base_adjustment_positive":"","base_currency_code":"","base_discount_amount":"","base_discount_tax_compensation_amount":"","base_grand_total":"","base_shipping_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_tax_amount":"","base_subtotal":"","base_subtotal_incl_tax":"","base_tax_amount":"","base_to_global_rate":"","base_to_order_rate":"","billing_address_id":0,"comments":[{"comment":"","created_at":"","entity_id":0,"extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_id":0}],"created_at":"","creditmemo_status":0,"discount_amount":"","discount_description":"","discount_tax_compensation_amount":"","email_sent":0,"entity_id":0,"extension_attributes":{"base_customer_balance_amount":"","base_gift_cards_amount":"","customer_balance_amount":"","gift_cards_amount":"","gw_base_price":"","gw_base_tax_amount":"","gw_card_base_price":"","gw_card_base_tax_amount":"","gw_card_price":"","gw_card_tax_amount":"","gw_items_base_price":"","gw_items_base_tax_amount":"","gw_items_price":"","gw_items_tax_amount":"","gw_price":"","gw_tax_amount":""},"global_currency_code":"","grand_total":"","increment_id":"","invoice_id":0,"items":[{"additional_data":"","base_cost":"","base_discount_amount":"","base_discount_tax_compensation_amount":"","base_price":"","base_price_incl_tax":"","base_row_total":"","base_row_total_incl_tax":"","base_tax_amount":"","base_weee_tax_applied_amount":"","base_weee_tax_applied_row_amnt":"","base_weee_tax_disposition":"","base_weee_tax_row_disposition":"","description":"","discount_amount":"","discount_tax_compensation_amount":"","entity_id":0,"extension_attributes":{"invoice_text_codes":[],"tax_codes":[],"vertex_tax_codes":[]},"name":"","order_item_id":0,"parent_id":0,"price":"","price_incl_tax":"","product_id":0,"qty":"","row_total":"","row_total_incl_tax":"","sku":"","tax_amount":"","weee_tax_applied":"","weee_tax_applied_amount":"","weee_tax_applied_row_amount":"","weee_tax_disposition":"","weee_tax_row_disposition":""}],"order_currency_code":"","order_id":0,"shipping_address_id":0,"shipping_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_tax_amount":"","state":0,"store_currency_code":"","store_id":0,"store_to_base_rate":"","store_to_order_rate":"","subtotal":"","subtotal_incl_tax":"","tax_amount":"","transaction_id":"","updated_at":""},"offlineRequested":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"creditmemo": @{ @"adjustment": @"", @"adjustment_negative": @"", @"adjustment_positive": @"", @"base_adjustment": @"", @"base_adjustment_negative": @"", @"base_adjustment_positive": @"", @"base_currency_code": @"", @"base_discount_amount": @"", @"base_discount_tax_compensation_amount": @"", @"base_grand_total": @"", @"base_shipping_amount": @"", @"base_shipping_discount_tax_compensation_amnt": @"", @"base_shipping_incl_tax": @"", @"base_shipping_tax_amount": @"", @"base_subtotal": @"", @"base_subtotal_incl_tax": @"", @"base_tax_amount": @"", @"base_to_global_rate": @"", @"base_to_order_rate": @"", @"billing_address_id": @0, @"comments": @[ @{ @"comment": @"", @"created_at": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"is_customer_notified": @0, @"is_visible_on_front": @0, @"parent_id": @0 } ], @"created_at": @"", @"creditmemo_status": @0, @"discount_amount": @"", @"discount_description": @"", @"discount_tax_compensation_amount": @"", @"email_sent": @0, @"entity_id": @0, @"extension_attributes": @{ @"base_customer_balance_amount": @"", @"base_gift_cards_amount": @"", @"customer_balance_amount": @"", @"gift_cards_amount": @"", @"gw_base_price": @"", @"gw_base_tax_amount": @"", @"gw_card_base_price": @"", @"gw_card_base_tax_amount": @"", @"gw_card_price": @"", @"gw_card_tax_amount": @"", @"gw_items_base_price": @"", @"gw_items_base_tax_amount": @"", @"gw_items_price": @"", @"gw_items_tax_amount": @"", @"gw_price": @"", @"gw_tax_amount": @"" }, @"global_currency_code": @"", @"grand_total": @"", @"increment_id": @"", @"invoice_id": @0, @"items": @[ @{ @"additional_data": @"", @"base_cost": @"", @"base_discount_amount": @"", @"base_discount_tax_compensation_amount": @"", @"base_price": @"", @"base_price_incl_tax": @"", @"base_row_total": @"", @"base_row_total_incl_tax": @"", @"base_tax_amount": @"", @"base_weee_tax_applied_amount": @"", @"base_weee_tax_applied_row_amnt": @"", @"base_weee_tax_disposition": @"", @"base_weee_tax_row_disposition": @"", @"description": @"", @"discount_amount": @"", @"discount_tax_compensation_amount": @"", @"entity_id": @0, @"extension_attributes": @{ @"invoice_text_codes": @[  ], @"tax_codes": @[  ], @"vertex_tax_codes": @[  ] }, @"name": @"", @"order_item_id": @0, @"parent_id": @0, @"price": @"", @"price_incl_tax": @"", @"product_id": @0, @"qty": @"", @"row_total": @"", @"row_total_incl_tax": @"", @"sku": @"", @"tax_amount": @"", @"weee_tax_applied": @"", @"weee_tax_applied_amount": @"", @"weee_tax_applied_row_amount": @"", @"weee_tax_disposition": @"", @"weee_tax_row_disposition": @"" } ], @"order_currency_code": @"", @"order_id": @0, @"shipping_address_id": @0, @"shipping_amount": @"", @"shipping_discount_tax_compensation_amount": @"", @"shipping_incl_tax": @"", @"shipping_tax_amount": @"", @"state": @0, @"store_currency_code": @"", @"store_id": @0, @"store_to_base_rate": @"", @"store_to_order_rate": @"", @"subtotal": @"", @"subtotal_incl_tax": @"", @"tax_amount": @"", @"transaction_id": @"", @"updated_at": @"" },
                              @"offlineRequested": @NO };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/creditmemo/refund"]
                                                       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}}/V1/creditmemo/refund" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"creditmemo\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  },\n  \"offlineRequested\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/creditmemo/refund",
  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([
    'creditmemo' => [
        'adjustment' => '',
        'adjustment_negative' => '',
        'adjustment_positive' => '',
        'base_adjustment' => '',
        'base_adjustment_negative' => '',
        'base_adjustment_positive' => '',
        'base_currency_code' => '',
        'base_discount_amount' => '',
        'base_discount_tax_compensation_amount' => '',
        'base_grand_total' => '',
        'base_shipping_amount' => '',
        'base_shipping_discount_tax_compensation_amnt' => '',
        'base_shipping_incl_tax' => '',
        'base_shipping_tax_amount' => '',
        'base_subtotal' => '',
        'base_subtotal_incl_tax' => '',
        'base_tax_amount' => '',
        'base_to_global_rate' => '',
        'base_to_order_rate' => '',
        'billing_address_id' => 0,
        'comments' => [
                [
                                'comment' => '',
                                'created_at' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'is_customer_notified' => 0,
                                'is_visible_on_front' => 0,
                                'parent_id' => 0
                ]
        ],
        'created_at' => '',
        'creditmemo_status' => 0,
        'discount_amount' => '',
        'discount_description' => '',
        'discount_tax_compensation_amount' => '',
        'email_sent' => 0,
        'entity_id' => 0,
        'extension_attributes' => [
                'base_customer_balance_amount' => '',
                'base_gift_cards_amount' => '',
                'customer_balance_amount' => '',
                'gift_cards_amount' => '',
                'gw_base_price' => '',
                'gw_base_tax_amount' => '',
                'gw_card_base_price' => '',
                'gw_card_base_tax_amount' => '',
                'gw_card_price' => '',
                'gw_card_tax_amount' => '',
                'gw_items_base_price' => '',
                'gw_items_base_tax_amount' => '',
                'gw_items_price' => '',
                'gw_items_tax_amount' => '',
                'gw_price' => '',
                'gw_tax_amount' => ''
        ],
        'global_currency_code' => '',
        'grand_total' => '',
        'increment_id' => '',
        'invoice_id' => 0,
        'items' => [
                [
                                'additional_data' => '',
                                'base_cost' => '',
                                'base_discount_amount' => '',
                                'base_discount_tax_compensation_amount' => '',
                                'base_price' => '',
                                'base_price_incl_tax' => '',
                                'base_row_total' => '',
                                'base_row_total_incl_tax' => '',
                                'base_tax_amount' => '',
                                'base_weee_tax_applied_amount' => '',
                                'base_weee_tax_applied_row_amnt' => '',
                                'base_weee_tax_disposition' => '',
                                'base_weee_tax_row_disposition' => '',
                                'description' => '',
                                'discount_amount' => '',
                                'discount_tax_compensation_amount' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                'invoice_text_codes' => [
                                                                                                                                
                                                                ],
                                                                'tax_codes' => [
                                                                                                                                
                                                                ],
                                                                'vertex_tax_codes' => [
                                                                                                                                
                                                                ]
                                ],
                                'name' => '',
                                'order_item_id' => 0,
                                'parent_id' => 0,
                                'price' => '',
                                'price_incl_tax' => '',
                                'product_id' => 0,
                                'qty' => '',
                                'row_total' => '',
                                'row_total_incl_tax' => '',
                                'sku' => '',
                                'tax_amount' => '',
                                'weee_tax_applied' => '',
                                'weee_tax_applied_amount' => '',
                                'weee_tax_applied_row_amount' => '',
                                'weee_tax_disposition' => '',
                                'weee_tax_row_disposition' => ''
                ]
        ],
        'order_currency_code' => '',
        'order_id' => 0,
        'shipping_address_id' => 0,
        'shipping_amount' => '',
        'shipping_discount_tax_compensation_amount' => '',
        'shipping_incl_tax' => '',
        'shipping_tax_amount' => '',
        'state' => 0,
        'store_currency_code' => '',
        'store_id' => 0,
        'store_to_base_rate' => '',
        'store_to_order_rate' => '',
        'subtotal' => '',
        'subtotal_incl_tax' => '',
        'tax_amount' => '',
        'transaction_id' => '',
        'updated_at' => ''
    ],
    'offlineRequested' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/creditmemo/refund', [
  'body' => '{
  "creditmemo": {
    "adjustment": "",
    "adjustment_negative": "",
    "adjustment_positive": "",
    "base_adjustment": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "creditmemo_status": 0,
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": ""
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "invoice_id": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "base_weee_tax_applied_amount": "",
        "base_weee_tax_applied_row_amnt": "",
        "base_weee_tax_disposition": "",
        "base_weee_tax_row_disposition": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": "",
        "weee_tax_applied": "",
        "weee_tax_applied_amount": "",
        "weee_tax_applied_row_amount": "",
        "weee_tax_disposition": "",
        "weee_tax_row_disposition": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "transaction_id": "",
    "updated_at": ""
  },
  "offlineRequested": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/creditmemo/refund');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'creditmemo' => [
    'adjustment' => '',
    'adjustment_negative' => '',
    'adjustment_positive' => '',
    'base_adjustment' => '',
    'base_adjustment_negative' => '',
    'base_adjustment_positive' => '',
    'base_currency_code' => '',
    'base_discount_amount' => '',
    'base_discount_tax_compensation_amount' => '',
    'base_grand_total' => '',
    'base_shipping_amount' => '',
    'base_shipping_discount_tax_compensation_amnt' => '',
    'base_shipping_incl_tax' => '',
    'base_shipping_tax_amount' => '',
    'base_subtotal' => '',
    'base_subtotal_incl_tax' => '',
    'base_tax_amount' => '',
    'base_to_global_rate' => '',
    'base_to_order_rate' => '',
    'billing_address_id' => 0,
    'comments' => [
        [
                'comment' => '',
                'created_at' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'is_customer_notified' => 0,
                'is_visible_on_front' => 0,
                'parent_id' => 0
        ]
    ],
    'created_at' => '',
    'creditmemo_status' => 0,
    'discount_amount' => '',
    'discount_description' => '',
    'discount_tax_compensation_amount' => '',
    'email_sent' => 0,
    'entity_id' => 0,
    'extension_attributes' => [
        'base_customer_balance_amount' => '',
        'base_gift_cards_amount' => '',
        'customer_balance_amount' => '',
        'gift_cards_amount' => '',
        'gw_base_price' => '',
        'gw_base_tax_amount' => '',
        'gw_card_base_price' => '',
        'gw_card_base_tax_amount' => '',
        'gw_card_price' => '',
        'gw_card_tax_amount' => '',
        'gw_items_base_price' => '',
        'gw_items_base_tax_amount' => '',
        'gw_items_price' => '',
        'gw_items_tax_amount' => '',
        'gw_price' => '',
        'gw_tax_amount' => ''
    ],
    'global_currency_code' => '',
    'grand_total' => '',
    'increment_id' => '',
    'invoice_id' => 0,
    'items' => [
        [
                'additional_data' => '',
                'base_cost' => '',
                'base_discount_amount' => '',
                'base_discount_tax_compensation_amount' => '',
                'base_price' => '',
                'base_price_incl_tax' => '',
                'base_row_total' => '',
                'base_row_total_incl_tax' => '',
                'base_tax_amount' => '',
                'base_weee_tax_applied_amount' => '',
                'base_weee_tax_applied_row_amnt' => '',
                'base_weee_tax_disposition' => '',
                'base_weee_tax_row_disposition' => '',
                'description' => '',
                'discount_amount' => '',
                'discount_tax_compensation_amount' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                'invoice_text_codes' => [
                                                                
                                ],
                                'tax_codes' => [
                                                                
                                ],
                                'vertex_tax_codes' => [
                                                                
                                ]
                ],
                'name' => '',
                'order_item_id' => 0,
                'parent_id' => 0,
                'price' => '',
                'price_incl_tax' => '',
                'product_id' => 0,
                'qty' => '',
                'row_total' => '',
                'row_total_incl_tax' => '',
                'sku' => '',
                'tax_amount' => '',
                'weee_tax_applied' => '',
                'weee_tax_applied_amount' => '',
                'weee_tax_applied_row_amount' => '',
                'weee_tax_disposition' => '',
                'weee_tax_row_disposition' => ''
        ]
    ],
    'order_currency_code' => '',
    'order_id' => 0,
    'shipping_address_id' => 0,
    'shipping_amount' => '',
    'shipping_discount_tax_compensation_amount' => '',
    'shipping_incl_tax' => '',
    'shipping_tax_amount' => '',
    'state' => 0,
    'store_currency_code' => '',
    'store_id' => 0,
    'store_to_base_rate' => '',
    'store_to_order_rate' => '',
    'subtotal' => '',
    'subtotal_incl_tax' => '',
    'tax_amount' => '',
    'transaction_id' => '',
    'updated_at' => ''
  ],
  'offlineRequested' => null
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'creditmemo' => [
    'adjustment' => '',
    'adjustment_negative' => '',
    'adjustment_positive' => '',
    'base_adjustment' => '',
    'base_adjustment_negative' => '',
    'base_adjustment_positive' => '',
    'base_currency_code' => '',
    'base_discount_amount' => '',
    'base_discount_tax_compensation_amount' => '',
    'base_grand_total' => '',
    'base_shipping_amount' => '',
    'base_shipping_discount_tax_compensation_amnt' => '',
    'base_shipping_incl_tax' => '',
    'base_shipping_tax_amount' => '',
    'base_subtotal' => '',
    'base_subtotal_incl_tax' => '',
    'base_tax_amount' => '',
    'base_to_global_rate' => '',
    'base_to_order_rate' => '',
    'billing_address_id' => 0,
    'comments' => [
        [
                'comment' => '',
                'created_at' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'is_customer_notified' => 0,
                'is_visible_on_front' => 0,
                'parent_id' => 0
        ]
    ],
    'created_at' => '',
    'creditmemo_status' => 0,
    'discount_amount' => '',
    'discount_description' => '',
    'discount_tax_compensation_amount' => '',
    'email_sent' => 0,
    'entity_id' => 0,
    'extension_attributes' => [
        'base_customer_balance_amount' => '',
        'base_gift_cards_amount' => '',
        'customer_balance_amount' => '',
        'gift_cards_amount' => '',
        'gw_base_price' => '',
        'gw_base_tax_amount' => '',
        'gw_card_base_price' => '',
        'gw_card_base_tax_amount' => '',
        'gw_card_price' => '',
        'gw_card_tax_amount' => '',
        'gw_items_base_price' => '',
        'gw_items_base_tax_amount' => '',
        'gw_items_price' => '',
        'gw_items_tax_amount' => '',
        'gw_price' => '',
        'gw_tax_amount' => ''
    ],
    'global_currency_code' => '',
    'grand_total' => '',
    'increment_id' => '',
    'invoice_id' => 0,
    'items' => [
        [
                'additional_data' => '',
                'base_cost' => '',
                'base_discount_amount' => '',
                'base_discount_tax_compensation_amount' => '',
                'base_price' => '',
                'base_price_incl_tax' => '',
                'base_row_total' => '',
                'base_row_total_incl_tax' => '',
                'base_tax_amount' => '',
                'base_weee_tax_applied_amount' => '',
                'base_weee_tax_applied_row_amnt' => '',
                'base_weee_tax_disposition' => '',
                'base_weee_tax_row_disposition' => '',
                'description' => '',
                'discount_amount' => '',
                'discount_tax_compensation_amount' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                'invoice_text_codes' => [
                                                                
                                ],
                                'tax_codes' => [
                                                                
                                ],
                                'vertex_tax_codes' => [
                                                                
                                ]
                ],
                'name' => '',
                'order_item_id' => 0,
                'parent_id' => 0,
                'price' => '',
                'price_incl_tax' => '',
                'product_id' => 0,
                'qty' => '',
                'row_total' => '',
                'row_total_incl_tax' => '',
                'sku' => '',
                'tax_amount' => '',
                'weee_tax_applied' => '',
                'weee_tax_applied_amount' => '',
                'weee_tax_applied_row_amount' => '',
                'weee_tax_disposition' => '',
                'weee_tax_row_disposition' => ''
        ]
    ],
    'order_currency_code' => '',
    'order_id' => 0,
    'shipping_address_id' => 0,
    'shipping_amount' => '',
    'shipping_discount_tax_compensation_amount' => '',
    'shipping_incl_tax' => '',
    'shipping_tax_amount' => '',
    'state' => 0,
    'store_currency_code' => '',
    'store_id' => 0,
    'store_to_base_rate' => '',
    'store_to_order_rate' => '',
    'subtotal' => '',
    'subtotal_incl_tax' => '',
    'tax_amount' => '',
    'transaction_id' => '',
    'updated_at' => ''
  ],
  'offlineRequested' => null
]));
$request->setRequestUrl('{{baseUrl}}/V1/creditmemo/refund');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/creditmemo/refund' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "creditmemo": {
    "adjustment": "",
    "adjustment_negative": "",
    "adjustment_positive": "",
    "base_adjustment": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "creditmemo_status": 0,
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": ""
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "invoice_id": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "base_weee_tax_applied_amount": "",
        "base_weee_tax_applied_row_amnt": "",
        "base_weee_tax_disposition": "",
        "base_weee_tax_row_disposition": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": "",
        "weee_tax_applied": "",
        "weee_tax_applied_amount": "",
        "weee_tax_applied_row_amount": "",
        "weee_tax_disposition": "",
        "weee_tax_row_disposition": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "transaction_id": "",
    "updated_at": ""
  },
  "offlineRequested": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/creditmemo/refund' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "creditmemo": {
    "adjustment": "",
    "adjustment_negative": "",
    "adjustment_positive": "",
    "base_adjustment": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "creditmemo_status": 0,
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": ""
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "invoice_id": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "base_weee_tax_applied_amount": "",
        "base_weee_tax_applied_row_amnt": "",
        "base_weee_tax_disposition": "",
        "base_weee_tax_row_disposition": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": "",
        "weee_tax_applied": "",
        "weee_tax_applied_amount": "",
        "weee_tax_applied_row_amount": "",
        "weee_tax_disposition": "",
        "weee_tax_row_disposition": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "transaction_id": "",
    "updated_at": ""
  },
  "offlineRequested": false
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"creditmemo\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  },\n  \"offlineRequested\": false\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/creditmemo/refund", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/creditmemo/refund"

payload = {
    "creditmemo": {
        "adjustment": "",
        "adjustment_negative": "",
        "adjustment_positive": "",
        "base_adjustment": "",
        "base_adjustment_negative": "",
        "base_adjustment_positive": "",
        "base_currency_code": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_grand_total": "",
        "base_shipping_amount": "",
        "base_shipping_discount_tax_compensation_amnt": "",
        "base_shipping_incl_tax": "",
        "base_shipping_tax_amount": "",
        "base_subtotal": "",
        "base_subtotal_incl_tax": "",
        "base_tax_amount": "",
        "base_to_global_rate": "",
        "base_to_order_rate": "",
        "billing_address_id": 0,
        "comments": [
            {
                "comment": "",
                "created_at": "",
                "entity_id": 0,
                "extension_attributes": {},
                "is_customer_notified": 0,
                "is_visible_on_front": 0,
                "parent_id": 0
            }
        ],
        "created_at": "",
        "creditmemo_status": 0,
        "discount_amount": "",
        "discount_description": "",
        "discount_tax_compensation_amount": "",
        "email_sent": 0,
        "entity_id": 0,
        "extension_attributes": {
            "base_customer_balance_amount": "",
            "base_gift_cards_amount": "",
            "customer_balance_amount": "",
            "gift_cards_amount": "",
            "gw_base_price": "",
            "gw_base_tax_amount": "",
            "gw_card_base_price": "",
            "gw_card_base_tax_amount": "",
            "gw_card_price": "",
            "gw_card_tax_amount": "",
            "gw_items_base_price": "",
            "gw_items_base_tax_amount": "",
            "gw_items_price": "",
            "gw_items_tax_amount": "",
            "gw_price": "",
            "gw_tax_amount": ""
        },
        "global_currency_code": "",
        "grand_total": "",
        "increment_id": "",
        "invoice_id": 0,
        "items": [
            {
                "additional_data": "",
                "base_cost": "",
                "base_discount_amount": "",
                "base_discount_tax_compensation_amount": "",
                "base_price": "",
                "base_price_incl_tax": "",
                "base_row_total": "",
                "base_row_total_incl_tax": "",
                "base_tax_amount": "",
                "base_weee_tax_applied_amount": "",
                "base_weee_tax_applied_row_amnt": "",
                "base_weee_tax_disposition": "",
                "base_weee_tax_row_disposition": "",
                "description": "",
                "discount_amount": "",
                "discount_tax_compensation_amount": "",
                "entity_id": 0,
                "extension_attributes": {
                    "invoice_text_codes": [],
                    "tax_codes": [],
                    "vertex_tax_codes": []
                },
                "name": "",
                "order_item_id": 0,
                "parent_id": 0,
                "price": "",
                "price_incl_tax": "",
                "product_id": 0,
                "qty": "",
                "row_total": "",
                "row_total_incl_tax": "",
                "sku": "",
                "tax_amount": "",
                "weee_tax_applied": "",
                "weee_tax_applied_amount": "",
                "weee_tax_applied_row_amount": "",
                "weee_tax_disposition": "",
                "weee_tax_row_disposition": ""
            }
        ],
        "order_currency_code": "",
        "order_id": 0,
        "shipping_address_id": 0,
        "shipping_amount": "",
        "shipping_discount_tax_compensation_amount": "",
        "shipping_incl_tax": "",
        "shipping_tax_amount": "",
        "state": 0,
        "store_currency_code": "",
        "store_id": 0,
        "store_to_base_rate": "",
        "store_to_order_rate": "",
        "subtotal": "",
        "subtotal_incl_tax": "",
        "tax_amount": "",
        "transaction_id": "",
        "updated_at": ""
    },
    "offlineRequested": False
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/creditmemo/refund"

payload <- "{\n  \"creditmemo\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  },\n  \"offlineRequested\": false\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/creditmemo/refund")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"creditmemo\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  },\n  \"offlineRequested\": 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/V1/creditmemo/refund') do |req|
  req.body = "{\n  \"creditmemo\": {\n    \"adjustment\": \"\",\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"base_adjustment\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"creditmemo_status\": 0,\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\"\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"invoice_id\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_weee_tax_applied_amount\": \"\",\n        \"base_weee_tax_applied_row_amnt\": \"\",\n        \"base_weee_tax_disposition\": \"\",\n        \"base_weee_tax_row_disposition\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\",\n        \"weee_tax_applied\": \"\",\n        \"weee_tax_applied_amount\": \"\",\n        \"weee_tax_applied_row_amount\": \"\",\n        \"weee_tax_disposition\": \"\",\n        \"weee_tax_row_disposition\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  },\n  \"offlineRequested\": false\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/creditmemo/refund";

    let payload = json!({
        "creditmemo": json!({
            "adjustment": "",
            "adjustment_negative": "",
            "adjustment_positive": "",
            "base_adjustment": "",
            "base_adjustment_negative": "",
            "base_adjustment_positive": "",
            "base_currency_code": "",
            "base_discount_amount": "",
            "base_discount_tax_compensation_amount": "",
            "base_grand_total": "",
            "base_shipping_amount": "",
            "base_shipping_discount_tax_compensation_amnt": "",
            "base_shipping_incl_tax": "",
            "base_shipping_tax_amount": "",
            "base_subtotal": "",
            "base_subtotal_incl_tax": "",
            "base_tax_amount": "",
            "base_to_global_rate": "",
            "base_to_order_rate": "",
            "billing_address_id": 0,
            "comments": (
                json!({
                    "comment": "",
                    "created_at": "",
                    "entity_id": 0,
                    "extension_attributes": json!({}),
                    "is_customer_notified": 0,
                    "is_visible_on_front": 0,
                    "parent_id": 0
                })
            ),
            "created_at": "",
            "creditmemo_status": 0,
            "discount_amount": "",
            "discount_description": "",
            "discount_tax_compensation_amount": "",
            "email_sent": 0,
            "entity_id": 0,
            "extension_attributes": json!({
                "base_customer_balance_amount": "",
                "base_gift_cards_amount": "",
                "customer_balance_amount": "",
                "gift_cards_amount": "",
                "gw_base_price": "",
                "gw_base_tax_amount": "",
                "gw_card_base_price": "",
                "gw_card_base_tax_amount": "",
                "gw_card_price": "",
                "gw_card_tax_amount": "",
                "gw_items_base_price": "",
                "gw_items_base_tax_amount": "",
                "gw_items_price": "",
                "gw_items_tax_amount": "",
                "gw_price": "",
                "gw_tax_amount": ""
            }),
            "global_currency_code": "",
            "grand_total": "",
            "increment_id": "",
            "invoice_id": 0,
            "items": (
                json!({
                    "additional_data": "",
                    "base_cost": "",
                    "base_discount_amount": "",
                    "base_discount_tax_compensation_amount": "",
                    "base_price": "",
                    "base_price_incl_tax": "",
                    "base_row_total": "",
                    "base_row_total_incl_tax": "",
                    "base_tax_amount": "",
                    "base_weee_tax_applied_amount": "",
                    "base_weee_tax_applied_row_amnt": "",
                    "base_weee_tax_disposition": "",
                    "base_weee_tax_row_disposition": "",
                    "description": "",
                    "discount_amount": "",
                    "discount_tax_compensation_amount": "",
                    "entity_id": 0,
                    "extension_attributes": json!({
                        "invoice_text_codes": (),
                        "tax_codes": (),
                        "vertex_tax_codes": ()
                    }),
                    "name": "",
                    "order_item_id": 0,
                    "parent_id": 0,
                    "price": "",
                    "price_incl_tax": "",
                    "product_id": 0,
                    "qty": "",
                    "row_total": "",
                    "row_total_incl_tax": "",
                    "sku": "",
                    "tax_amount": "",
                    "weee_tax_applied": "",
                    "weee_tax_applied_amount": "",
                    "weee_tax_applied_row_amount": "",
                    "weee_tax_disposition": "",
                    "weee_tax_row_disposition": ""
                })
            ),
            "order_currency_code": "",
            "order_id": 0,
            "shipping_address_id": 0,
            "shipping_amount": "",
            "shipping_discount_tax_compensation_amount": "",
            "shipping_incl_tax": "",
            "shipping_tax_amount": "",
            "state": 0,
            "store_currency_code": "",
            "store_id": 0,
            "store_to_base_rate": "",
            "store_to_order_rate": "",
            "subtotal": "",
            "subtotal_incl_tax": "",
            "tax_amount": "",
            "transaction_id": "",
            "updated_at": ""
        }),
        "offlineRequested": false
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/creditmemo/refund \
  --header 'content-type: application/json' \
  --data '{
  "creditmemo": {
    "adjustment": "",
    "adjustment_negative": "",
    "adjustment_positive": "",
    "base_adjustment": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "creditmemo_status": 0,
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": ""
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "invoice_id": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "base_weee_tax_applied_amount": "",
        "base_weee_tax_applied_row_amnt": "",
        "base_weee_tax_disposition": "",
        "base_weee_tax_row_disposition": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": "",
        "weee_tax_applied": "",
        "weee_tax_applied_amount": "",
        "weee_tax_applied_row_amount": "",
        "weee_tax_disposition": "",
        "weee_tax_row_disposition": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "transaction_id": "",
    "updated_at": ""
  },
  "offlineRequested": false
}'
echo '{
  "creditmemo": {
    "adjustment": "",
    "adjustment_negative": "",
    "adjustment_positive": "",
    "base_adjustment": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "creditmemo_status": 0,
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": ""
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "invoice_id": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "base_weee_tax_applied_amount": "",
        "base_weee_tax_applied_row_amnt": "",
        "base_weee_tax_disposition": "",
        "base_weee_tax_row_disposition": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": "",
        "weee_tax_applied": "",
        "weee_tax_applied_amount": "",
        "weee_tax_applied_row_amount": "",
        "weee_tax_disposition": "",
        "weee_tax_row_disposition": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "transaction_id": "",
    "updated_at": ""
  },
  "offlineRequested": false
}' |  \
  http POST {{baseUrl}}/V1/creditmemo/refund \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "creditmemo": {\n    "adjustment": "",\n    "adjustment_negative": "",\n    "adjustment_positive": "",\n    "base_adjustment": "",\n    "base_adjustment_negative": "",\n    "base_adjustment_positive": "",\n    "base_currency_code": "",\n    "base_discount_amount": "",\n    "base_discount_tax_compensation_amount": "",\n    "base_grand_total": "",\n    "base_shipping_amount": "",\n    "base_shipping_discount_tax_compensation_amnt": "",\n    "base_shipping_incl_tax": "",\n    "base_shipping_tax_amount": "",\n    "base_subtotal": "",\n    "base_subtotal_incl_tax": "",\n    "base_tax_amount": "",\n    "base_to_global_rate": "",\n    "base_to_order_rate": "",\n    "billing_address_id": 0,\n    "comments": [\n      {\n        "comment": "",\n        "created_at": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "is_customer_notified": 0,\n        "is_visible_on_front": 0,\n        "parent_id": 0\n      }\n    ],\n    "created_at": "",\n    "creditmemo_status": 0,\n    "discount_amount": "",\n    "discount_description": "",\n    "discount_tax_compensation_amount": "",\n    "email_sent": 0,\n    "entity_id": 0,\n    "extension_attributes": {\n      "base_customer_balance_amount": "",\n      "base_gift_cards_amount": "",\n      "customer_balance_amount": "",\n      "gift_cards_amount": "",\n      "gw_base_price": "",\n      "gw_base_tax_amount": "",\n      "gw_card_base_price": "",\n      "gw_card_base_tax_amount": "",\n      "gw_card_price": "",\n      "gw_card_tax_amount": "",\n      "gw_items_base_price": "",\n      "gw_items_base_tax_amount": "",\n      "gw_items_price": "",\n      "gw_items_tax_amount": "",\n      "gw_price": "",\n      "gw_tax_amount": ""\n    },\n    "global_currency_code": "",\n    "grand_total": "",\n    "increment_id": "",\n    "invoice_id": 0,\n    "items": [\n      {\n        "additional_data": "",\n        "base_cost": "",\n        "base_discount_amount": "",\n        "base_discount_tax_compensation_amount": "",\n        "base_price": "",\n        "base_price_incl_tax": "",\n        "base_row_total": "",\n        "base_row_total_incl_tax": "",\n        "base_tax_amount": "",\n        "base_weee_tax_applied_amount": "",\n        "base_weee_tax_applied_row_amnt": "",\n        "base_weee_tax_disposition": "",\n        "base_weee_tax_row_disposition": "",\n        "description": "",\n        "discount_amount": "",\n        "discount_tax_compensation_amount": "",\n        "entity_id": 0,\n        "extension_attributes": {\n          "invoice_text_codes": [],\n          "tax_codes": [],\n          "vertex_tax_codes": []\n        },\n        "name": "",\n        "order_item_id": 0,\n        "parent_id": 0,\n        "price": "",\n        "price_incl_tax": "",\n        "product_id": 0,\n        "qty": "",\n        "row_total": "",\n        "row_total_incl_tax": "",\n        "sku": "",\n        "tax_amount": "",\n        "weee_tax_applied": "",\n        "weee_tax_applied_amount": "",\n        "weee_tax_applied_row_amount": "",\n        "weee_tax_disposition": "",\n        "weee_tax_row_disposition": ""\n      }\n    ],\n    "order_currency_code": "",\n    "order_id": 0,\n    "shipping_address_id": 0,\n    "shipping_amount": "",\n    "shipping_discount_tax_compensation_amount": "",\n    "shipping_incl_tax": "",\n    "shipping_tax_amount": "",\n    "state": 0,\n    "store_currency_code": "",\n    "store_id": 0,\n    "store_to_base_rate": "",\n    "store_to_order_rate": "",\n    "subtotal": "",\n    "subtotal_incl_tax": "",\n    "tax_amount": "",\n    "transaction_id": "",\n    "updated_at": ""\n  },\n  "offlineRequested": false\n}' \
  --output-document \
  - {{baseUrl}}/V1/creditmemo/refund
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "creditmemo": [
    "adjustment": "",
    "adjustment_negative": "",
    "adjustment_positive": "",
    "base_adjustment": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "billing_address_id": 0,
    "comments": [
      [
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": [],
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      ]
    ],
    "created_at": "",
    "creditmemo_status": 0,
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": [
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": ""
    ],
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "invoice_id": 0,
    "items": [
      [
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "base_weee_tax_applied_amount": "",
        "base_weee_tax_applied_row_amnt": "",
        "base_weee_tax_disposition": "",
        "base_weee_tax_row_disposition": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": [
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        ],
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": "",
        "weee_tax_applied": "",
        "weee_tax_applied_amount": "",
        "weee_tax_applied_row_amount": "",
        "weee_tax_disposition": "",
        "weee_tax_row_disposition": ""
      ]
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "transaction_id": "",
    "updated_at": ""
  ],
  "offlineRequested": false
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/creditmemo/refund")! 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 creditmemos
{{baseUrl}}/V1/creditmemos
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/creditmemos");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/creditmemos")
require "http/client"

url = "{{baseUrl}}/V1/creditmemos"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/creditmemos"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/creditmemos");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/creditmemos"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/creditmemos HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/creditmemos")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/creditmemos"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/creditmemos")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/creditmemos")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/creditmemos');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/creditmemos'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/creditmemos';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/creditmemos',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/creditmemos")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/creditmemos',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/creditmemos'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/creditmemos');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/creditmemos'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/creditmemos';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/creditmemos"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/creditmemos" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/creditmemos",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/creditmemos');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/creditmemos');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/creditmemos');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/creditmemos' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/creditmemos' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/creditmemos")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/creditmemos"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/creditmemos"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/creditmemos")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/creditmemos') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/creditmemos";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/creditmemos
http GET {{baseUrl}}/V1/creditmemos
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/creditmemos
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/creditmemos")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST customerGroups
{{baseUrl}}/V1/customerGroups
BODY json

{
  "group": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "tax_class_id": 0,
    "tax_class_name": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customerGroups");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/customerGroups" {:content-type :json
                                                              :form-params {:group {:code ""
                                                                                    :extension_attributes {}
                                                                                    :id 0
                                                                                    :tax_class_id 0
                                                                                    :tax_class_name ""}}})
require "http/client"

url = "{{baseUrl}}/V1/customerGroups"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\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}}/V1/customerGroups"),
    Content = new StringContent("{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\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}}/V1/customerGroups");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customerGroups"

	payload := strings.NewReader("{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/customerGroups HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 129

{
  "group": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "tax_class_id": 0,
    "tax_class_name": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/customerGroups")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customerGroups"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\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  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/customerGroups")
  .header("content-type", "application/json")
  .body("{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  group: {
    code: '',
    extension_attributes: {},
    id: 0,
    tax_class_id: 0,
    tax_class_name: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/customerGroups');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/customerGroups',
  headers: {'content-type': 'application/json'},
  data: {
    group: {code: '', extension_attributes: {}, id: 0, tax_class_id: 0, tax_class_name: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customerGroups';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"group":{"code":"","extension_attributes":{},"id":0,"tax_class_id":0,"tax_class_name":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customerGroups',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "group": {\n    "code": "",\n    "extension_attributes": {},\n    "id": 0,\n    "tax_class_id": 0,\n    "tax_class_name": ""\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  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customerGroups',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  group: {code: '', extension_attributes: {}, id: 0, tax_class_id: 0, tax_class_name: ''}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/customerGroups',
  headers: {'content-type': 'application/json'},
  body: {
    group: {code: '', extension_attributes: {}, id: 0, tax_class_id: 0, tax_class_name: ''}
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/customerGroups');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  group: {
    code: '',
    extension_attributes: {},
    id: 0,
    tax_class_id: 0,
    tax_class_name: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/customerGroups',
  headers: {'content-type': 'application/json'},
  data: {
    group: {code: '', extension_attributes: {}, id: 0, tax_class_id: 0, tax_class_name: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customerGroups';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"group":{"code":"","extension_attributes":{},"id":0,"tax_class_id":0,"tax_class_name":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"group": @{ @"code": @"", @"extension_attributes": @{  }, @"id": @0, @"tax_class_id": @0, @"tax_class_name": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customerGroups"]
                                                       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}}/V1/customerGroups" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customerGroups",
  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([
    'group' => [
        'code' => '',
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'tax_class_id' => 0,
        'tax_class_name' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/customerGroups', [
  'body' => '{
  "group": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "tax_class_id": 0,
    "tax_class_name": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customerGroups');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'group' => [
    'code' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'tax_class_id' => 0,
    'tax_class_name' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'group' => [
    'code' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'tax_class_id' => 0,
    'tax_class_name' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/customerGroups');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customerGroups' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "group": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "tax_class_id": 0,
    "tax_class_name": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customerGroups' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "group": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "tax_class_id": 0,
    "tax_class_name": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/customerGroups", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customerGroups"

payload = { "group": {
        "code": "",
        "extension_attributes": {},
        "id": 0,
        "tax_class_id": 0,
        "tax_class_name": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customerGroups"

payload <- "{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customerGroups")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\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/V1/customerGroups') do |req|
  req.body = "{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customerGroups";

    let payload = json!({"group": json!({
            "code": "",
            "extension_attributes": json!({}),
            "id": 0,
            "tax_class_id": 0,
            "tax_class_name": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/customerGroups \
  --header 'content-type: application/json' \
  --data '{
  "group": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "tax_class_id": 0,
    "tax_class_name": ""
  }
}'
echo '{
  "group": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "tax_class_id": 0,
    "tax_class_name": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/customerGroups \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "group": {\n    "code": "",\n    "extension_attributes": {},\n    "id": 0,\n    "tax_class_id": 0,\n    "tax_class_name": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/customerGroups
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["group": [
    "code": "",
    "extension_attributes": [],
    "id": 0,
    "tax_class_id": 0,
    "tax_class_name": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customerGroups")! 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 customerGroups-{id} (GET)
{{baseUrl}}/V1/customerGroups/:id
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customerGroups/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/customerGroups/:id")
require "http/client"

url = "{{baseUrl}}/V1/customerGroups/:id"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/customerGroups/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customerGroups/:id");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customerGroups/:id"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/customerGroups/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/customerGroups/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customerGroups/:id"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups/:id")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/customerGroups/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/customerGroups/:id');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/customerGroups/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customerGroups/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customerGroups/:id',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups/:id")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customerGroups/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/customerGroups/:id'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/customerGroups/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/customerGroups/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customerGroups/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customerGroups/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customerGroups/:id" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customerGroups/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/customerGroups/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customerGroups/:id');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customerGroups/:id');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customerGroups/:id' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customerGroups/:id' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/customerGroups/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customerGroups/:id"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customerGroups/:id"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customerGroups/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/customerGroups/:id') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customerGroups/:id";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/customerGroups/:id
http GET {{baseUrl}}/V1/customerGroups/:id
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/customerGroups/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customerGroups/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT customerGroups-{id} (PUT)
{{baseUrl}}/V1/customerGroups/:id
QUERY PARAMS

id
BODY json

{
  "group": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "tax_class_id": 0,
    "tax_class_name": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customerGroups/:id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/customerGroups/:id" {:content-type :json
                                                                 :form-params {:group {:code ""
                                                                                       :extension_attributes {}
                                                                                       :id 0
                                                                                       :tax_class_id 0
                                                                                       :tax_class_name ""}}})
require "http/client"

url = "{{baseUrl}}/V1/customerGroups/:id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\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}}/V1/customerGroups/:id"),
    Content = new StringContent("{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\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}}/V1/customerGroups/:id");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customerGroups/:id"

	payload := strings.NewReader("{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/customerGroups/:id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 129

{
  "group": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "tax_class_id": 0,
    "tax_class_name": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/customerGroups/:id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customerGroups/:id"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\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  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/customerGroups/:id")
  .header("content-type", "application/json")
  .body("{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  group: {
    code: '',
    extension_attributes: {},
    id: 0,
    tax_class_id: 0,
    tax_class_name: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/customerGroups/:id');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customerGroups/:id',
  headers: {'content-type': 'application/json'},
  data: {
    group: {code: '', extension_attributes: {}, id: 0, tax_class_id: 0, tax_class_name: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customerGroups/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"group":{"code":"","extension_attributes":{},"id":0,"tax_class_id":0,"tax_class_name":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customerGroups/:id',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "group": {\n    "code": "",\n    "extension_attributes": {},\n    "id": 0,\n    "tax_class_id": 0,\n    "tax_class_name": ""\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  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customerGroups/:id',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  group: {code: '', extension_attributes: {}, id: 0, tax_class_id: 0, tax_class_name: ''}
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customerGroups/:id',
  headers: {'content-type': 'application/json'},
  body: {
    group: {code: '', extension_attributes: {}, id: 0, tax_class_id: 0, tax_class_name: ''}
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/customerGroups/:id');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  group: {
    code: '',
    extension_attributes: {},
    id: 0,
    tax_class_id: 0,
    tax_class_name: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customerGroups/:id',
  headers: {'content-type': 'application/json'},
  data: {
    group: {code: '', extension_attributes: {}, id: 0, tax_class_id: 0, tax_class_name: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customerGroups/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"group":{"code":"","extension_attributes":{},"id":0,"tax_class_id":0,"tax_class_name":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"group": @{ @"code": @"", @"extension_attributes": @{  }, @"id": @0, @"tax_class_id": @0, @"tax_class_name": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customerGroups/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customerGroups/:id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customerGroups/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'group' => [
        'code' => '',
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'tax_class_id' => 0,
        'tax_class_name' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/customerGroups/:id', [
  'body' => '{
  "group": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "tax_class_id": 0,
    "tax_class_name": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customerGroups/:id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'group' => [
    'code' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'tax_class_id' => 0,
    'tax_class_name' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'group' => [
    'code' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'tax_class_id' => 0,
    'tax_class_name' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/customerGroups/:id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customerGroups/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "group": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "tax_class_id": 0,
    "tax_class_name": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customerGroups/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "group": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "tax_class_id": 0,
    "tax_class_name": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/customerGroups/:id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customerGroups/:id"

payload = { "group": {
        "code": "",
        "extension_attributes": {},
        "id": 0,
        "tax_class_id": 0,
        "tax_class_name": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customerGroups/:id"

payload <- "{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customerGroups/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\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/V1/customerGroups/:id') do |req|
  req.body = "{\n  \"group\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"tax_class_id\": 0,\n    \"tax_class_name\": \"\"\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}}/V1/customerGroups/:id";

    let payload = json!({"group": json!({
            "code": "",
            "extension_attributes": json!({}),
            "id": 0,
            "tax_class_id": 0,
            "tax_class_name": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/customerGroups/:id \
  --header 'content-type: application/json' \
  --data '{
  "group": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "tax_class_id": 0,
    "tax_class_name": ""
  }
}'
echo '{
  "group": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "tax_class_id": 0,
    "tax_class_name": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/customerGroups/:id \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "group": {\n    "code": "",\n    "extension_attributes": {},\n    "id": 0,\n    "tax_class_id": 0,\n    "tax_class_name": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/customerGroups/:id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["group": [
    "code": "",
    "extension_attributes": [],
    "id": 0,
    "tax_class_id": 0,
    "tax_class_name": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customerGroups/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE customerGroups-{id}
{{baseUrl}}/V1/customerGroups/:id
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customerGroups/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/customerGroups/:id")
require "http/client"

url = "{{baseUrl}}/V1/customerGroups/:id"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/customerGroups/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customerGroups/:id");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customerGroups/:id"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/customerGroups/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/customerGroups/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customerGroups/:id"))
    .method("DELETE", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups/:id")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/customerGroups/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/V1/customerGroups/:id');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/customerGroups/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customerGroups/:id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customerGroups/:id',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups/:id")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customerGroups/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/customerGroups/:id'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/customerGroups/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/customerGroups/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customerGroups/:id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customerGroups/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customerGroups/:id" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customerGroups/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/customerGroups/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customerGroups/:id');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customerGroups/:id');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customerGroups/:id' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customerGroups/:id' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/customerGroups/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customerGroups/:id"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customerGroups/:id"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customerGroups/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/customerGroups/:id') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customerGroups/:id";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/customerGroups/:id
http DELETE {{baseUrl}}/V1/customerGroups/:id
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/customerGroups/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customerGroups/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET customerGroups-{id}-permissions
{{baseUrl}}/V1/customerGroups/:id/permissions
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customerGroups/:id/permissions");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/customerGroups/:id/permissions")
require "http/client"

url = "{{baseUrl}}/V1/customerGroups/:id/permissions"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/customerGroups/:id/permissions"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customerGroups/:id/permissions");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customerGroups/:id/permissions"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/customerGroups/:id/permissions HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/customerGroups/:id/permissions")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customerGroups/:id/permissions"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups/:id/permissions")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/customerGroups/:id/permissions")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/customerGroups/:id/permissions');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customerGroups/:id/permissions'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customerGroups/:id/permissions';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customerGroups/:id/permissions',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups/:id/permissions")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customerGroups/:id/permissions',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customerGroups/:id/permissions'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/customerGroups/:id/permissions');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customerGroups/:id/permissions'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customerGroups/:id/permissions';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customerGroups/:id/permissions"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customerGroups/:id/permissions" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customerGroups/:id/permissions",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/customerGroups/:id/permissions');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customerGroups/:id/permissions');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customerGroups/:id/permissions');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customerGroups/:id/permissions' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customerGroups/:id/permissions' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/customerGroups/:id/permissions")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customerGroups/:id/permissions"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customerGroups/:id/permissions"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customerGroups/:id/permissions")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/customerGroups/:id/permissions') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customerGroups/:id/permissions";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/customerGroups/:id/permissions
http GET {{baseUrl}}/V1/customerGroups/:id/permissions
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/customerGroups/:id/permissions
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customerGroups/:id/permissions")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET customerGroups-default
{{baseUrl}}/V1/customerGroups/default
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customerGroups/default");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/customerGroups/default")
require "http/client"

url = "{{baseUrl}}/V1/customerGroups/default"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/customerGroups/default"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customerGroups/default");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customerGroups/default"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/customerGroups/default HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/customerGroups/default")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customerGroups/default"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups/default")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/customerGroups/default")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/customerGroups/default');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/customerGroups/default'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customerGroups/default';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customerGroups/default',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups/default")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customerGroups/default',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/customerGroups/default'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/customerGroups/default');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/customerGroups/default'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customerGroups/default';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customerGroups/default"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customerGroups/default" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customerGroups/default",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/customerGroups/default');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customerGroups/default');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customerGroups/default');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customerGroups/default' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customerGroups/default' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/customerGroups/default")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customerGroups/default"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customerGroups/default"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customerGroups/default")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/customerGroups/default') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customerGroups/default";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/customerGroups/default
http GET {{baseUrl}}/V1/customerGroups/default
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/customerGroups/default
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customerGroups/default")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT customerGroups-default-{id}
{{baseUrl}}/V1/customerGroups/default/:id
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customerGroups/default/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/customerGroups/default/:id")
require "http/client"

url = "{{baseUrl}}/V1/customerGroups/default/:id"

response = HTTP::Client.put url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/V1/customerGroups/default/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customerGroups/default/:id");
var request = new RestRequest("", Method.Put);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customerGroups/default/:id"

	req, _ := http.NewRequest("PUT", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/customerGroups/default/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/customerGroups/default/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customerGroups/default/:id"))
    .method("PUT", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups/default/:id")
  .put(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/customerGroups/default/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/customerGroups/default/:id');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customerGroups/default/:id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customerGroups/default/:id';
const options = {method: 'PUT'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customerGroups/default/:id',
  method: 'PUT',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups/default/:id")
  .put(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customerGroups/default/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customerGroups/default/:id'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/customerGroups/default/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customerGroups/default/:id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customerGroups/default/:id';
const options = {method: 'PUT'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customerGroups/default/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customerGroups/default/:id" in

Client.call `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customerGroups/default/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/customerGroups/default/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customerGroups/default/:id');
$request->setMethod(HTTP_METH_PUT);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customerGroups/default/:id');
$request->setRequestMethod('PUT');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customerGroups/default/:id' -Method PUT 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customerGroups/default/:id' -Method PUT 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("PUT", "/baseUrl/V1/customerGroups/default/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customerGroups/default/:id"

response = requests.put(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customerGroups/default/:id"

response <- VERB("PUT", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customerGroups/default/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/V1/customerGroups/default/:id') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customerGroups/default/:id";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/customerGroups/default/:id
http PUT {{baseUrl}}/V1/customerGroups/default/:id
wget --quiet \
  --method PUT \
  --output-document \
  - {{baseUrl}}/V1/customerGroups/default/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customerGroups/default/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET customerGroups-default-{storeId}
{{baseUrl}}/V1/customerGroups/default/:storeId
QUERY PARAMS

storeId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customerGroups/default/:storeId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/customerGroups/default/:storeId")
require "http/client"

url = "{{baseUrl}}/V1/customerGroups/default/:storeId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/customerGroups/default/:storeId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customerGroups/default/:storeId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customerGroups/default/:storeId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/customerGroups/default/:storeId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/customerGroups/default/:storeId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customerGroups/default/:storeId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups/default/:storeId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/customerGroups/default/:storeId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/customerGroups/default/:storeId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customerGroups/default/:storeId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customerGroups/default/:storeId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customerGroups/default/:storeId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups/default/:storeId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customerGroups/default/:storeId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customerGroups/default/:storeId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/customerGroups/default/:storeId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customerGroups/default/:storeId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customerGroups/default/:storeId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customerGroups/default/:storeId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customerGroups/default/:storeId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customerGroups/default/:storeId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/customerGroups/default/:storeId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customerGroups/default/:storeId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customerGroups/default/:storeId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customerGroups/default/:storeId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customerGroups/default/:storeId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/customerGroups/default/:storeId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customerGroups/default/:storeId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customerGroups/default/:storeId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customerGroups/default/:storeId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/customerGroups/default/:storeId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customerGroups/default/:storeId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/customerGroups/default/:storeId
http GET {{baseUrl}}/V1/customerGroups/default/:storeId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/customerGroups/default/:storeId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customerGroups/default/:storeId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customerGroups/search");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/customerGroups/search")
require "http/client"

url = "{{baseUrl}}/V1/customerGroups/search"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/customerGroups/search"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customerGroups/search");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customerGroups/search"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/customerGroups/search HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/customerGroups/search")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customerGroups/search"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups/search")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/customerGroups/search")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/customerGroups/search');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/customerGroups/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customerGroups/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customerGroups/search',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customerGroups/search")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customerGroups/search',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/customerGroups/search'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/customerGroups/search');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/customerGroups/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customerGroups/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customerGroups/search"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customerGroups/search" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customerGroups/search",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/customerGroups/search');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customerGroups/search');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customerGroups/search');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customerGroups/search' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customerGroups/search' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/customerGroups/search")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customerGroups/search"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customerGroups/search"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customerGroups/search")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/customerGroups/search') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customerGroups/search";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/customerGroups/search
http GET {{baseUrl}}/V1/customerGroups/search
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/customerGroups/search
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customerGroups/search")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST customers
{{baseUrl}}/V1/customers
BODY json

{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "password": "",
  "redirectUrl": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"password\": \"\",\n  \"redirectUrl\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/customers" {:content-type :json
                                                         :form-params {:customer {:addresses [{:city ""
                                                                                               :company ""
                                                                                               :country_id ""
                                                                                               :custom_attributes [{:attribute_code ""
                                                                                                                    :value ""}]
                                                                                               :customer_id 0
                                                                                               :default_billing false
                                                                                               :default_shipping false
                                                                                               :extension_attributes {}
                                                                                               :fax ""
                                                                                               :firstname ""
                                                                                               :id 0
                                                                                               :lastname ""
                                                                                               :middlename ""
                                                                                               :postcode ""
                                                                                               :prefix ""
                                                                                               :region {:extension_attributes {}
                                                                                                        :region ""
                                                                                                        :region_code ""
                                                                                                        :region_id 0}
                                                                                               :region_id 0
                                                                                               :street []
                                                                                               :suffix ""
                                                                                               :telephone ""
                                                                                               :vat_id ""}]
                                                                                  :confirmation ""
                                                                                  :created_at ""
                                                                                  :created_in ""
                                                                                  :custom_attributes [{}]
                                                                                  :default_billing ""
                                                                                  :default_shipping ""
                                                                                  :disable_auto_group_change 0
                                                                                  :dob ""
                                                                                  :email ""
                                                                                  :extension_attributes {:amazon_id ""
                                                                                                         :company_attributes {:company_id 0
                                                                                                                              :customer_id 0
                                                                                                                              :extension_attributes {}
                                                                                                                              :job_title ""
                                                                                                                              :status 0
                                                                                                                              :telephone ""}
                                                                                                         :is_subscribed false
                                                                                                         :vertex_customer_code ""}
                                                                                  :firstname ""
                                                                                  :gender 0
                                                                                  :group_id 0
                                                                                  :id 0
                                                                                  :lastname ""
                                                                                  :middlename ""
                                                                                  :prefix ""
                                                                                  :store_id 0
                                                                                  :suffix ""
                                                                                  :taxvat ""
                                                                                  :updated_at ""
                                                                                  :website_id 0}
                                                                       :password ""
                                                                       :redirectUrl ""}})
require "http/client"

url = "{{baseUrl}}/V1/customers"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"password\": \"\",\n  \"redirectUrl\": \"\"\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}}/V1/customers"),
    Content = new StringContent("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"password\": \"\",\n  \"redirectUrl\": \"\"\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}}/V1/customers");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"password\": \"\",\n  \"redirectUrl\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers"

	payload := strings.NewReader("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"password\": \"\",\n  \"redirectUrl\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/customers HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1626

{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "password": "",
  "redirectUrl": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/customers")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"password\": \"\",\n  \"redirectUrl\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"password\": \"\",\n  \"redirectUrl\": \"\"\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  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"password\": \"\",\n  \"redirectUrl\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/customers")
  .header("content-type", "application/json")
  .body("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"password\": \"\",\n  \"redirectUrl\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  customer: {
    addresses: [
      {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [
          {
            attribute_code: '',
            value: ''
          }
        ],
        customer_id: 0,
        default_billing: false,
        default_shipping: false,
        extension_attributes: {},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: {
          extension_attributes: {},
          region: '',
          region_code: '',
          region_id: 0
        },
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      }
    ],
    confirmation: '',
    created_at: '',
    created_in: '',
    custom_attributes: [
      {}
    ],
    default_billing: '',
    default_shipping: '',
    disable_auto_group_change: 0,
    dob: '',
    email: '',
    extension_attributes: {
      amazon_id: '',
      company_attributes: {
        company_id: 0,
        customer_id: 0,
        extension_attributes: {},
        job_title: '',
        status: 0,
        telephone: ''
      },
      is_subscribed: false,
      vertex_customer_code: ''
    },
    firstname: '',
    gender: 0,
    group_id: 0,
    id: 0,
    lastname: '',
    middlename: '',
    prefix: '',
    store_id: 0,
    suffix: '',
    taxvat: '',
    updated_at: '',
    website_id: 0
  },
  password: '',
  redirectUrl: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/customers');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/customers',
  headers: {'content-type': 'application/json'},
  data: {
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [{}],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_id: 0
    },
    password: '',
    redirectUrl: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"customer":{"addresses":[{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_id":0,"default_billing":false,"default_shipping":false,"extension_attributes":{},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":{"extension_attributes":{},"region":"","region_code":"","region_id":0},"region_id":0,"street":[],"suffix":"","telephone":"","vat_id":""}],"confirmation":"","created_at":"","created_in":"","custom_attributes":[{}],"default_billing":"","default_shipping":"","disable_auto_group_change":0,"dob":"","email":"","extension_attributes":{"amazon_id":"","company_attributes":{"company_id":0,"customer_id":0,"extension_attributes":{},"job_title":"","status":0,"telephone":""},"is_subscribed":false,"vertex_customer_code":""},"firstname":"","gender":0,"group_id":0,"id":0,"lastname":"","middlename":"","prefix":"","store_id":0,"suffix":"","taxvat":"","updated_at":"","website_id":0},"password":"","redirectUrl":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "customer": {\n    "addresses": [\n      {\n        "city": "",\n        "company": "",\n        "country_id": "",\n        "custom_attributes": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ],\n        "customer_id": 0,\n        "default_billing": false,\n        "default_shipping": false,\n        "extension_attributes": {},\n        "fax": "",\n        "firstname": "",\n        "id": 0,\n        "lastname": "",\n        "middlename": "",\n        "postcode": "",\n        "prefix": "",\n        "region": {\n          "extension_attributes": {},\n          "region": "",\n          "region_code": "",\n          "region_id": 0\n        },\n        "region_id": 0,\n        "street": [],\n        "suffix": "",\n        "telephone": "",\n        "vat_id": ""\n      }\n    ],\n    "confirmation": "",\n    "created_at": "",\n    "created_in": "",\n    "custom_attributes": [\n      {}\n    ],\n    "default_billing": "",\n    "default_shipping": "",\n    "disable_auto_group_change": 0,\n    "dob": "",\n    "email": "",\n    "extension_attributes": {\n      "amazon_id": "",\n      "company_attributes": {\n        "company_id": 0,\n        "customer_id": 0,\n        "extension_attributes": {},\n        "job_title": "",\n        "status": 0,\n        "telephone": ""\n      },\n      "is_subscribed": false,\n      "vertex_customer_code": ""\n    },\n    "firstname": "",\n    "gender": 0,\n    "group_id": 0,\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "prefix": "",\n    "store_id": 0,\n    "suffix": "",\n    "taxvat": "",\n    "updated_at": "",\n    "website_id": 0\n  },\n  "password": "",\n  "redirectUrl": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"password\": \"\",\n  \"redirectUrl\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  customer: {
    addresses: [
      {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_id: 0,
        default_billing: false,
        default_shipping: false,
        extension_attributes: {},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      }
    ],
    confirmation: '',
    created_at: '',
    created_in: '',
    custom_attributes: [{}],
    default_billing: '',
    default_shipping: '',
    disable_auto_group_change: 0,
    dob: '',
    email: '',
    extension_attributes: {
      amazon_id: '',
      company_attributes: {
        company_id: 0,
        customer_id: 0,
        extension_attributes: {},
        job_title: '',
        status: 0,
        telephone: ''
      },
      is_subscribed: false,
      vertex_customer_code: ''
    },
    firstname: '',
    gender: 0,
    group_id: 0,
    id: 0,
    lastname: '',
    middlename: '',
    prefix: '',
    store_id: 0,
    suffix: '',
    taxvat: '',
    updated_at: '',
    website_id: 0
  },
  password: '',
  redirectUrl: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/customers',
  headers: {'content-type': 'application/json'},
  body: {
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [{}],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_id: 0
    },
    password: '',
    redirectUrl: ''
  },
  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}}/V1/customers');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  customer: {
    addresses: [
      {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [
          {
            attribute_code: '',
            value: ''
          }
        ],
        customer_id: 0,
        default_billing: false,
        default_shipping: false,
        extension_attributes: {},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: {
          extension_attributes: {},
          region: '',
          region_code: '',
          region_id: 0
        },
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      }
    ],
    confirmation: '',
    created_at: '',
    created_in: '',
    custom_attributes: [
      {}
    ],
    default_billing: '',
    default_shipping: '',
    disable_auto_group_change: 0,
    dob: '',
    email: '',
    extension_attributes: {
      amazon_id: '',
      company_attributes: {
        company_id: 0,
        customer_id: 0,
        extension_attributes: {},
        job_title: '',
        status: 0,
        telephone: ''
      },
      is_subscribed: false,
      vertex_customer_code: ''
    },
    firstname: '',
    gender: 0,
    group_id: 0,
    id: 0,
    lastname: '',
    middlename: '',
    prefix: '',
    store_id: 0,
    suffix: '',
    taxvat: '',
    updated_at: '',
    website_id: 0
  },
  password: '',
  redirectUrl: ''
});

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}}/V1/customers',
  headers: {'content-type': 'application/json'},
  data: {
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [{}],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_id: 0
    },
    password: '',
    redirectUrl: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"customer":{"addresses":[{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_id":0,"default_billing":false,"default_shipping":false,"extension_attributes":{},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":{"extension_attributes":{},"region":"","region_code":"","region_id":0},"region_id":0,"street":[],"suffix":"","telephone":"","vat_id":""}],"confirmation":"","created_at":"","created_in":"","custom_attributes":[{}],"default_billing":"","default_shipping":"","disable_auto_group_change":0,"dob":"","email":"","extension_attributes":{"amazon_id":"","company_attributes":{"company_id":0,"customer_id":0,"extension_attributes":{},"job_title":"","status":0,"telephone":""},"is_subscribed":false,"vertex_customer_code":""},"firstname":"","gender":0,"group_id":0,"id":0,"lastname":"","middlename":"","prefix":"","store_id":0,"suffix":"","taxvat":"","updated_at":"","website_id":0},"password":"","redirectUrl":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"customer": @{ @"addresses": @[ @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_id": @0, @"default_billing": @NO, @"default_shipping": @NO, @"extension_attributes": @{  }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @{ @"extension_attributes": @{  }, @"region": @"", @"region_code": @"", @"region_id": @0 }, @"region_id": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" } ], @"confirmation": @"", @"created_at": @"", @"created_in": @"", @"custom_attributes": @[ @{  } ], @"default_billing": @"", @"default_shipping": @"", @"disable_auto_group_change": @0, @"dob": @"", @"email": @"", @"extension_attributes": @{ @"amazon_id": @"", @"company_attributes": @{ @"company_id": @0, @"customer_id": @0, @"extension_attributes": @{  }, @"job_title": @"", @"status": @0, @"telephone": @"" }, @"is_subscribed": @NO, @"vertex_customer_code": @"" }, @"firstname": @"", @"gender": @0, @"group_id": @0, @"id": @0, @"lastname": @"", @"middlename": @"", @"prefix": @"", @"store_id": @0, @"suffix": @"", @"taxvat": @"", @"updated_at": @"", @"website_id": @0 },
                              @"password": @"",
                              @"redirectUrl": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers"]
                                                       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}}/V1/customers" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"password\": \"\",\n  \"redirectUrl\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers",
  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([
    'customer' => [
        'addresses' => [
                [
                                'city' => '',
                                'company' => '',
                                'country_id' => '',
                                'custom_attributes' => [
                                                                [
                                                                                                                                'attribute_code' => '',
                                                                                                                                'value' => ''
                                                                ]
                                ],
                                'customer_id' => 0,
                                'default_billing' => null,
                                'default_shipping' => null,
                                'extension_attributes' => [
                                                                
                                ],
                                'fax' => '',
                                'firstname' => '',
                                'id' => 0,
                                'lastname' => '',
                                'middlename' => '',
                                'postcode' => '',
                                'prefix' => '',
                                'region' => [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'region' => '',
                                                                'region_code' => '',
                                                                'region_id' => 0
                                ],
                                'region_id' => 0,
                                'street' => [
                                                                
                                ],
                                'suffix' => '',
                                'telephone' => '',
                                'vat_id' => ''
                ]
        ],
        'confirmation' => '',
        'created_at' => '',
        'created_in' => '',
        'custom_attributes' => [
                [
                                
                ]
        ],
        'default_billing' => '',
        'default_shipping' => '',
        'disable_auto_group_change' => 0,
        'dob' => '',
        'email' => '',
        'extension_attributes' => [
                'amazon_id' => '',
                'company_attributes' => [
                                'company_id' => 0,
                                'customer_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'job_title' => '',
                                'status' => 0,
                                'telephone' => ''
                ],
                'is_subscribed' => null,
                'vertex_customer_code' => ''
        ],
        'firstname' => '',
        'gender' => 0,
        'group_id' => 0,
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'prefix' => '',
        'store_id' => 0,
        'suffix' => '',
        'taxvat' => '',
        'updated_at' => '',
        'website_id' => 0
    ],
    'password' => '',
    'redirectUrl' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/customers', [
  'body' => '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "password": "",
  "redirectUrl": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'customer' => [
    'addresses' => [
        [
                'city' => '',
                'company' => '',
                'country_id' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_id' => 0,
                'default_billing' => null,
                'default_shipping' => null,
                'extension_attributes' => [
                                
                ],
                'fax' => '',
                'firstname' => '',
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'postcode' => '',
                'prefix' => '',
                'region' => [
                                'extension_attributes' => [
                                                                
                                ],
                                'region' => '',
                                'region_code' => '',
                                'region_id' => 0
                ],
                'region_id' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => ''
        ]
    ],
    'confirmation' => '',
    'created_at' => '',
    'created_in' => '',
    'custom_attributes' => [
        [
                
        ]
    ],
    'default_billing' => '',
    'default_shipping' => '',
    'disable_auto_group_change' => 0,
    'dob' => '',
    'email' => '',
    'extension_attributes' => [
        'amazon_id' => '',
        'company_attributes' => [
                'company_id' => 0,
                'customer_id' => 0,
                'extension_attributes' => [
                                
                ],
                'job_title' => '',
                'status' => 0,
                'telephone' => ''
        ],
        'is_subscribed' => null,
        'vertex_customer_code' => ''
    ],
    'firstname' => '',
    'gender' => 0,
    'group_id' => 0,
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'prefix' => '',
    'store_id' => 0,
    'suffix' => '',
    'taxvat' => '',
    'updated_at' => '',
    'website_id' => 0
  ],
  'password' => '',
  'redirectUrl' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'customer' => [
    'addresses' => [
        [
                'city' => '',
                'company' => '',
                'country_id' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_id' => 0,
                'default_billing' => null,
                'default_shipping' => null,
                'extension_attributes' => [
                                
                ],
                'fax' => '',
                'firstname' => '',
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'postcode' => '',
                'prefix' => '',
                'region' => [
                                'extension_attributes' => [
                                                                
                                ],
                                'region' => '',
                                'region_code' => '',
                                'region_id' => 0
                ],
                'region_id' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => ''
        ]
    ],
    'confirmation' => '',
    'created_at' => '',
    'created_in' => '',
    'custom_attributes' => [
        [
                
        ]
    ],
    'default_billing' => '',
    'default_shipping' => '',
    'disable_auto_group_change' => 0,
    'dob' => '',
    'email' => '',
    'extension_attributes' => [
        'amazon_id' => '',
        'company_attributes' => [
                'company_id' => 0,
                'customer_id' => 0,
                'extension_attributes' => [
                                
                ],
                'job_title' => '',
                'status' => 0,
                'telephone' => ''
        ],
        'is_subscribed' => null,
        'vertex_customer_code' => ''
    ],
    'firstname' => '',
    'gender' => 0,
    'group_id' => 0,
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'prefix' => '',
    'store_id' => 0,
    'suffix' => '',
    'taxvat' => '',
    'updated_at' => '',
    'website_id' => 0
  ],
  'password' => '',
  'redirectUrl' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/customers');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "password": "",
  "redirectUrl": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "password": "",
  "redirectUrl": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"password\": \"\",\n  \"redirectUrl\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/customers", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers"

payload = {
    "customer": {
        "addresses": [
            {
                "city": "",
                "company": "",
                "country_id": "",
                "custom_attributes": [
                    {
                        "attribute_code": "",
                        "value": ""
                    }
                ],
                "customer_id": 0,
                "default_billing": False,
                "default_shipping": False,
                "extension_attributes": {},
                "fax": "",
                "firstname": "",
                "id": 0,
                "lastname": "",
                "middlename": "",
                "postcode": "",
                "prefix": "",
                "region": {
                    "extension_attributes": {},
                    "region": "",
                    "region_code": "",
                    "region_id": 0
                },
                "region_id": 0,
                "street": [],
                "suffix": "",
                "telephone": "",
                "vat_id": ""
            }
        ],
        "confirmation": "",
        "created_at": "",
        "created_in": "",
        "custom_attributes": [{}],
        "default_billing": "",
        "default_shipping": "",
        "disable_auto_group_change": 0,
        "dob": "",
        "email": "",
        "extension_attributes": {
            "amazon_id": "",
            "company_attributes": {
                "company_id": 0,
                "customer_id": 0,
                "extension_attributes": {},
                "job_title": "",
                "status": 0,
                "telephone": ""
            },
            "is_subscribed": False,
            "vertex_customer_code": ""
        },
        "firstname": "",
        "gender": 0,
        "group_id": 0,
        "id": 0,
        "lastname": "",
        "middlename": "",
        "prefix": "",
        "store_id": 0,
        "suffix": "",
        "taxvat": "",
        "updated_at": "",
        "website_id": 0
    },
    "password": "",
    "redirectUrl": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers"

payload <- "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"password\": \"\",\n  \"redirectUrl\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"password\": \"\",\n  \"redirectUrl\": \"\"\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/V1/customers') do |req|
  req.body = "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"password\": \"\",\n  \"redirectUrl\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customers";

    let payload = json!({
        "customer": json!({
            "addresses": (
                json!({
                    "city": "",
                    "company": "",
                    "country_id": "",
                    "custom_attributes": (
                        json!({
                            "attribute_code": "",
                            "value": ""
                        })
                    ),
                    "customer_id": 0,
                    "default_billing": false,
                    "default_shipping": false,
                    "extension_attributes": json!({}),
                    "fax": "",
                    "firstname": "",
                    "id": 0,
                    "lastname": "",
                    "middlename": "",
                    "postcode": "",
                    "prefix": "",
                    "region": json!({
                        "extension_attributes": json!({}),
                        "region": "",
                        "region_code": "",
                        "region_id": 0
                    }),
                    "region_id": 0,
                    "street": (),
                    "suffix": "",
                    "telephone": "",
                    "vat_id": ""
                })
            ),
            "confirmation": "",
            "created_at": "",
            "created_in": "",
            "custom_attributes": (json!({})),
            "default_billing": "",
            "default_shipping": "",
            "disable_auto_group_change": 0,
            "dob": "",
            "email": "",
            "extension_attributes": json!({
                "amazon_id": "",
                "company_attributes": json!({
                    "company_id": 0,
                    "customer_id": 0,
                    "extension_attributes": json!({}),
                    "job_title": "",
                    "status": 0,
                    "telephone": ""
                }),
                "is_subscribed": false,
                "vertex_customer_code": ""
            }),
            "firstname": "",
            "gender": 0,
            "group_id": 0,
            "id": 0,
            "lastname": "",
            "middlename": "",
            "prefix": "",
            "store_id": 0,
            "suffix": "",
            "taxvat": "",
            "updated_at": "",
            "website_id": 0
        }),
        "password": "",
        "redirectUrl": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/customers \
  --header 'content-type: application/json' \
  --data '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "password": "",
  "redirectUrl": ""
}'
echo '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "password": "",
  "redirectUrl": ""
}' |  \
  http POST {{baseUrl}}/V1/customers \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "customer": {\n    "addresses": [\n      {\n        "city": "",\n        "company": "",\n        "country_id": "",\n        "custom_attributes": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ],\n        "customer_id": 0,\n        "default_billing": false,\n        "default_shipping": false,\n        "extension_attributes": {},\n        "fax": "",\n        "firstname": "",\n        "id": 0,\n        "lastname": "",\n        "middlename": "",\n        "postcode": "",\n        "prefix": "",\n        "region": {\n          "extension_attributes": {},\n          "region": "",\n          "region_code": "",\n          "region_id": 0\n        },\n        "region_id": 0,\n        "street": [],\n        "suffix": "",\n        "telephone": "",\n        "vat_id": ""\n      }\n    ],\n    "confirmation": "",\n    "created_at": "",\n    "created_in": "",\n    "custom_attributes": [\n      {}\n    ],\n    "default_billing": "",\n    "default_shipping": "",\n    "disable_auto_group_change": 0,\n    "dob": "",\n    "email": "",\n    "extension_attributes": {\n      "amazon_id": "",\n      "company_attributes": {\n        "company_id": 0,\n        "customer_id": 0,\n        "extension_attributes": {},\n        "job_title": "",\n        "status": 0,\n        "telephone": ""\n      },\n      "is_subscribed": false,\n      "vertex_customer_code": ""\n    },\n    "firstname": "",\n    "gender": 0,\n    "group_id": 0,\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "prefix": "",\n    "store_id": 0,\n    "suffix": "",\n    "taxvat": "",\n    "updated_at": "",\n    "website_id": 0\n  },\n  "password": "",\n  "redirectUrl": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/customers
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "customer": [
    "addresses": [
      [
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          [
            "attribute_code": "",
            "value": ""
          ]
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": [],
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": [
          "extension_attributes": [],
          "region": "",
          "region_code": "",
          "region_id": 0
        ],
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      ]
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [[]],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": [
      "amazon_id": "",
      "company_attributes": [
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": [],
        "job_title": "",
        "status": 0,
        "telephone": ""
      ],
      "is_subscribed": false,
      "vertex_customer_code": ""
    ],
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  ],
  "password": "",
  "redirectUrl": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers")! 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 customers-{customerId} (GET)
{{baseUrl}}/V1/customers/:customerId
QUERY PARAMS

customerId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/:customerId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/customers/:customerId")
require "http/client"

url = "{{baseUrl}}/V1/customers/:customerId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/customers/:customerId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customers/:customerId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/:customerId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/customers/:customerId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/customers/:customerId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/:customerId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/:customerId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/customers/:customerId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/customers/:customerId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/customers/:customerId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/:customerId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/:customerId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/:customerId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/:customerId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/customers/:customerId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/customers/:customerId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/customers/:customerId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/:customerId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/:customerId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customers/:customerId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/:customerId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/customers/:customerId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/:customerId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customers/:customerId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/:customerId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/:customerId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/customers/:customerId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/:customerId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/:customerId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/:customerId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/customers/:customerId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customers/:customerId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/customers/:customerId
http GET {{baseUrl}}/V1/customers/:customerId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/customers/:customerId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/:customerId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT customers-{customerId} (PUT)
{{baseUrl}}/V1/customers/:customerId
QUERY PARAMS

customerId
BODY json

{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "passwordHash": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/:customerId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/customers/:customerId" {:content-type :json
                                                                    :form-params {:customer {:addresses [{:city ""
                                                                                                          :company ""
                                                                                                          :country_id ""
                                                                                                          :custom_attributes [{:attribute_code ""
                                                                                                                               :value ""}]
                                                                                                          :customer_id 0
                                                                                                          :default_billing false
                                                                                                          :default_shipping false
                                                                                                          :extension_attributes {}
                                                                                                          :fax ""
                                                                                                          :firstname ""
                                                                                                          :id 0
                                                                                                          :lastname ""
                                                                                                          :middlename ""
                                                                                                          :postcode ""
                                                                                                          :prefix ""
                                                                                                          :region {:extension_attributes {}
                                                                                                                   :region ""
                                                                                                                   :region_code ""
                                                                                                                   :region_id 0}
                                                                                                          :region_id 0
                                                                                                          :street []
                                                                                                          :suffix ""
                                                                                                          :telephone ""
                                                                                                          :vat_id ""}]
                                                                                             :confirmation ""
                                                                                             :created_at ""
                                                                                             :created_in ""
                                                                                             :custom_attributes [{}]
                                                                                             :default_billing ""
                                                                                             :default_shipping ""
                                                                                             :disable_auto_group_change 0
                                                                                             :dob ""
                                                                                             :email ""
                                                                                             :extension_attributes {:amazon_id ""
                                                                                                                    :company_attributes {:company_id 0
                                                                                                                                         :customer_id 0
                                                                                                                                         :extension_attributes {}
                                                                                                                                         :job_title ""
                                                                                                                                         :status 0
                                                                                                                                         :telephone ""}
                                                                                                                    :is_subscribed false
                                                                                                                    :vertex_customer_code ""}
                                                                                             :firstname ""
                                                                                             :gender 0
                                                                                             :group_id 0
                                                                                             :id 0
                                                                                             :lastname ""
                                                                                             :middlename ""
                                                                                             :prefix ""
                                                                                             :store_id 0
                                                                                             :suffix ""
                                                                                             :taxvat ""
                                                                                             :updated_at ""
                                                                                             :website_id 0}
                                                                                  :passwordHash ""}})
require "http/client"

url = "{{baseUrl}}/V1/customers/:customerId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\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}}/V1/customers/:customerId"),
    Content = new StringContent("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\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}}/V1/customers/:customerId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/:customerId"

	payload := strings.NewReader("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/customers/:customerId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1609

{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "passwordHash": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/customers/:customerId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/:customerId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\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  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/:customerId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/customers/:customerId")
  .header("content-type", "application/json")
  .body("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  customer: {
    addresses: [
      {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [
          {
            attribute_code: '',
            value: ''
          }
        ],
        customer_id: 0,
        default_billing: false,
        default_shipping: false,
        extension_attributes: {},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: {
          extension_attributes: {},
          region: '',
          region_code: '',
          region_id: 0
        },
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      }
    ],
    confirmation: '',
    created_at: '',
    created_in: '',
    custom_attributes: [
      {}
    ],
    default_billing: '',
    default_shipping: '',
    disable_auto_group_change: 0,
    dob: '',
    email: '',
    extension_attributes: {
      amazon_id: '',
      company_attributes: {
        company_id: 0,
        customer_id: 0,
        extension_attributes: {},
        job_title: '',
        status: 0,
        telephone: ''
      },
      is_subscribed: false,
      vertex_customer_code: ''
    },
    firstname: '',
    gender: 0,
    group_id: 0,
    id: 0,
    lastname: '',
    middlename: '',
    prefix: '',
    store_id: 0,
    suffix: '',
    taxvat: '',
    updated_at: '',
    website_id: 0
  },
  passwordHash: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/customers/:customerId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customers/:customerId',
  headers: {'content-type': 'application/json'},
  data: {
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [{}],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_id: 0
    },
    passwordHash: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/:customerId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"customer":{"addresses":[{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_id":0,"default_billing":false,"default_shipping":false,"extension_attributes":{},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":{"extension_attributes":{},"region":"","region_code":"","region_id":0},"region_id":0,"street":[],"suffix":"","telephone":"","vat_id":""}],"confirmation":"","created_at":"","created_in":"","custom_attributes":[{}],"default_billing":"","default_shipping":"","disable_auto_group_change":0,"dob":"","email":"","extension_attributes":{"amazon_id":"","company_attributes":{"company_id":0,"customer_id":0,"extension_attributes":{},"job_title":"","status":0,"telephone":""},"is_subscribed":false,"vertex_customer_code":""},"firstname":"","gender":0,"group_id":0,"id":0,"lastname":"","middlename":"","prefix":"","store_id":0,"suffix":"","taxvat":"","updated_at":"","website_id":0},"passwordHash":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/:customerId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "customer": {\n    "addresses": [\n      {\n        "city": "",\n        "company": "",\n        "country_id": "",\n        "custom_attributes": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ],\n        "customer_id": 0,\n        "default_billing": false,\n        "default_shipping": false,\n        "extension_attributes": {},\n        "fax": "",\n        "firstname": "",\n        "id": 0,\n        "lastname": "",\n        "middlename": "",\n        "postcode": "",\n        "prefix": "",\n        "region": {\n          "extension_attributes": {},\n          "region": "",\n          "region_code": "",\n          "region_id": 0\n        },\n        "region_id": 0,\n        "street": [],\n        "suffix": "",\n        "telephone": "",\n        "vat_id": ""\n      }\n    ],\n    "confirmation": "",\n    "created_at": "",\n    "created_in": "",\n    "custom_attributes": [\n      {}\n    ],\n    "default_billing": "",\n    "default_shipping": "",\n    "disable_auto_group_change": 0,\n    "dob": "",\n    "email": "",\n    "extension_attributes": {\n      "amazon_id": "",\n      "company_attributes": {\n        "company_id": 0,\n        "customer_id": 0,\n        "extension_attributes": {},\n        "job_title": "",\n        "status": 0,\n        "telephone": ""\n      },\n      "is_subscribed": false,\n      "vertex_customer_code": ""\n    },\n    "firstname": "",\n    "gender": 0,\n    "group_id": 0,\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "prefix": "",\n    "store_id": 0,\n    "suffix": "",\n    "taxvat": "",\n    "updated_at": "",\n    "website_id": 0\n  },\n  "passwordHash": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/:customerId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/:customerId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  customer: {
    addresses: [
      {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_id: 0,
        default_billing: false,
        default_shipping: false,
        extension_attributes: {},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      }
    ],
    confirmation: '',
    created_at: '',
    created_in: '',
    custom_attributes: [{}],
    default_billing: '',
    default_shipping: '',
    disable_auto_group_change: 0,
    dob: '',
    email: '',
    extension_attributes: {
      amazon_id: '',
      company_attributes: {
        company_id: 0,
        customer_id: 0,
        extension_attributes: {},
        job_title: '',
        status: 0,
        telephone: ''
      },
      is_subscribed: false,
      vertex_customer_code: ''
    },
    firstname: '',
    gender: 0,
    group_id: 0,
    id: 0,
    lastname: '',
    middlename: '',
    prefix: '',
    store_id: 0,
    suffix: '',
    taxvat: '',
    updated_at: '',
    website_id: 0
  },
  passwordHash: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customers/:customerId',
  headers: {'content-type': 'application/json'},
  body: {
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [{}],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_id: 0
    },
    passwordHash: ''
  },
  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}}/V1/customers/:customerId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  customer: {
    addresses: [
      {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [
          {
            attribute_code: '',
            value: ''
          }
        ],
        customer_id: 0,
        default_billing: false,
        default_shipping: false,
        extension_attributes: {},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: {
          extension_attributes: {},
          region: '',
          region_code: '',
          region_id: 0
        },
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      }
    ],
    confirmation: '',
    created_at: '',
    created_in: '',
    custom_attributes: [
      {}
    ],
    default_billing: '',
    default_shipping: '',
    disable_auto_group_change: 0,
    dob: '',
    email: '',
    extension_attributes: {
      amazon_id: '',
      company_attributes: {
        company_id: 0,
        customer_id: 0,
        extension_attributes: {},
        job_title: '',
        status: 0,
        telephone: ''
      },
      is_subscribed: false,
      vertex_customer_code: ''
    },
    firstname: '',
    gender: 0,
    group_id: 0,
    id: 0,
    lastname: '',
    middlename: '',
    prefix: '',
    store_id: 0,
    suffix: '',
    taxvat: '',
    updated_at: '',
    website_id: 0
  },
  passwordHash: ''
});

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}}/V1/customers/:customerId',
  headers: {'content-type': 'application/json'},
  data: {
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [{}],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_id: 0
    },
    passwordHash: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/:customerId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"customer":{"addresses":[{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_id":0,"default_billing":false,"default_shipping":false,"extension_attributes":{},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":{"extension_attributes":{},"region":"","region_code":"","region_id":0},"region_id":0,"street":[],"suffix":"","telephone":"","vat_id":""}],"confirmation":"","created_at":"","created_in":"","custom_attributes":[{}],"default_billing":"","default_shipping":"","disable_auto_group_change":0,"dob":"","email":"","extension_attributes":{"amazon_id":"","company_attributes":{"company_id":0,"customer_id":0,"extension_attributes":{},"job_title":"","status":0,"telephone":""},"is_subscribed":false,"vertex_customer_code":""},"firstname":"","gender":0,"group_id":0,"id":0,"lastname":"","middlename":"","prefix":"","store_id":0,"suffix":"","taxvat":"","updated_at":"","website_id":0},"passwordHash":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"customer": @{ @"addresses": @[ @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_id": @0, @"default_billing": @NO, @"default_shipping": @NO, @"extension_attributes": @{  }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @{ @"extension_attributes": @{  }, @"region": @"", @"region_code": @"", @"region_id": @0 }, @"region_id": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" } ], @"confirmation": @"", @"created_at": @"", @"created_in": @"", @"custom_attributes": @[ @{  } ], @"default_billing": @"", @"default_shipping": @"", @"disable_auto_group_change": @0, @"dob": @"", @"email": @"", @"extension_attributes": @{ @"amazon_id": @"", @"company_attributes": @{ @"company_id": @0, @"customer_id": @0, @"extension_attributes": @{  }, @"job_title": @"", @"status": @0, @"telephone": @"" }, @"is_subscribed": @NO, @"vertex_customer_code": @"" }, @"firstname": @"", @"gender": @0, @"group_id": @0, @"id": @0, @"lastname": @"", @"middlename": @"", @"prefix": @"", @"store_id": @0, @"suffix": @"", @"taxvat": @"", @"updated_at": @"", @"website_id": @0 },
                              @"passwordHash": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/:customerId"]
                                                       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}}/V1/customers/:customerId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/:customerId",
  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([
    'customer' => [
        'addresses' => [
                [
                                'city' => '',
                                'company' => '',
                                'country_id' => '',
                                'custom_attributes' => [
                                                                [
                                                                                                                                'attribute_code' => '',
                                                                                                                                'value' => ''
                                                                ]
                                ],
                                'customer_id' => 0,
                                'default_billing' => null,
                                'default_shipping' => null,
                                'extension_attributes' => [
                                                                
                                ],
                                'fax' => '',
                                'firstname' => '',
                                'id' => 0,
                                'lastname' => '',
                                'middlename' => '',
                                'postcode' => '',
                                'prefix' => '',
                                'region' => [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'region' => '',
                                                                'region_code' => '',
                                                                'region_id' => 0
                                ],
                                'region_id' => 0,
                                'street' => [
                                                                
                                ],
                                'suffix' => '',
                                'telephone' => '',
                                'vat_id' => ''
                ]
        ],
        'confirmation' => '',
        'created_at' => '',
        'created_in' => '',
        'custom_attributes' => [
                [
                                
                ]
        ],
        'default_billing' => '',
        'default_shipping' => '',
        'disable_auto_group_change' => 0,
        'dob' => '',
        'email' => '',
        'extension_attributes' => [
                'amazon_id' => '',
                'company_attributes' => [
                                'company_id' => 0,
                                'customer_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'job_title' => '',
                                'status' => 0,
                                'telephone' => ''
                ],
                'is_subscribed' => null,
                'vertex_customer_code' => ''
        ],
        'firstname' => '',
        'gender' => 0,
        'group_id' => 0,
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'prefix' => '',
        'store_id' => 0,
        'suffix' => '',
        'taxvat' => '',
        'updated_at' => '',
        'website_id' => 0
    ],
    'passwordHash' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/customers/:customerId', [
  'body' => '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "passwordHash": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/:customerId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'customer' => [
    'addresses' => [
        [
                'city' => '',
                'company' => '',
                'country_id' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_id' => 0,
                'default_billing' => null,
                'default_shipping' => null,
                'extension_attributes' => [
                                
                ],
                'fax' => '',
                'firstname' => '',
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'postcode' => '',
                'prefix' => '',
                'region' => [
                                'extension_attributes' => [
                                                                
                                ],
                                'region' => '',
                                'region_code' => '',
                                'region_id' => 0
                ],
                'region_id' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => ''
        ]
    ],
    'confirmation' => '',
    'created_at' => '',
    'created_in' => '',
    'custom_attributes' => [
        [
                
        ]
    ],
    'default_billing' => '',
    'default_shipping' => '',
    'disable_auto_group_change' => 0,
    'dob' => '',
    'email' => '',
    'extension_attributes' => [
        'amazon_id' => '',
        'company_attributes' => [
                'company_id' => 0,
                'customer_id' => 0,
                'extension_attributes' => [
                                
                ],
                'job_title' => '',
                'status' => 0,
                'telephone' => ''
        ],
        'is_subscribed' => null,
        'vertex_customer_code' => ''
    ],
    'firstname' => '',
    'gender' => 0,
    'group_id' => 0,
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'prefix' => '',
    'store_id' => 0,
    'suffix' => '',
    'taxvat' => '',
    'updated_at' => '',
    'website_id' => 0
  ],
  'passwordHash' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'customer' => [
    'addresses' => [
        [
                'city' => '',
                'company' => '',
                'country_id' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_id' => 0,
                'default_billing' => null,
                'default_shipping' => null,
                'extension_attributes' => [
                                
                ],
                'fax' => '',
                'firstname' => '',
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'postcode' => '',
                'prefix' => '',
                'region' => [
                                'extension_attributes' => [
                                                                
                                ],
                                'region' => '',
                                'region_code' => '',
                                'region_id' => 0
                ],
                'region_id' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => ''
        ]
    ],
    'confirmation' => '',
    'created_at' => '',
    'created_in' => '',
    'custom_attributes' => [
        [
                
        ]
    ],
    'default_billing' => '',
    'default_shipping' => '',
    'disable_auto_group_change' => 0,
    'dob' => '',
    'email' => '',
    'extension_attributes' => [
        'amazon_id' => '',
        'company_attributes' => [
                'company_id' => 0,
                'customer_id' => 0,
                'extension_attributes' => [
                                
                ],
                'job_title' => '',
                'status' => 0,
                'telephone' => ''
        ],
        'is_subscribed' => null,
        'vertex_customer_code' => ''
    ],
    'firstname' => '',
    'gender' => 0,
    'group_id' => 0,
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'prefix' => '',
    'store_id' => 0,
    'suffix' => '',
    'taxvat' => '',
    'updated_at' => '',
    'website_id' => 0
  ],
  'passwordHash' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/customers/:customerId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/:customerId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "passwordHash": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/:customerId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "passwordHash": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/customers/:customerId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/:customerId"

payload = {
    "customer": {
        "addresses": [
            {
                "city": "",
                "company": "",
                "country_id": "",
                "custom_attributes": [
                    {
                        "attribute_code": "",
                        "value": ""
                    }
                ],
                "customer_id": 0,
                "default_billing": False,
                "default_shipping": False,
                "extension_attributes": {},
                "fax": "",
                "firstname": "",
                "id": 0,
                "lastname": "",
                "middlename": "",
                "postcode": "",
                "prefix": "",
                "region": {
                    "extension_attributes": {},
                    "region": "",
                    "region_code": "",
                    "region_id": 0
                },
                "region_id": 0,
                "street": [],
                "suffix": "",
                "telephone": "",
                "vat_id": ""
            }
        ],
        "confirmation": "",
        "created_at": "",
        "created_in": "",
        "custom_attributes": [{}],
        "default_billing": "",
        "default_shipping": "",
        "disable_auto_group_change": 0,
        "dob": "",
        "email": "",
        "extension_attributes": {
            "amazon_id": "",
            "company_attributes": {
                "company_id": 0,
                "customer_id": 0,
                "extension_attributes": {},
                "job_title": "",
                "status": 0,
                "telephone": ""
            },
            "is_subscribed": False,
            "vertex_customer_code": ""
        },
        "firstname": "",
        "gender": 0,
        "group_id": 0,
        "id": 0,
        "lastname": "",
        "middlename": "",
        "prefix": "",
        "store_id": 0,
        "suffix": "",
        "taxvat": "",
        "updated_at": "",
        "website_id": 0
    },
    "passwordHash": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/:customerId"

payload <- "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/:customerId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\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/V1/customers/:customerId') do |req|
  req.body = "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\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}}/V1/customers/:customerId";

    let payload = json!({
        "customer": json!({
            "addresses": (
                json!({
                    "city": "",
                    "company": "",
                    "country_id": "",
                    "custom_attributes": (
                        json!({
                            "attribute_code": "",
                            "value": ""
                        })
                    ),
                    "customer_id": 0,
                    "default_billing": false,
                    "default_shipping": false,
                    "extension_attributes": json!({}),
                    "fax": "",
                    "firstname": "",
                    "id": 0,
                    "lastname": "",
                    "middlename": "",
                    "postcode": "",
                    "prefix": "",
                    "region": json!({
                        "extension_attributes": json!({}),
                        "region": "",
                        "region_code": "",
                        "region_id": 0
                    }),
                    "region_id": 0,
                    "street": (),
                    "suffix": "",
                    "telephone": "",
                    "vat_id": ""
                })
            ),
            "confirmation": "",
            "created_at": "",
            "created_in": "",
            "custom_attributes": (json!({})),
            "default_billing": "",
            "default_shipping": "",
            "disable_auto_group_change": 0,
            "dob": "",
            "email": "",
            "extension_attributes": json!({
                "amazon_id": "",
                "company_attributes": json!({
                    "company_id": 0,
                    "customer_id": 0,
                    "extension_attributes": json!({}),
                    "job_title": "",
                    "status": 0,
                    "telephone": ""
                }),
                "is_subscribed": false,
                "vertex_customer_code": ""
            }),
            "firstname": "",
            "gender": 0,
            "group_id": 0,
            "id": 0,
            "lastname": "",
            "middlename": "",
            "prefix": "",
            "store_id": 0,
            "suffix": "",
            "taxvat": "",
            "updated_at": "",
            "website_id": 0
        }),
        "passwordHash": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/customers/:customerId \
  --header 'content-type: application/json' \
  --data '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "passwordHash": ""
}'
echo '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "passwordHash": ""
}' |  \
  http PUT {{baseUrl}}/V1/customers/:customerId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "customer": {\n    "addresses": [\n      {\n        "city": "",\n        "company": "",\n        "country_id": "",\n        "custom_attributes": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ],\n        "customer_id": 0,\n        "default_billing": false,\n        "default_shipping": false,\n        "extension_attributes": {},\n        "fax": "",\n        "firstname": "",\n        "id": 0,\n        "lastname": "",\n        "middlename": "",\n        "postcode": "",\n        "prefix": "",\n        "region": {\n          "extension_attributes": {},\n          "region": "",\n          "region_code": "",\n          "region_id": 0\n        },\n        "region_id": 0,\n        "street": [],\n        "suffix": "",\n        "telephone": "",\n        "vat_id": ""\n      }\n    ],\n    "confirmation": "",\n    "created_at": "",\n    "created_in": "",\n    "custom_attributes": [\n      {}\n    ],\n    "default_billing": "",\n    "default_shipping": "",\n    "disable_auto_group_change": 0,\n    "dob": "",\n    "email": "",\n    "extension_attributes": {\n      "amazon_id": "",\n      "company_attributes": {\n        "company_id": 0,\n        "customer_id": 0,\n        "extension_attributes": {},\n        "job_title": "",\n        "status": 0,\n        "telephone": ""\n      },\n      "is_subscribed": false,\n      "vertex_customer_code": ""\n    },\n    "firstname": "",\n    "gender": 0,\n    "group_id": 0,\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "prefix": "",\n    "store_id": 0,\n    "suffix": "",\n    "taxvat": "",\n    "updated_at": "",\n    "website_id": 0\n  },\n  "passwordHash": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/customers/:customerId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "customer": [
    "addresses": [
      [
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          [
            "attribute_code": "",
            "value": ""
          ]
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": [],
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": [
          "extension_attributes": [],
          "region": "",
          "region_code": "",
          "region_id": 0
        ],
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      ]
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [[]],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": [
      "amazon_id": "",
      "company_attributes": [
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": [],
        "job_title": "",
        "status": 0,
        "telephone": ""
      ],
      "is_subscribed": false,
      "vertex_customer_code": ""
    ],
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  ],
  "passwordHash": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/:customerId")! 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()
DELETE customers-{customerId}
{{baseUrl}}/V1/customers/:customerId
QUERY PARAMS

customerId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/:customerId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/customers/:customerId")
require "http/client"

url = "{{baseUrl}}/V1/customers/:customerId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/customers/:customerId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customers/:customerId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/:customerId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/customers/:customerId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/customers/:customerId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/:customerId"))
    .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}}/V1/customers/:customerId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/customers/:customerId")
  .asString();
const 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}}/V1/customers/:customerId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/customers/:customerId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/:customerId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/:customerId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/:customerId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/:customerId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/customers/:customerId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/customers/:customerId');

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}}/V1/customers/:customerId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/:customerId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/:customerId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customers/:customerId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/:customerId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/customers/:customerId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/:customerId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customers/:customerId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/:customerId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/:customerId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/customers/:customerId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/:customerId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/:customerId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/:customerId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/customers/:customerId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customers/:customerId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/customers/:customerId
http DELETE {{baseUrl}}/V1/customers/:customerId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/customers/:customerId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/:customerId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET customers-{customerId}-billingAddress
{{baseUrl}}/V1/customers/:customerId/billingAddress
QUERY PARAMS

customerId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/:customerId/billingAddress");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/customers/:customerId/billingAddress")
require "http/client"

url = "{{baseUrl}}/V1/customers/:customerId/billingAddress"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/customers/:customerId/billingAddress"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customers/:customerId/billingAddress");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/:customerId/billingAddress"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/customers/:customerId/billingAddress HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/customers/:customerId/billingAddress")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/:customerId/billingAddress"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/:customerId/billingAddress")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/customers/:customerId/billingAddress")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/customers/:customerId/billingAddress');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/:customerId/billingAddress'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/:customerId/billingAddress';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/:customerId/billingAddress',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/:customerId/billingAddress")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/:customerId/billingAddress',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/:customerId/billingAddress'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/customers/:customerId/billingAddress');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/:customerId/billingAddress'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/:customerId/billingAddress';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/:customerId/billingAddress"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customers/:customerId/billingAddress" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/:customerId/billingAddress",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/customers/:customerId/billingAddress');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/:customerId/billingAddress');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customers/:customerId/billingAddress');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/:customerId/billingAddress' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/:customerId/billingAddress' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/customers/:customerId/billingAddress")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/:customerId/billingAddress"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/:customerId/billingAddress"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/:customerId/billingAddress")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/customers/:customerId/billingAddress') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customers/:customerId/billingAddress";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/customers/:customerId/billingAddress
http GET {{baseUrl}}/V1/customers/:customerId/billingAddress
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/customers/:customerId/billingAddress
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/:customerId/billingAddress")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST customers-{customerId}-carts
{{baseUrl}}/V1/customers/:customerId/carts
QUERY PARAMS

customerId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/:customerId/carts");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/customers/:customerId/carts")
require "http/client"

url = "{{baseUrl}}/V1/customers/:customerId/carts"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/customers/:customerId/carts"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customers/:customerId/carts");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/:customerId/carts"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/customers/:customerId/carts HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/customers/:customerId/carts")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/:customerId/carts"))
    .method("POST", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/:customerId/carts")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/customers/:customerId/carts")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/customers/:customerId/carts');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/customers/:customerId/carts'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/:customerId/carts';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/:customerId/carts',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/:customerId/carts")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/:customerId/carts',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/customers/:customerId/carts'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/customers/:customerId/carts');

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}}/V1/customers/:customerId/carts'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/:customerId/carts';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/:customerId/carts"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customers/:customerId/carts" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/:customerId/carts",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/customers/:customerId/carts');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/:customerId/carts');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customers/:customerId/carts');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/:customerId/carts' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/:customerId/carts' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/V1/customers/:customerId/carts")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/:customerId/carts"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/:customerId/carts"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/:customerId/carts")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/V1/customers/:customerId/carts') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customers/:customerId/carts";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/customers/:customerId/carts
http POST {{baseUrl}}/V1/customers/:customerId/carts
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/V1/customers/:customerId/carts
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/:customerId/carts")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET customers-{customerId}-confirm
{{baseUrl}}/V1/customers/:customerId/confirm
QUERY PARAMS

customerId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/:customerId/confirm");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/customers/:customerId/confirm")
require "http/client"

url = "{{baseUrl}}/V1/customers/:customerId/confirm"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/customers/:customerId/confirm"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customers/:customerId/confirm");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/:customerId/confirm"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/customers/:customerId/confirm HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/customers/:customerId/confirm")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/:customerId/confirm"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/:customerId/confirm")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/customers/:customerId/confirm")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/customers/:customerId/confirm');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/:customerId/confirm'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/:customerId/confirm';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/:customerId/confirm',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/:customerId/confirm")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/:customerId/confirm',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/:customerId/confirm'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/customers/:customerId/confirm');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/:customerId/confirm'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/:customerId/confirm';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/:customerId/confirm"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customers/:customerId/confirm" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/:customerId/confirm",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/customers/:customerId/confirm');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/:customerId/confirm');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customers/:customerId/confirm');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/:customerId/confirm' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/:customerId/confirm' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/customers/:customerId/confirm")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/:customerId/confirm"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/:customerId/confirm"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/:customerId/confirm")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/customers/:customerId/confirm') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customers/:customerId/confirm";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/customers/:customerId/confirm
http GET {{baseUrl}}/V1/customers/:customerId/confirm
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/customers/:customerId/confirm
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/:customerId/confirm")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET customers-{customerId}-password-resetLinkToken-{resetPasswordLinkToken}
{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken
QUERY PARAMS

customerId
resetPasswordLinkToken
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken")
require "http/client"

url = "{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken
http GET {{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/:customerId/password/resetLinkToken/:resetPasswordLinkToken")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET customers-{customerId}-permissions-readonly
{{baseUrl}}/V1/customers/:customerId/permissions/readonly
QUERY PARAMS

customerId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/:customerId/permissions/readonly");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/customers/:customerId/permissions/readonly")
require "http/client"

url = "{{baseUrl}}/V1/customers/:customerId/permissions/readonly"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/customers/:customerId/permissions/readonly"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customers/:customerId/permissions/readonly");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/:customerId/permissions/readonly"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/customers/:customerId/permissions/readonly HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/customers/:customerId/permissions/readonly")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/:customerId/permissions/readonly"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/:customerId/permissions/readonly")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/customers/:customerId/permissions/readonly")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/customers/:customerId/permissions/readonly');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/:customerId/permissions/readonly'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/:customerId/permissions/readonly';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/:customerId/permissions/readonly',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/:customerId/permissions/readonly")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/:customerId/permissions/readonly',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/:customerId/permissions/readonly'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/customers/:customerId/permissions/readonly');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/:customerId/permissions/readonly'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/:customerId/permissions/readonly';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/:customerId/permissions/readonly"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customers/:customerId/permissions/readonly" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/:customerId/permissions/readonly",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/customers/:customerId/permissions/readonly');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/:customerId/permissions/readonly');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customers/:customerId/permissions/readonly');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/:customerId/permissions/readonly' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/:customerId/permissions/readonly' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/customers/:customerId/permissions/readonly")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/:customerId/permissions/readonly"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/:customerId/permissions/readonly"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/:customerId/permissions/readonly")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/customers/:customerId/permissions/readonly') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customers/:customerId/permissions/readonly";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/customers/:customerId/permissions/readonly
http GET {{baseUrl}}/V1/customers/:customerId/permissions/readonly
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/customers/:customerId/permissions/readonly
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/:customerId/permissions/readonly")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET customers-{customerId}-shippingAddress
{{baseUrl}}/V1/customers/:customerId/shippingAddress
QUERY PARAMS

customerId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/:customerId/shippingAddress");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/customers/:customerId/shippingAddress")
require "http/client"

url = "{{baseUrl}}/V1/customers/:customerId/shippingAddress"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/customers/:customerId/shippingAddress"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customers/:customerId/shippingAddress");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/:customerId/shippingAddress"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/customers/:customerId/shippingAddress HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/customers/:customerId/shippingAddress")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/:customerId/shippingAddress"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/:customerId/shippingAddress")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/customers/:customerId/shippingAddress")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/customers/:customerId/shippingAddress');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/:customerId/shippingAddress'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/:customerId/shippingAddress';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/:customerId/shippingAddress',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/:customerId/shippingAddress")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/:customerId/shippingAddress',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/:customerId/shippingAddress'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/customers/:customerId/shippingAddress');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/:customerId/shippingAddress'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/:customerId/shippingAddress';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/:customerId/shippingAddress"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customers/:customerId/shippingAddress" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/:customerId/shippingAddress",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/customers/:customerId/shippingAddress');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/:customerId/shippingAddress');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customers/:customerId/shippingAddress');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/:customerId/shippingAddress' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/:customerId/shippingAddress' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/customers/:customerId/shippingAddress")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/:customerId/shippingAddress"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/:customerId/shippingAddress"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/:customerId/shippingAddress")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/customers/:customerId/shippingAddress') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customers/:customerId/shippingAddress";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/customers/:customerId/shippingAddress
http GET {{baseUrl}}/V1/customers/:customerId/shippingAddress
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/customers/:customerId/shippingAddress
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/:customerId/shippingAddress")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT customers-{email}-activate
{{baseUrl}}/V1/customers/:email/activate
QUERY PARAMS

email
BODY json

{
  "confirmationKey": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/:email/activate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"confirmationKey\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/customers/:email/activate" {:content-type :json
                                                                        :form-params {:confirmationKey ""}})
require "http/client"

url = "{{baseUrl}}/V1/customers/:email/activate"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"confirmationKey\": \"\"\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}}/V1/customers/:email/activate"),
    Content = new StringContent("{\n  \"confirmationKey\": \"\"\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}}/V1/customers/:email/activate");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"confirmationKey\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/:email/activate"

	payload := strings.NewReader("{\n  \"confirmationKey\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/customers/:email/activate HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 27

{
  "confirmationKey": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/customers/:email/activate")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"confirmationKey\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/:email/activate"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"confirmationKey\": \"\"\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  \"confirmationKey\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/:email/activate")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/customers/:email/activate")
  .header("content-type", "application/json")
  .body("{\n  \"confirmationKey\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  confirmationKey: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/customers/:email/activate');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customers/:email/activate',
  headers: {'content-type': 'application/json'},
  data: {confirmationKey: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/:email/activate';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"confirmationKey":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/:email/activate',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "confirmationKey": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"confirmationKey\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/:email/activate")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/:email/activate',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({confirmationKey: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customers/:email/activate',
  headers: {'content-type': 'application/json'},
  body: {confirmationKey: ''},
  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}}/V1/customers/:email/activate');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  confirmationKey: ''
});

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}}/V1/customers/:email/activate',
  headers: {'content-type': 'application/json'},
  data: {confirmationKey: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/:email/activate';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"confirmationKey":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"confirmationKey": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/:email/activate"]
                                                       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}}/V1/customers/:email/activate" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"confirmationKey\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/:email/activate",
  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([
    'confirmationKey' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/customers/:email/activate', [
  'body' => '{
  "confirmationKey": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/:email/activate');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'confirmationKey' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'confirmationKey' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/customers/:email/activate');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/:email/activate' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "confirmationKey": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/:email/activate' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "confirmationKey": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"confirmationKey\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/customers/:email/activate", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/:email/activate"

payload = { "confirmationKey": "" }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/:email/activate"

payload <- "{\n  \"confirmationKey\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/:email/activate")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"confirmationKey\": \"\"\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/V1/customers/:email/activate') do |req|
  req.body = "{\n  \"confirmationKey\": \"\"\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}}/V1/customers/:email/activate";

    let payload = json!({"confirmationKey": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/customers/:email/activate \
  --header 'content-type: application/json' \
  --data '{
  "confirmationKey": ""
}'
echo '{
  "confirmationKey": ""
}' |  \
  http PUT {{baseUrl}}/V1/customers/:email/activate \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "confirmationKey": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/customers/:email/activate
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["confirmationKey": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/:email/activate")! 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 customers-addresses-{addressId}
{{baseUrl}}/V1/customers/addresses/:addressId
QUERY PARAMS

addressId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/addresses/:addressId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/customers/addresses/:addressId")
require "http/client"

url = "{{baseUrl}}/V1/customers/addresses/:addressId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/customers/addresses/:addressId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customers/addresses/:addressId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/addresses/:addressId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/customers/addresses/:addressId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/customers/addresses/:addressId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/addresses/:addressId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/addresses/:addressId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/customers/addresses/:addressId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/customers/addresses/:addressId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/addresses/:addressId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/addresses/:addressId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/addresses/:addressId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/addresses/:addressId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/addresses/:addressId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/addresses/:addressId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/customers/addresses/:addressId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/addresses/:addressId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/addresses/:addressId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/addresses/:addressId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customers/addresses/:addressId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/addresses/:addressId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/customers/addresses/:addressId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/addresses/:addressId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customers/addresses/:addressId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/addresses/:addressId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/addresses/:addressId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/customers/addresses/:addressId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/addresses/:addressId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/addresses/:addressId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/addresses/:addressId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/customers/addresses/:addressId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customers/addresses/:addressId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/customers/addresses/:addressId
http GET {{baseUrl}}/V1/customers/addresses/:addressId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/customers/addresses/:addressId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/addresses/:addressId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST customers-confirm
{{baseUrl}}/V1/customers/confirm
BODY json

{
  "email": "",
  "redirectUrl": "",
  "websiteId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/confirm");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"email\": \"\",\n  \"redirectUrl\": \"\",\n  \"websiteId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/customers/confirm" {:content-type :json
                                                                 :form-params {:email ""
                                                                               :redirectUrl ""
                                                                               :websiteId 0}})
require "http/client"

url = "{{baseUrl}}/V1/customers/confirm"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"email\": \"\",\n  \"redirectUrl\": \"\",\n  \"websiteId\": 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}}/V1/customers/confirm"),
    Content = new StringContent("{\n  \"email\": \"\",\n  \"redirectUrl\": \"\",\n  \"websiteId\": 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}}/V1/customers/confirm");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"email\": \"\",\n  \"redirectUrl\": \"\",\n  \"websiteId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/confirm"

	payload := strings.NewReader("{\n  \"email\": \"\",\n  \"redirectUrl\": \"\",\n  \"websiteId\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/customers/confirm HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 56

{
  "email": "",
  "redirectUrl": "",
  "websiteId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/customers/confirm")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"email\": \"\",\n  \"redirectUrl\": \"\",\n  \"websiteId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/confirm"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"email\": \"\",\n  \"redirectUrl\": \"\",\n  \"websiteId\": 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  \"email\": \"\",\n  \"redirectUrl\": \"\",\n  \"websiteId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/confirm")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/customers/confirm")
  .header("content-type", "application/json")
  .body("{\n  \"email\": \"\",\n  \"redirectUrl\": \"\",\n  \"websiteId\": 0\n}")
  .asString();
const data = JSON.stringify({
  email: '',
  redirectUrl: '',
  websiteId: 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}}/V1/customers/confirm');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/customers/confirm',
  headers: {'content-type': 'application/json'},
  data: {email: '', redirectUrl: '', websiteId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/confirm';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"email":"","redirectUrl":"","websiteId":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}}/V1/customers/confirm',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "email": "",\n  "redirectUrl": "",\n  "websiteId": 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  \"email\": \"\",\n  \"redirectUrl\": \"\",\n  \"websiteId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/confirm")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/confirm',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({email: '', redirectUrl: '', websiteId: 0}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/customers/confirm',
  headers: {'content-type': 'application/json'},
  body: {email: '', redirectUrl: '', websiteId: 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}}/V1/customers/confirm');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  email: '',
  redirectUrl: '',
  websiteId: 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}}/V1/customers/confirm',
  headers: {'content-type': 'application/json'},
  data: {email: '', redirectUrl: '', websiteId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/confirm';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"email":"","redirectUrl":"","websiteId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"email": @"",
                              @"redirectUrl": @"",
                              @"websiteId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/confirm"]
                                                       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}}/V1/customers/confirm" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"email\": \"\",\n  \"redirectUrl\": \"\",\n  \"websiteId\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/confirm",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'email' => '',
    'redirectUrl' => '',
    'websiteId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/customers/confirm', [
  'body' => '{
  "email": "",
  "redirectUrl": "",
  "websiteId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/confirm');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'email' => '',
  'redirectUrl' => '',
  'websiteId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'email' => '',
  'redirectUrl' => '',
  'websiteId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/customers/confirm');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/confirm' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "email": "",
  "redirectUrl": "",
  "websiteId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/confirm' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "email": "",
  "redirectUrl": "",
  "websiteId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"email\": \"\",\n  \"redirectUrl\": \"\",\n  \"websiteId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/customers/confirm", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/confirm"

payload = {
    "email": "",
    "redirectUrl": "",
    "websiteId": 0
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/confirm"

payload <- "{\n  \"email\": \"\",\n  \"redirectUrl\": \"\",\n  \"websiteId\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/confirm")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"email\": \"\",\n  \"redirectUrl\": \"\",\n  \"websiteId\": 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/V1/customers/confirm') do |req|
  req.body = "{\n  \"email\": \"\",\n  \"redirectUrl\": \"\",\n  \"websiteId\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customers/confirm";

    let payload = json!({
        "email": "",
        "redirectUrl": "",
        "websiteId": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/customers/confirm \
  --header 'content-type: application/json' \
  --data '{
  "email": "",
  "redirectUrl": "",
  "websiteId": 0
}'
echo '{
  "email": "",
  "redirectUrl": "",
  "websiteId": 0
}' |  \
  http POST {{baseUrl}}/V1/customers/confirm \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "email": "",\n  "redirectUrl": "",\n  "websiteId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/customers/confirm
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "email": "",
  "redirectUrl": "",
  "websiteId": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/confirm")! 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 customers-isEmailAvailable
{{baseUrl}}/V1/customers/isEmailAvailable
BODY json

{
  "customerEmail": "",
  "websiteId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/isEmailAvailable");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"customerEmail\": \"\",\n  \"websiteId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/customers/isEmailAvailable" {:content-type :json
                                                                          :form-params {:customerEmail ""
                                                                                        :websiteId 0}})
require "http/client"

url = "{{baseUrl}}/V1/customers/isEmailAvailable"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"customerEmail\": \"\",\n  \"websiteId\": 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}}/V1/customers/isEmailAvailable"),
    Content = new StringContent("{\n  \"customerEmail\": \"\",\n  \"websiteId\": 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}}/V1/customers/isEmailAvailable");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"customerEmail\": \"\",\n  \"websiteId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/isEmailAvailable"

	payload := strings.NewReader("{\n  \"customerEmail\": \"\",\n  \"websiteId\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/customers/isEmailAvailable HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 43

{
  "customerEmail": "",
  "websiteId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/customers/isEmailAvailable")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"customerEmail\": \"\",\n  \"websiteId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/isEmailAvailable"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"customerEmail\": \"\",\n  \"websiteId\": 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  \"customerEmail\": \"\",\n  \"websiteId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/isEmailAvailable")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/customers/isEmailAvailable")
  .header("content-type", "application/json")
  .body("{\n  \"customerEmail\": \"\",\n  \"websiteId\": 0\n}")
  .asString();
const data = JSON.stringify({
  customerEmail: '',
  websiteId: 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}}/V1/customers/isEmailAvailable');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/customers/isEmailAvailable',
  headers: {'content-type': 'application/json'},
  data: {customerEmail: '', websiteId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/isEmailAvailable';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"customerEmail":"","websiteId":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}}/V1/customers/isEmailAvailable',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "customerEmail": "",\n  "websiteId": 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  \"customerEmail\": \"\",\n  \"websiteId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/isEmailAvailable")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/isEmailAvailable',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({customerEmail: '', websiteId: 0}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/customers/isEmailAvailable',
  headers: {'content-type': 'application/json'},
  body: {customerEmail: '', websiteId: 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}}/V1/customers/isEmailAvailable');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  customerEmail: '',
  websiteId: 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}}/V1/customers/isEmailAvailable',
  headers: {'content-type': 'application/json'},
  data: {customerEmail: '', websiteId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/isEmailAvailable';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"customerEmail":"","websiteId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"customerEmail": @"",
                              @"websiteId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/isEmailAvailable"]
                                                       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}}/V1/customers/isEmailAvailable" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"customerEmail\": \"\",\n  \"websiteId\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/isEmailAvailable",
  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([
    'customerEmail' => '',
    'websiteId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/customers/isEmailAvailable', [
  'body' => '{
  "customerEmail": "",
  "websiteId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/isEmailAvailable');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'customerEmail' => '',
  'websiteId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'customerEmail' => '',
  'websiteId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/customers/isEmailAvailable');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/isEmailAvailable' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "customerEmail": "",
  "websiteId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/isEmailAvailable' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "customerEmail": "",
  "websiteId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"customerEmail\": \"\",\n  \"websiteId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/customers/isEmailAvailable", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/isEmailAvailable"

payload = {
    "customerEmail": "",
    "websiteId": 0
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/isEmailAvailable"

payload <- "{\n  \"customerEmail\": \"\",\n  \"websiteId\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/isEmailAvailable")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"customerEmail\": \"\",\n  \"websiteId\": 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/V1/customers/isEmailAvailable') do |req|
  req.body = "{\n  \"customerEmail\": \"\",\n  \"websiteId\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customers/isEmailAvailable";

    let payload = json!({
        "customerEmail": "",
        "websiteId": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/customers/isEmailAvailable \
  --header 'content-type: application/json' \
  --data '{
  "customerEmail": "",
  "websiteId": 0
}'
echo '{
  "customerEmail": "",
  "websiteId": 0
}' |  \
  http POST {{baseUrl}}/V1/customers/isEmailAvailable \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "customerEmail": "",\n  "websiteId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/customers/isEmailAvailable
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "customerEmail": "",
  "websiteId": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/isEmailAvailable")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT customers-me (PUT)
{{baseUrl}}/V1/customers/me
BODY json

{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "passwordHash": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/me");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/customers/me" {:content-type :json
                                                           :form-params {:customer {:addresses [{:city ""
                                                                                                 :company ""
                                                                                                 :country_id ""
                                                                                                 :custom_attributes [{:attribute_code ""
                                                                                                                      :value ""}]
                                                                                                 :customer_id 0
                                                                                                 :default_billing false
                                                                                                 :default_shipping false
                                                                                                 :extension_attributes {}
                                                                                                 :fax ""
                                                                                                 :firstname ""
                                                                                                 :id 0
                                                                                                 :lastname ""
                                                                                                 :middlename ""
                                                                                                 :postcode ""
                                                                                                 :prefix ""
                                                                                                 :region {:extension_attributes {}
                                                                                                          :region ""
                                                                                                          :region_code ""
                                                                                                          :region_id 0}
                                                                                                 :region_id 0
                                                                                                 :street []
                                                                                                 :suffix ""
                                                                                                 :telephone ""
                                                                                                 :vat_id ""}]
                                                                                    :confirmation ""
                                                                                    :created_at ""
                                                                                    :created_in ""
                                                                                    :custom_attributes [{}]
                                                                                    :default_billing ""
                                                                                    :default_shipping ""
                                                                                    :disable_auto_group_change 0
                                                                                    :dob ""
                                                                                    :email ""
                                                                                    :extension_attributes {:amazon_id ""
                                                                                                           :company_attributes {:company_id 0
                                                                                                                                :customer_id 0
                                                                                                                                :extension_attributes {}
                                                                                                                                :job_title ""
                                                                                                                                :status 0
                                                                                                                                :telephone ""}
                                                                                                           :is_subscribed false
                                                                                                           :vertex_customer_code ""}
                                                                                    :firstname ""
                                                                                    :gender 0
                                                                                    :group_id 0
                                                                                    :id 0
                                                                                    :lastname ""
                                                                                    :middlename ""
                                                                                    :prefix ""
                                                                                    :store_id 0
                                                                                    :suffix ""
                                                                                    :taxvat ""
                                                                                    :updated_at ""
                                                                                    :website_id 0}
                                                                         :passwordHash ""}})
require "http/client"

url = "{{baseUrl}}/V1/customers/me"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\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}}/V1/customers/me"),
    Content = new StringContent("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\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}}/V1/customers/me");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/me"

	payload := strings.NewReader("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/customers/me HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1609

{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "passwordHash": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/customers/me")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/me"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\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  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/me")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/customers/me")
  .header("content-type", "application/json")
  .body("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  customer: {
    addresses: [
      {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [
          {
            attribute_code: '',
            value: ''
          }
        ],
        customer_id: 0,
        default_billing: false,
        default_shipping: false,
        extension_attributes: {},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: {
          extension_attributes: {},
          region: '',
          region_code: '',
          region_id: 0
        },
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      }
    ],
    confirmation: '',
    created_at: '',
    created_in: '',
    custom_attributes: [
      {}
    ],
    default_billing: '',
    default_shipping: '',
    disable_auto_group_change: 0,
    dob: '',
    email: '',
    extension_attributes: {
      amazon_id: '',
      company_attributes: {
        company_id: 0,
        customer_id: 0,
        extension_attributes: {},
        job_title: '',
        status: 0,
        telephone: ''
      },
      is_subscribed: false,
      vertex_customer_code: ''
    },
    firstname: '',
    gender: 0,
    group_id: 0,
    id: 0,
    lastname: '',
    middlename: '',
    prefix: '',
    store_id: 0,
    suffix: '',
    taxvat: '',
    updated_at: '',
    website_id: 0
  },
  passwordHash: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/customers/me');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customers/me',
  headers: {'content-type': 'application/json'},
  data: {
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [{}],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_id: 0
    },
    passwordHash: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/me';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"customer":{"addresses":[{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_id":0,"default_billing":false,"default_shipping":false,"extension_attributes":{},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":{"extension_attributes":{},"region":"","region_code":"","region_id":0},"region_id":0,"street":[],"suffix":"","telephone":"","vat_id":""}],"confirmation":"","created_at":"","created_in":"","custom_attributes":[{}],"default_billing":"","default_shipping":"","disable_auto_group_change":0,"dob":"","email":"","extension_attributes":{"amazon_id":"","company_attributes":{"company_id":0,"customer_id":0,"extension_attributes":{},"job_title":"","status":0,"telephone":""},"is_subscribed":false,"vertex_customer_code":""},"firstname":"","gender":0,"group_id":0,"id":0,"lastname":"","middlename":"","prefix":"","store_id":0,"suffix":"","taxvat":"","updated_at":"","website_id":0},"passwordHash":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/me',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "customer": {\n    "addresses": [\n      {\n        "city": "",\n        "company": "",\n        "country_id": "",\n        "custom_attributes": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ],\n        "customer_id": 0,\n        "default_billing": false,\n        "default_shipping": false,\n        "extension_attributes": {},\n        "fax": "",\n        "firstname": "",\n        "id": 0,\n        "lastname": "",\n        "middlename": "",\n        "postcode": "",\n        "prefix": "",\n        "region": {\n          "extension_attributes": {},\n          "region": "",\n          "region_code": "",\n          "region_id": 0\n        },\n        "region_id": 0,\n        "street": [],\n        "suffix": "",\n        "telephone": "",\n        "vat_id": ""\n      }\n    ],\n    "confirmation": "",\n    "created_at": "",\n    "created_in": "",\n    "custom_attributes": [\n      {}\n    ],\n    "default_billing": "",\n    "default_shipping": "",\n    "disable_auto_group_change": 0,\n    "dob": "",\n    "email": "",\n    "extension_attributes": {\n      "amazon_id": "",\n      "company_attributes": {\n        "company_id": 0,\n        "customer_id": 0,\n        "extension_attributes": {},\n        "job_title": "",\n        "status": 0,\n        "telephone": ""\n      },\n      "is_subscribed": false,\n      "vertex_customer_code": ""\n    },\n    "firstname": "",\n    "gender": 0,\n    "group_id": 0,\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "prefix": "",\n    "store_id": 0,\n    "suffix": "",\n    "taxvat": "",\n    "updated_at": "",\n    "website_id": 0\n  },\n  "passwordHash": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/me")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/me',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  customer: {
    addresses: [
      {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_id: 0,
        default_billing: false,
        default_shipping: false,
        extension_attributes: {},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      }
    ],
    confirmation: '',
    created_at: '',
    created_in: '',
    custom_attributes: [{}],
    default_billing: '',
    default_shipping: '',
    disable_auto_group_change: 0,
    dob: '',
    email: '',
    extension_attributes: {
      amazon_id: '',
      company_attributes: {
        company_id: 0,
        customer_id: 0,
        extension_attributes: {},
        job_title: '',
        status: 0,
        telephone: ''
      },
      is_subscribed: false,
      vertex_customer_code: ''
    },
    firstname: '',
    gender: 0,
    group_id: 0,
    id: 0,
    lastname: '',
    middlename: '',
    prefix: '',
    store_id: 0,
    suffix: '',
    taxvat: '',
    updated_at: '',
    website_id: 0
  },
  passwordHash: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customers/me',
  headers: {'content-type': 'application/json'},
  body: {
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [{}],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_id: 0
    },
    passwordHash: ''
  },
  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}}/V1/customers/me');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  customer: {
    addresses: [
      {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [
          {
            attribute_code: '',
            value: ''
          }
        ],
        customer_id: 0,
        default_billing: false,
        default_shipping: false,
        extension_attributes: {},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: {
          extension_attributes: {},
          region: '',
          region_code: '',
          region_id: 0
        },
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      }
    ],
    confirmation: '',
    created_at: '',
    created_in: '',
    custom_attributes: [
      {}
    ],
    default_billing: '',
    default_shipping: '',
    disable_auto_group_change: 0,
    dob: '',
    email: '',
    extension_attributes: {
      amazon_id: '',
      company_attributes: {
        company_id: 0,
        customer_id: 0,
        extension_attributes: {},
        job_title: '',
        status: 0,
        telephone: ''
      },
      is_subscribed: false,
      vertex_customer_code: ''
    },
    firstname: '',
    gender: 0,
    group_id: 0,
    id: 0,
    lastname: '',
    middlename: '',
    prefix: '',
    store_id: 0,
    suffix: '',
    taxvat: '',
    updated_at: '',
    website_id: 0
  },
  passwordHash: ''
});

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}}/V1/customers/me',
  headers: {'content-type': 'application/json'},
  data: {
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [{}],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_id: 0
    },
    passwordHash: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/me';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"customer":{"addresses":[{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_id":0,"default_billing":false,"default_shipping":false,"extension_attributes":{},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":{"extension_attributes":{},"region":"","region_code":"","region_id":0},"region_id":0,"street":[],"suffix":"","telephone":"","vat_id":""}],"confirmation":"","created_at":"","created_in":"","custom_attributes":[{}],"default_billing":"","default_shipping":"","disable_auto_group_change":0,"dob":"","email":"","extension_attributes":{"amazon_id":"","company_attributes":{"company_id":0,"customer_id":0,"extension_attributes":{},"job_title":"","status":0,"telephone":""},"is_subscribed":false,"vertex_customer_code":""},"firstname":"","gender":0,"group_id":0,"id":0,"lastname":"","middlename":"","prefix":"","store_id":0,"suffix":"","taxvat":"","updated_at":"","website_id":0},"passwordHash":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"customer": @{ @"addresses": @[ @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_id": @0, @"default_billing": @NO, @"default_shipping": @NO, @"extension_attributes": @{  }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @{ @"extension_attributes": @{  }, @"region": @"", @"region_code": @"", @"region_id": @0 }, @"region_id": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" } ], @"confirmation": @"", @"created_at": @"", @"created_in": @"", @"custom_attributes": @[ @{  } ], @"default_billing": @"", @"default_shipping": @"", @"disable_auto_group_change": @0, @"dob": @"", @"email": @"", @"extension_attributes": @{ @"amazon_id": @"", @"company_attributes": @{ @"company_id": @0, @"customer_id": @0, @"extension_attributes": @{  }, @"job_title": @"", @"status": @0, @"telephone": @"" }, @"is_subscribed": @NO, @"vertex_customer_code": @"" }, @"firstname": @"", @"gender": @0, @"group_id": @0, @"id": @0, @"lastname": @"", @"middlename": @"", @"prefix": @"", @"store_id": @0, @"suffix": @"", @"taxvat": @"", @"updated_at": @"", @"website_id": @0 },
                              @"passwordHash": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/me"]
                                                       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}}/V1/customers/me" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/me",
  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([
    'customer' => [
        'addresses' => [
                [
                                'city' => '',
                                'company' => '',
                                'country_id' => '',
                                'custom_attributes' => [
                                                                [
                                                                                                                                'attribute_code' => '',
                                                                                                                                'value' => ''
                                                                ]
                                ],
                                'customer_id' => 0,
                                'default_billing' => null,
                                'default_shipping' => null,
                                'extension_attributes' => [
                                                                
                                ],
                                'fax' => '',
                                'firstname' => '',
                                'id' => 0,
                                'lastname' => '',
                                'middlename' => '',
                                'postcode' => '',
                                'prefix' => '',
                                'region' => [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'region' => '',
                                                                'region_code' => '',
                                                                'region_id' => 0
                                ],
                                'region_id' => 0,
                                'street' => [
                                                                
                                ],
                                'suffix' => '',
                                'telephone' => '',
                                'vat_id' => ''
                ]
        ],
        'confirmation' => '',
        'created_at' => '',
        'created_in' => '',
        'custom_attributes' => [
                [
                                
                ]
        ],
        'default_billing' => '',
        'default_shipping' => '',
        'disable_auto_group_change' => 0,
        'dob' => '',
        'email' => '',
        'extension_attributes' => [
                'amazon_id' => '',
                'company_attributes' => [
                                'company_id' => 0,
                                'customer_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'job_title' => '',
                                'status' => 0,
                                'telephone' => ''
                ],
                'is_subscribed' => null,
                'vertex_customer_code' => ''
        ],
        'firstname' => '',
        'gender' => 0,
        'group_id' => 0,
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'prefix' => '',
        'store_id' => 0,
        'suffix' => '',
        'taxvat' => '',
        'updated_at' => '',
        'website_id' => 0
    ],
    'passwordHash' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/customers/me', [
  'body' => '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "passwordHash": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/me');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'customer' => [
    'addresses' => [
        [
                'city' => '',
                'company' => '',
                'country_id' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_id' => 0,
                'default_billing' => null,
                'default_shipping' => null,
                'extension_attributes' => [
                                
                ],
                'fax' => '',
                'firstname' => '',
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'postcode' => '',
                'prefix' => '',
                'region' => [
                                'extension_attributes' => [
                                                                
                                ],
                                'region' => '',
                                'region_code' => '',
                                'region_id' => 0
                ],
                'region_id' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => ''
        ]
    ],
    'confirmation' => '',
    'created_at' => '',
    'created_in' => '',
    'custom_attributes' => [
        [
                
        ]
    ],
    'default_billing' => '',
    'default_shipping' => '',
    'disable_auto_group_change' => 0,
    'dob' => '',
    'email' => '',
    'extension_attributes' => [
        'amazon_id' => '',
        'company_attributes' => [
                'company_id' => 0,
                'customer_id' => 0,
                'extension_attributes' => [
                                
                ],
                'job_title' => '',
                'status' => 0,
                'telephone' => ''
        ],
        'is_subscribed' => null,
        'vertex_customer_code' => ''
    ],
    'firstname' => '',
    'gender' => 0,
    'group_id' => 0,
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'prefix' => '',
    'store_id' => 0,
    'suffix' => '',
    'taxvat' => '',
    'updated_at' => '',
    'website_id' => 0
  ],
  'passwordHash' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'customer' => [
    'addresses' => [
        [
                'city' => '',
                'company' => '',
                'country_id' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_id' => 0,
                'default_billing' => null,
                'default_shipping' => null,
                'extension_attributes' => [
                                
                ],
                'fax' => '',
                'firstname' => '',
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'postcode' => '',
                'prefix' => '',
                'region' => [
                                'extension_attributes' => [
                                                                
                                ],
                                'region' => '',
                                'region_code' => '',
                                'region_id' => 0
                ],
                'region_id' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => ''
        ]
    ],
    'confirmation' => '',
    'created_at' => '',
    'created_in' => '',
    'custom_attributes' => [
        [
                
        ]
    ],
    'default_billing' => '',
    'default_shipping' => '',
    'disable_auto_group_change' => 0,
    'dob' => '',
    'email' => '',
    'extension_attributes' => [
        'amazon_id' => '',
        'company_attributes' => [
                'company_id' => 0,
                'customer_id' => 0,
                'extension_attributes' => [
                                
                ],
                'job_title' => '',
                'status' => 0,
                'telephone' => ''
        ],
        'is_subscribed' => null,
        'vertex_customer_code' => ''
    ],
    'firstname' => '',
    'gender' => 0,
    'group_id' => 0,
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'prefix' => '',
    'store_id' => 0,
    'suffix' => '',
    'taxvat' => '',
    'updated_at' => '',
    'website_id' => 0
  ],
  'passwordHash' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/customers/me');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/me' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "passwordHash": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/me' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "passwordHash": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/customers/me", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/me"

payload = {
    "customer": {
        "addresses": [
            {
                "city": "",
                "company": "",
                "country_id": "",
                "custom_attributes": [
                    {
                        "attribute_code": "",
                        "value": ""
                    }
                ],
                "customer_id": 0,
                "default_billing": False,
                "default_shipping": False,
                "extension_attributes": {},
                "fax": "",
                "firstname": "",
                "id": 0,
                "lastname": "",
                "middlename": "",
                "postcode": "",
                "prefix": "",
                "region": {
                    "extension_attributes": {},
                    "region": "",
                    "region_code": "",
                    "region_id": 0
                },
                "region_id": 0,
                "street": [],
                "suffix": "",
                "telephone": "",
                "vat_id": ""
            }
        ],
        "confirmation": "",
        "created_at": "",
        "created_in": "",
        "custom_attributes": [{}],
        "default_billing": "",
        "default_shipping": "",
        "disable_auto_group_change": 0,
        "dob": "",
        "email": "",
        "extension_attributes": {
            "amazon_id": "",
            "company_attributes": {
                "company_id": 0,
                "customer_id": 0,
                "extension_attributes": {},
                "job_title": "",
                "status": 0,
                "telephone": ""
            },
            "is_subscribed": False,
            "vertex_customer_code": ""
        },
        "firstname": "",
        "gender": 0,
        "group_id": 0,
        "id": 0,
        "lastname": "",
        "middlename": "",
        "prefix": "",
        "store_id": 0,
        "suffix": "",
        "taxvat": "",
        "updated_at": "",
        "website_id": 0
    },
    "passwordHash": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/me"

payload <- "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/me")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\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/V1/customers/me') do |req|
  req.body = "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  },\n  \"passwordHash\": \"\"\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}}/V1/customers/me";

    let payload = json!({
        "customer": json!({
            "addresses": (
                json!({
                    "city": "",
                    "company": "",
                    "country_id": "",
                    "custom_attributes": (
                        json!({
                            "attribute_code": "",
                            "value": ""
                        })
                    ),
                    "customer_id": 0,
                    "default_billing": false,
                    "default_shipping": false,
                    "extension_attributes": json!({}),
                    "fax": "",
                    "firstname": "",
                    "id": 0,
                    "lastname": "",
                    "middlename": "",
                    "postcode": "",
                    "prefix": "",
                    "region": json!({
                        "extension_attributes": json!({}),
                        "region": "",
                        "region_code": "",
                        "region_id": 0
                    }),
                    "region_id": 0,
                    "street": (),
                    "suffix": "",
                    "telephone": "",
                    "vat_id": ""
                })
            ),
            "confirmation": "",
            "created_at": "",
            "created_in": "",
            "custom_attributes": (json!({})),
            "default_billing": "",
            "default_shipping": "",
            "disable_auto_group_change": 0,
            "dob": "",
            "email": "",
            "extension_attributes": json!({
                "amazon_id": "",
                "company_attributes": json!({
                    "company_id": 0,
                    "customer_id": 0,
                    "extension_attributes": json!({}),
                    "job_title": "",
                    "status": 0,
                    "telephone": ""
                }),
                "is_subscribed": false,
                "vertex_customer_code": ""
            }),
            "firstname": "",
            "gender": 0,
            "group_id": 0,
            "id": 0,
            "lastname": "",
            "middlename": "",
            "prefix": "",
            "store_id": 0,
            "suffix": "",
            "taxvat": "",
            "updated_at": "",
            "website_id": 0
        }),
        "passwordHash": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/customers/me \
  --header 'content-type: application/json' \
  --data '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "passwordHash": ""
}'
echo '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  },
  "passwordHash": ""
}' |  \
  http PUT {{baseUrl}}/V1/customers/me \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "customer": {\n    "addresses": [\n      {\n        "city": "",\n        "company": "",\n        "country_id": "",\n        "custom_attributes": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ],\n        "customer_id": 0,\n        "default_billing": false,\n        "default_shipping": false,\n        "extension_attributes": {},\n        "fax": "",\n        "firstname": "",\n        "id": 0,\n        "lastname": "",\n        "middlename": "",\n        "postcode": "",\n        "prefix": "",\n        "region": {\n          "extension_attributes": {},\n          "region": "",\n          "region_code": "",\n          "region_id": 0\n        },\n        "region_id": 0,\n        "street": [],\n        "suffix": "",\n        "telephone": "",\n        "vat_id": ""\n      }\n    ],\n    "confirmation": "",\n    "created_at": "",\n    "created_in": "",\n    "custom_attributes": [\n      {}\n    ],\n    "default_billing": "",\n    "default_shipping": "",\n    "disable_auto_group_change": 0,\n    "dob": "",\n    "email": "",\n    "extension_attributes": {\n      "amazon_id": "",\n      "company_attributes": {\n        "company_id": 0,\n        "customer_id": 0,\n        "extension_attributes": {},\n        "job_title": "",\n        "status": 0,\n        "telephone": ""\n      },\n      "is_subscribed": false,\n      "vertex_customer_code": ""\n    },\n    "firstname": "",\n    "gender": 0,\n    "group_id": 0,\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "prefix": "",\n    "store_id": 0,\n    "suffix": "",\n    "taxvat": "",\n    "updated_at": "",\n    "website_id": 0\n  },\n  "passwordHash": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/customers/me
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "customer": [
    "addresses": [
      [
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          [
            "attribute_code": "",
            "value": ""
          ]
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": [],
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": [
          "extension_attributes": [],
          "region": "",
          "region_code": "",
          "region_id": 0
        ],
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      ]
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [[]],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": [
      "amazon_id": "",
      "company_attributes": [
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": [],
        "job_title": "",
        "status": 0,
        "telephone": ""
      ],
      "is_subscribed": false,
      "vertex_customer_code": ""
    ],
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  ],
  "passwordHash": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/me")! 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 customers-me
{{baseUrl}}/V1/customers/me
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/me");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/customers/me")
require "http/client"

url = "{{baseUrl}}/V1/customers/me"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/customers/me"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customers/me");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/me"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/customers/me HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/customers/me")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/me"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/me")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/customers/me")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/customers/me');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/customers/me'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/me';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/me',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/me")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/me',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/customers/me'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/customers/me');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/customers/me'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/me';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/me"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customers/me" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/me",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/customers/me');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/me');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customers/me');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/me' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/me' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/customers/me")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/me"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/me"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/me")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/customers/me') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customers/me";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/customers/me
http GET {{baseUrl}}/V1/customers/me
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/customers/me
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/me")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT customers-me-activate
{{baseUrl}}/V1/customers/me/activate
BODY json

{
  "confirmationKey": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/me/activate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"confirmationKey\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/customers/me/activate" {:content-type :json
                                                                    :form-params {:confirmationKey ""}})
require "http/client"

url = "{{baseUrl}}/V1/customers/me/activate"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"confirmationKey\": \"\"\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}}/V1/customers/me/activate"),
    Content = new StringContent("{\n  \"confirmationKey\": \"\"\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}}/V1/customers/me/activate");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"confirmationKey\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/me/activate"

	payload := strings.NewReader("{\n  \"confirmationKey\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/customers/me/activate HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 27

{
  "confirmationKey": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/customers/me/activate")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"confirmationKey\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/me/activate"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"confirmationKey\": \"\"\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  \"confirmationKey\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/me/activate")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/customers/me/activate")
  .header("content-type", "application/json")
  .body("{\n  \"confirmationKey\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  confirmationKey: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/customers/me/activate');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customers/me/activate',
  headers: {'content-type': 'application/json'},
  data: {confirmationKey: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/me/activate';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"confirmationKey":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/me/activate',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "confirmationKey": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"confirmationKey\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/me/activate")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/me/activate',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({confirmationKey: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customers/me/activate',
  headers: {'content-type': 'application/json'},
  body: {confirmationKey: ''},
  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}}/V1/customers/me/activate');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  confirmationKey: ''
});

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}}/V1/customers/me/activate',
  headers: {'content-type': 'application/json'},
  data: {confirmationKey: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/me/activate';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"confirmationKey":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"confirmationKey": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/me/activate"]
                                                       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}}/V1/customers/me/activate" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"confirmationKey\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/me/activate",
  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([
    'confirmationKey' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/customers/me/activate', [
  'body' => '{
  "confirmationKey": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/me/activate');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'confirmationKey' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'confirmationKey' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/customers/me/activate');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/me/activate' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "confirmationKey": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/me/activate' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "confirmationKey": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"confirmationKey\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/customers/me/activate", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/me/activate"

payload = { "confirmationKey": "" }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/me/activate"

payload <- "{\n  \"confirmationKey\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/me/activate")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"confirmationKey\": \"\"\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/V1/customers/me/activate') do |req|
  req.body = "{\n  \"confirmationKey\": \"\"\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}}/V1/customers/me/activate";

    let payload = json!({"confirmationKey": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/customers/me/activate \
  --header 'content-type: application/json' \
  --data '{
  "confirmationKey": ""
}'
echo '{
  "confirmationKey": ""
}' |  \
  http PUT {{baseUrl}}/V1/customers/me/activate \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "confirmationKey": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/customers/me/activate
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["confirmationKey": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/me/activate")! 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 customers-me-billingAddress
{{baseUrl}}/V1/customers/me/billingAddress
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/me/billingAddress");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/customers/me/billingAddress")
require "http/client"

url = "{{baseUrl}}/V1/customers/me/billingAddress"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/customers/me/billingAddress"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customers/me/billingAddress");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/me/billingAddress"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/customers/me/billingAddress HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/customers/me/billingAddress")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/me/billingAddress"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/me/billingAddress")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/customers/me/billingAddress")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/customers/me/billingAddress');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/me/billingAddress'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/me/billingAddress';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/me/billingAddress',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/me/billingAddress")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/me/billingAddress',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/me/billingAddress'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/customers/me/billingAddress');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/me/billingAddress'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/me/billingAddress';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/me/billingAddress"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customers/me/billingAddress" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/me/billingAddress",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/customers/me/billingAddress');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/me/billingAddress');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customers/me/billingAddress');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/me/billingAddress' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/me/billingAddress' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/customers/me/billingAddress")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/me/billingAddress"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/me/billingAddress"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/me/billingAddress")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/customers/me/billingAddress') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customers/me/billingAddress";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/customers/me/billingAddress
http GET {{baseUrl}}/V1/customers/me/billingAddress
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/customers/me/billingAddress
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/me/billingAddress")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT customers-me-password
{{baseUrl}}/V1/customers/me/password
BODY json

{
  "currentPassword": "",
  "newPassword": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/me/password");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"currentPassword\": \"\",\n  \"newPassword\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/customers/me/password" {:content-type :json
                                                                    :form-params {:currentPassword ""
                                                                                  :newPassword ""}})
require "http/client"

url = "{{baseUrl}}/V1/customers/me/password"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"currentPassword\": \"\",\n  \"newPassword\": \"\"\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}}/V1/customers/me/password"),
    Content = new StringContent("{\n  \"currentPassword\": \"\",\n  \"newPassword\": \"\"\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}}/V1/customers/me/password");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"currentPassword\": \"\",\n  \"newPassword\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/me/password"

	payload := strings.NewReader("{\n  \"currentPassword\": \"\",\n  \"newPassword\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/customers/me/password HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 48

{
  "currentPassword": "",
  "newPassword": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/customers/me/password")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"currentPassword\": \"\",\n  \"newPassword\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/me/password"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"currentPassword\": \"\",\n  \"newPassword\": \"\"\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  \"currentPassword\": \"\",\n  \"newPassword\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/me/password")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/customers/me/password")
  .header("content-type", "application/json")
  .body("{\n  \"currentPassword\": \"\",\n  \"newPassword\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  currentPassword: '',
  newPassword: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/customers/me/password');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customers/me/password',
  headers: {'content-type': 'application/json'},
  data: {currentPassword: '', newPassword: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/me/password';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"currentPassword":"","newPassword":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/me/password',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "currentPassword": "",\n  "newPassword": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"currentPassword\": \"\",\n  \"newPassword\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/me/password")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/me/password',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({currentPassword: '', newPassword: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customers/me/password',
  headers: {'content-type': 'application/json'},
  body: {currentPassword: '', newPassword: ''},
  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}}/V1/customers/me/password');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  currentPassword: '',
  newPassword: ''
});

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}}/V1/customers/me/password',
  headers: {'content-type': 'application/json'},
  data: {currentPassword: '', newPassword: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/me/password';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"currentPassword":"","newPassword":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"currentPassword": @"",
                              @"newPassword": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/me/password"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customers/me/password" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"currentPassword\": \"\",\n  \"newPassword\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/me/password",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'currentPassword' => '',
    'newPassword' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/customers/me/password', [
  'body' => '{
  "currentPassword": "",
  "newPassword": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/me/password');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'currentPassword' => '',
  'newPassword' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'currentPassword' => '',
  'newPassword' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/customers/me/password');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/me/password' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "currentPassword": "",
  "newPassword": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/me/password' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "currentPassword": "",
  "newPassword": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"currentPassword\": \"\",\n  \"newPassword\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/customers/me/password", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/me/password"

payload = {
    "currentPassword": "",
    "newPassword": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/me/password"

payload <- "{\n  \"currentPassword\": \"\",\n  \"newPassword\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/me/password")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"currentPassword\": \"\",\n  \"newPassword\": \"\"\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/V1/customers/me/password') do |req|
  req.body = "{\n  \"currentPassword\": \"\",\n  \"newPassword\": \"\"\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}}/V1/customers/me/password";

    let payload = json!({
        "currentPassword": "",
        "newPassword": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/customers/me/password \
  --header 'content-type: application/json' \
  --data '{
  "currentPassword": "",
  "newPassword": ""
}'
echo '{
  "currentPassword": "",
  "newPassword": ""
}' |  \
  http PUT {{baseUrl}}/V1/customers/me/password \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "currentPassword": "",\n  "newPassword": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/customers/me/password
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "currentPassword": "",
  "newPassword": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/me/password")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET customers-me-shippingAddress
{{baseUrl}}/V1/customers/me/shippingAddress
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/me/shippingAddress");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/customers/me/shippingAddress")
require "http/client"

url = "{{baseUrl}}/V1/customers/me/shippingAddress"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/customers/me/shippingAddress"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customers/me/shippingAddress");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/me/shippingAddress"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/customers/me/shippingAddress HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/customers/me/shippingAddress")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/me/shippingAddress"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/me/shippingAddress")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/customers/me/shippingAddress")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/customers/me/shippingAddress');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/me/shippingAddress'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/me/shippingAddress';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/me/shippingAddress',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/me/shippingAddress")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/me/shippingAddress',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/me/shippingAddress'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/customers/me/shippingAddress');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/customers/me/shippingAddress'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/me/shippingAddress';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/me/shippingAddress"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customers/me/shippingAddress" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/me/shippingAddress",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/customers/me/shippingAddress');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/me/shippingAddress');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customers/me/shippingAddress');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/me/shippingAddress' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/me/shippingAddress' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/customers/me/shippingAddress")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/me/shippingAddress"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/me/shippingAddress"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/me/shippingAddress")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/customers/me/shippingAddress') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customers/me/shippingAddress";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/customers/me/shippingAddress
http GET {{baseUrl}}/V1/customers/me/shippingAddress
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/customers/me/shippingAddress
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/me/shippingAddress")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT customers-password
{{baseUrl}}/V1/customers/password
BODY json

{
  "email": "",
  "template": "",
  "websiteId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/password");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"email\": \"\",\n  \"template\": \"\",\n  \"websiteId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/customers/password" {:content-type :json
                                                                 :form-params {:email ""
                                                                               :template ""
                                                                               :websiteId 0}})
require "http/client"

url = "{{baseUrl}}/V1/customers/password"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"email\": \"\",\n  \"template\": \"\",\n  \"websiteId\": 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}}/V1/customers/password"),
    Content = new StringContent("{\n  \"email\": \"\",\n  \"template\": \"\",\n  \"websiteId\": 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}}/V1/customers/password");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"email\": \"\",\n  \"template\": \"\",\n  \"websiteId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/password"

	payload := strings.NewReader("{\n  \"email\": \"\",\n  \"template\": \"\",\n  \"websiteId\": 0\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/customers/password HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 53

{
  "email": "",
  "template": "",
  "websiteId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/customers/password")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"email\": \"\",\n  \"template\": \"\",\n  \"websiteId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/password"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"email\": \"\",\n  \"template\": \"\",\n  \"websiteId\": 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  \"email\": \"\",\n  \"template\": \"\",\n  \"websiteId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/password")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/customers/password")
  .header("content-type", "application/json")
  .body("{\n  \"email\": \"\",\n  \"template\": \"\",\n  \"websiteId\": 0\n}")
  .asString();
const data = JSON.stringify({
  email: '',
  template: '',
  websiteId: 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}}/V1/customers/password');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customers/password',
  headers: {'content-type': 'application/json'},
  data: {email: '', template: '', websiteId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/password';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"email":"","template":"","websiteId":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}}/V1/customers/password',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "email": "",\n  "template": "",\n  "websiteId": 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  \"email\": \"\",\n  \"template\": \"\",\n  \"websiteId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/password")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/password',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({email: '', template: '', websiteId: 0}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customers/password',
  headers: {'content-type': 'application/json'},
  body: {email: '', template: '', websiteId: 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}}/V1/customers/password');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  email: '',
  template: '',
  websiteId: 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}}/V1/customers/password',
  headers: {'content-type': 'application/json'},
  data: {email: '', template: '', websiteId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/password';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"email":"","template":"","websiteId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"email": @"",
                              @"template": @"",
                              @"websiteId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/password"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customers/password" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"email\": \"\",\n  \"template\": \"\",\n  \"websiteId\": 0\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/password",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'email' => '',
    'template' => '',
    'websiteId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/customers/password', [
  'body' => '{
  "email": "",
  "template": "",
  "websiteId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/password');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'email' => '',
  'template' => '',
  'websiteId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'email' => '',
  'template' => '',
  'websiteId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/customers/password');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/password' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "email": "",
  "template": "",
  "websiteId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/password' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "email": "",
  "template": "",
  "websiteId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"email\": \"\",\n  \"template\": \"\",\n  \"websiteId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/customers/password", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/password"

payload = {
    "email": "",
    "template": "",
    "websiteId": 0
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/password"

payload <- "{\n  \"email\": \"\",\n  \"template\": \"\",\n  \"websiteId\": 0\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/password")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"email\": \"\",\n  \"template\": \"\",\n  \"websiteId\": 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/V1/customers/password') do |req|
  req.body = "{\n  \"email\": \"\",\n  \"template\": \"\",\n  \"websiteId\": 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}}/V1/customers/password";

    let payload = json!({
        "email": "",
        "template": "",
        "websiteId": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/customers/password \
  --header 'content-type: application/json' \
  --data '{
  "email": "",
  "template": "",
  "websiteId": 0
}'
echo '{
  "email": "",
  "template": "",
  "websiteId": 0
}' |  \
  http PUT {{baseUrl}}/V1/customers/password \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "email": "",\n  "template": "",\n  "websiteId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/customers/password
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "email": "",
  "template": "",
  "websiteId": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/password")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST customers-resetPassword
{{baseUrl}}/V1/customers/resetPassword
BODY json

{
  "email": "",
  "newPassword": "",
  "resetToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/resetPassword");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"email\": \"\",\n  \"newPassword\": \"\",\n  \"resetToken\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/customers/resetPassword" {:content-type :json
                                                                       :form-params {:email ""
                                                                                     :newPassword ""
                                                                                     :resetToken ""}})
require "http/client"

url = "{{baseUrl}}/V1/customers/resetPassword"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"email\": \"\",\n  \"newPassword\": \"\",\n  \"resetToken\": \"\"\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}}/V1/customers/resetPassword"),
    Content = new StringContent("{\n  \"email\": \"\",\n  \"newPassword\": \"\",\n  \"resetToken\": \"\"\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}}/V1/customers/resetPassword");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"email\": \"\",\n  \"newPassword\": \"\",\n  \"resetToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/resetPassword"

	payload := strings.NewReader("{\n  \"email\": \"\",\n  \"newPassword\": \"\",\n  \"resetToken\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/customers/resetPassword HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 58

{
  "email": "",
  "newPassword": "",
  "resetToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/customers/resetPassword")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"email\": \"\",\n  \"newPassword\": \"\",\n  \"resetToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/resetPassword"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"email\": \"\",\n  \"newPassword\": \"\",\n  \"resetToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"email\": \"\",\n  \"newPassword\": \"\",\n  \"resetToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/resetPassword")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/customers/resetPassword")
  .header("content-type", "application/json")
  .body("{\n  \"email\": \"\",\n  \"newPassword\": \"\",\n  \"resetToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  email: '',
  newPassword: '',
  resetToken: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/customers/resetPassword');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/customers/resetPassword',
  headers: {'content-type': 'application/json'},
  data: {email: '', newPassword: '', resetToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/resetPassword';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"email":"","newPassword":"","resetToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/resetPassword',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "email": "",\n  "newPassword": "",\n  "resetToken": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"email\": \"\",\n  \"newPassword\": \"\",\n  \"resetToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/resetPassword")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/resetPassword',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({email: '', newPassword: '', resetToken: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/customers/resetPassword',
  headers: {'content-type': 'application/json'},
  body: {email: '', newPassword: '', resetToken: ''},
  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}}/V1/customers/resetPassword');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  email: '',
  newPassword: '',
  resetToken: ''
});

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}}/V1/customers/resetPassword',
  headers: {'content-type': 'application/json'},
  data: {email: '', newPassword: '', resetToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/resetPassword';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"email":"","newPassword":"","resetToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"email": @"",
                              @"newPassword": @"",
                              @"resetToken": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/resetPassword"]
                                                       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}}/V1/customers/resetPassword" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"email\": \"\",\n  \"newPassword\": \"\",\n  \"resetToken\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/resetPassword",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'email' => '',
    'newPassword' => '',
    'resetToken' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/customers/resetPassword', [
  'body' => '{
  "email": "",
  "newPassword": "",
  "resetToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/resetPassword');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'email' => '',
  'newPassword' => '',
  'resetToken' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'email' => '',
  'newPassword' => '',
  'resetToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/customers/resetPassword');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/resetPassword' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "email": "",
  "newPassword": "",
  "resetToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/resetPassword' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "email": "",
  "newPassword": "",
  "resetToken": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"email\": \"\",\n  \"newPassword\": \"\",\n  \"resetToken\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/customers/resetPassword", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/resetPassword"

payload = {
    "email": "",
    "newPassword": "",
    "resetToken": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/resetPassword"

payload <- "{\n  \"email\": \"\",\n  \"newPassword\": \"\",\n  \"resetToken\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/resetPassword")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"email\": \"\",\n  \"newPassword\": \"\",\n  \"resetToken\": \"\"\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/V1/customers/resetPassword') do |req|
  req.body = "{\n  \"email\": \"\",\n  \"newPassword\": \"\",\n  \"resetToken\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customers/resetPassword";

    let payload = json!({
        "email": "",
        "newPassword": "",
        "resetToken": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/customers/resetPassword \
  --header 'content-type: application/json' \
  --data '{
  "email": "",
  "newPassword": "",
  "resetToken": ""
}'
echo '{
  "email": "",
  "newPassword": "",
  "resetToken": ""
}' |  \
  http POST {{baseUrl}}/V1/customers/resetPassword \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "email": "",\n  "newPassword": "",\n  "resetToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/customers/resetPassword
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "email": "",
  "newPassword": "",
  "resetToken": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/resetPassword")! 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}}/V1/customers/search");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/customers/search")
require "http/client"

url = "{{baseUrl}}/V1/customers/search"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/customers/search"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/customers/search");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/search"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/customers/search HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/customers/search")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/search"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/search")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/customers/search")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/customers/search');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/customers/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/customers/search',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/search")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/search',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/customers/search'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/customers/search');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/customers/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/customers/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/search"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/customers/search" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/search",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/customers/search');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/search');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/customers/search');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/search' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/search' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/customers/search")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/search"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/search"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/search")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/customers/search') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/customers/search";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/customers/search
http GET {{baseUrl}}/V1/customers/search
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/customers/search
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/search")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT customers-validate
{{baseUrl}}/V1/customers/validate
BODY json

{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/customers/validate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/customers/validate" {:content-type :json
                                                                 :form-params {:customer {:addresses [{:city ""
                                                                                                       :company ""
                                                                                                       :country_id ""
                                                                                                       :custom_attributes [{:attribute_code ""
                                                                                                                            :value ""}]
                                                                                                       :customer_id 0
                                                                                                       :default_billing false
                                                                                                       :default_shipping false
                                                                                                       :extension_attributes {}
                                                                                                       :fax ""
                                                                                                       :firstname ""
                                                                                                       :id 0
                                                                                                       :lastname ""
                                                                                                       :middlename ""
                                                                                                       :postcode ""
                                                                                                       :prefix ""
                                                                                                       :region {:extension_attributes {}
                                                                                                                :region ""
                                                                                                                :region_code ""
                                                                                                                :region_id 0}
                                                                                                       :region_id 0
                                                                                                       :street []
                                                                                                       :suffix ""
                                                                                                       :telephone ""
                                                                                                       :vat_id ""}]
                                                                                          :confirmation ""
                                                                                          :created_at ""
                                                                                          :created_in ""
                                                                                          :custom_attributes [{}]
                                                                                          :default_billing ""
                                                                                          :default_shipping ""
                                                                                          :disable_auto_group_change 0
                                                                                          :dob ""
                                                                                          :email ""
                                                                                          :extension_attributes {:amazon_id ""
                                                                                                                 :company_attributes {:company_id 0
                                                                                                                                      :customer_id 0
                                                                                                                                      :extension_attributes {}
                                                                                                                                      :job_title ""
                                                                                                                                      :status 0
                                                                                                                                      :telephone ""}
                                                                                                                 :is_subscribed false
                                                                                                                 :vertex_customer_code ""}
                                                                                          :firstname ""
                                                                                          :gender 0
                                                                                          :group_id 0
                                                                                          :id 0
                                                                                          :lastname ""
                                                                                          :middlename ""
                                                                                          :prefix ""
                                                                                          :store_id 0
                                                                                          :suffix ""
                                                                                          :taxvat ""
                                                                                          :updated_at ""
                                                                                          :website_id 0}}})
require "http/client"

url = "{{baseUrl}}/V1/customers/validate"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\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}}/V1/customers/validate"),
    Content = new StringContent("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\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}}/V1/customers/validate");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/customers/validate"

	payload := strings.NewReader("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/customers/validate HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1587

{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/customers/validate")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/customers/validate"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\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  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/customers/validate")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/customers/validate")
  .header("content-type", "application/json")
  .body("{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  customer: {
    addresses: [
      {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [
          {
            attribute_code: '',
            value: ''
          }
        ],
        customer_id: 0,
        default_billing: false,
        default_shipping: false,
        extension_attributes: {},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: {
          extension_attributes: {},
          region: '',
          region_code: '',
          region_id: 0
        },
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      }
    ],
    confirmation: '',
    created_at: '',
    created_in: '',
    custom_attributes: [
      {}
    ],
    default_billing: '',
    default_shipping: '',
    disable_auto_group_change: 0,
    dob: '',
    email: '',
    extension_attributes: {
      amazon_id: '',
      company_attributes: {
        company_id: 0,
        customer_id: 0,
        extension_attributes: {},
        job_title: '',
        status: 0,
        telephone: ''
      },
      is_subscribed: false,
      vertex_customer_code: ''
    },
    firstname: '',
    gender: 0,
    group_id: 0,
    id: 0,
    lastname: '',
    middlename: '',
    prefix: '',
    store_id: 0,
    suffix: '',
    taxvat: '',
    updated_at: '',
    website_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}}/V1/customers/validate');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customers/validate',
  headers: {'content-type': 'application/json'},
  data: {
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [{}],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_id: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/customers/validate';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"customer":{"addresses":[{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_id":0,"default_billing":false,"default_shipping":false,"extension_attributes":{},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":{"extension_attributes":{},"region":"","region_code":"","region_id":0},"region_id":0,"street":[],"suffix":"","telephone":"","vat_id":""}],"confirmation":"","created_at":"","created_in":"","custom_attributes":[{}],"default_billing":"","default_shipping":"","disable_auto_group_change":0,"dob":"","email":"","extension_attributes":{"amazon_id":"","company_attributes":{"company_id":0,"customer_id":0,"extension_attributes":{},"job_title":"","status":0,"telephone":""},"is_subscribed":false,"vertex_customer_code":""},"firstname":"","gender":0,"group_id":0,"id":0,"lastname":"","middlename":"","prefix":"","store_id":0,"suffix":"","taxvat":"","updated_at":"","website_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}}/V1/customers/validate',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "customer": {\n    "addresses": [\n      {\n        "city": "",\n        "company": "",\n        "country_id": "",\n        "custom_attributes": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ],\n        "customer_id": 0,\n        "default_billing": false,\n        "default_shipping": false,\n        "extension_attributes": {},\n        "fax": "",\n        "firstname": "",\n        "id": 0,\n        "lastname": "",\n        "middlename": "",\n        "postcode": "",\n        "prefix": "",\n        "region": {\n          "extension_attributes": {},\n          "region": "",\n          "region_code": "",\n          "region_id": 0\n        },\n        "region_id": 0,\n        "street": [],\n        "suffix": "",\n        "telephone": "",\n        "vat_id": ""\n      }\n    ],\n    "confirmation": "",\n    "created_at": "",\n    "created_in": "",\n    "custom_attributes": [\n      {}\n    ],\n    "default_billing": "",\n    "default_shipping": "",\n    "disable_auto_group_change": 0,\n    "dob": "",\n    "email": "",\n    "extension_attributes": {\n      "amazon_id": "",\n      "company_attributes": {\n        "company_id": 0,\n        "customer_id": 0,\n        "extension_attributes": {},\n        "job_title": "",\n        "status": 0,\n        "telephone": ""\n      },\n      "is_subscribed": false,\n      "vertex_customer_code": ""\n    },\n    "firstname": "",\n    "gender": 0,\n    "group_id": 0,\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "prefix": "",\n    "store_id": 0,\n    "suffix": "",\n    "taxvat": "",\n    "updated_at": "",\n    "website_id": 0\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  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/customers/validate")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/customers/validate',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  customer: {
    addresses: [
      {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_id: 0,
        default_billing: false,
        default_shipping: false,
        extension_attributes: {},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      }
    ],
    confirmation: '',
    created_at: '',
    created_in: '',
    custom_attributes: [{}],
    default_billing: '',
    default_shipping: '',
    disable_auto_group_change: 0,
    dob: '',
    email: '',
    extension_attributes: {
      amazon_id: '',
      company_attributes: {
        company_id: 0,
        customer_id: 0,
        extension_attributes: {},
        job_title: '',
        status: 0,
        telephone: ''
      },
      is_subscribed: false,
      vertex_customer_code: ''
    },
    firstname: '',
    gender: 0,
    group_id: 0,
    id: 0,
    lastname: '',
    middlename: '',
    prefix: '',
    store_id: 0,
    suffix: '',
    taxvat: '',
    updated_at: '',
    website_id: 0
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/customers/validate',
  headers: {'content-type': 'application/json'},
  body: {
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [{}],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_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}}/V1/customers/validate');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  customer: {
    addresses: [
      {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [
          {
            attribute_code: '',
            value: ''
          }
        ],
        customer_id: 0,
        default_billing: false,
        default_shipping: false,
        extension_attributes: {},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: {
          extension_attributes: {},
          region: '',
          region_code: '',
          region_id: 0
        },
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      }
    ],
    confirmation: '',
    created_at: '',
    created_in: '',
    custom_attributes: [
      {}
    ],
    default_billing: '',
    default_shipping: '',
    disable_auto_group_change: 0,
    dob: '',
    email: '',
    extension_attributes: {
      amazon_id: '',
      company_attributes: {
        company_id: 0,
        customer_id: 0,
        extension_attributes: {},
        job_title: '',
        status: 0,
        telephone: ''
      },
      is_subscribed: false,
      vertex_customer_code: ''
    },
    firstname: '',
    gender: 0,
    group_id: 0,
    id: 0,
    lastname: '',
    middlename: '',
    prefix: '',
    store_id: 0,
    suffix: '',
    taxvat: '',
    updated_at: '',
    website_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}}/V1/customers/validate',
  headers: {'content-type': 'application/json'},
  data: {
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [{}],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_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}}/V1/customers/validate';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"customer":{"addresses":[{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_id":0,"default_billing":false,"default_shipping":false,"extension_attributes":{},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":{"extension_attributes":{},"region":"","region_code":"","region_id":0},"region_id":0,"street":[],"suffix":"","telephone":"","vat_id":""}],"confirmation":"","created_at":"","created_in":"","custom_attributes":[{}],"default_billing":"","default_shipping":"","disable_auto_group_change":0,"dob":"","email":"","extension_attributes":{"amazon_id":"","company_attributes":{"company_id":0,"customer_id":0,"extension_attributes":{},"job_title":"","status":0,"telephone":""},"is_subscribed":false,"vertex_customer_code":""},"firstname":"","gender":0,"group_id":0,"id":0,"lastname":"","middlename":"","prefix":"","store_id":0,"suffix":"","taxvat":"","updated_at":"","website_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 = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"customer": @{ @"addresses": @[ @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_id": @0, @"default_billing": @NO, @"default_shipping": @NO, @"extension_attributes": @{  }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @{ @"extension_attributes": @{  }, @"region": @"", @"region_code": @"", @"region_id": @0 }, @"region_id": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" } ], @"confirmation": @"", @"created_at": @"", @"created_in": @"", @"custom_attributes": @[ @{  } ], @"default_billing": @"", @"default_shipping": @"", @"disable_auto_group_change": @0, @"dob": @"", @"email": @"", @"extension_attributes": @{ @"amazon_id": @"", @"company_attributes": @{ @"company_id": @0, @"customer_id": @0, @"extension_attributes": @{  }, @"job_title": @"", @"status": @0, @"telephone": @"" }, @"is_subscribed": @NO, @"vertex_customer_code": @"" }, @"firstname": @"", @"gender": @0, @"group_id": @0, @"id": @0, @"lastname": @"", @"middlename": @"", @"prefix": @"", @"store_id": @0, @"suffix": @"", @"taxvat": @"", @"updated_at": @"", @"website_id": @0 } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/customers/validate"]
                                                       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}}/V1/customers/validate" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/customers/validate",
  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([
    'customer' => [
        'addresses' => [
                [
                                'city' => '',
                                'company' => '',
                                'country_id' => '',
                                'custom_attributes' => [
                                                                [
                                                                                                                                'attribute_code' => '',
                                                                                                                                'value' => ''
                                                                ]
                                ],
                                'customer_id' => 0,
                                'default_billing' => null,
                                'default_shipping' => null,
                                'extension_attributes' => [
                                                                
                                ],
                                'fax' => '',
                                'firstname' => '',
                                'id' => 0,
                                'lastname' => '',
                                'middlename' => '',
                                'postcode' => '',
                                'prefix' => '',
                                'region' => [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'region' => '',
                                                                'region_code' => '',
                                                                'region_id' => 0
                                ],
                                'region_id' => 0,
                                'street' => [
                                                                
                                ],
                                'suffix' => '',
                                'telephone' => '',
                                'vat_id' => ''
                ]
        ],
        'confirmation' => '',
        'created_at' => '',
        'created_in' => '',
        'custom_attributes' => [
                [
                                
                ]
        ],
        'default_billing' => '',
        'default_shipping' => '',
        'disable_auto_group_change' => 0,
        'dob' => '',
        'email' => '',
        'extension_attributes' => [
                'amazon_id' => '',
                'company_attributes' => [
                                'company_id' => 0,
                                'customer_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'job_title' => '',
                                'status' => 0,
                                'telephone' => ''
                ],
                'is_subscribed' => null,
                'vertex_customer_code' => ''
        ],
        'firstname' => '',
        'gender' => 0,
        'group_id' => 0,
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'prefix' => '',
        'store_id' => 0,
        'suffix' => '',
        'taxvat' => '',
        'updated_at' => '',
        'website_id' => 0
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/customers/validate', [
  'body' => '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/customers/validate');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'customer' => [
    'addresses' => [
        [
                'city' => '',
                'company' => '',
                'country_id' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_id' => 0,
                'default_billing' => null,
                'default_shipping' => null,
                'extension_attributes' => [
                                
                ],
                'fax' => '',
                'firstname' => '',
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'postcode' => '',
                'prefix' => '',
                'region' => [
                                'extension_attributes' => [
                                                                
                                ],
                                'region' => '',
                                'region_code' => '',
                                'region_id' => 0
                ],
                'region_id' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => ''
        ]
    ],
    'confirmation' => '',
    'created_at' => '',
    'created_in' => '',
    'custom_attributes' => [
        [
                
        ]
    ],
    'default_billing' => '',
    'default_shipping' => '',
    'disable_auto_group_change' => 0,
    'dob' => '',
    'email' => '',
    'extension_attributes' => [
        'amazon_id' => '',
        'company_attributes' => [
                'company_id' => 0,
                'customer_id' => 0,
                'extension_attributes' => [
                                
                ],
                'job_title' => '',
                'status' => 0,
                'telephone' => ''
        ],
        'is_subscribed' => null,
        'vertex_customer_code' => ''
    ],
    'firstname' => '',
    'gender' => 0,
    'group_id' => 0,
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'prefix' => '',
    'store_id' => 0,
    'suffix' => '',
    'taxvat' => '',
    'updated_at' => '',
    'website_id' => 0
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'customer' => [
    'addresses' => [
        [
                'city' => '',
                'company' => '',
                'country_id' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_id' => 0,
                'default_billing' => null,
                'default_shipping' => null,
                'extension_attributes' => [
                                
                ],
                'fax' => '',
                'firstname' => '',
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'postcode' => '',
                'prefix' => '',
                'region' => [
                                'extension_attributes' => [
                                                                
                                ],
                                'region' => '',
                                'region_code' => '',
                                'region_id' => 0
                ],
                'region_id' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => ''
        ]
    ],
    'confirmation' => '',
    'created_at' => '',
    'created_in' => '',
    'custom_attributes' => [
        [
                
        ]
    ],
    'default_billing' => '',
    'default_shipping' => '',
    'disable_auto_group_change' => 0,
    'dob' => '',
    'email' => '',
    'extension_attributes' => [
        'amazon_id' => '',
        'company_attributes' => [
                'company_id' => 0,
                'customer_id' => 0,
                'extension_attributes' => [
                                
                ],
                'job_title' => '',
                'status' => 0,
                'telephone' => ''
        ],
        'is_subscribed' => null,
        'vertex_customer_code' => ''
    ],
    'firstname' => '',
    'gender' => 0,
    'group_id' => 0,
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'prefix' => '',
    'store_id' => 0,
    'suffix' => '',
    'taxvat' => '',
    'updated_at' => '',
    'website_id' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/customers/validate');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/customers/validate' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/customers/validate' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/customers/validate", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/customers/validate"

payload = { "customer": {
        "addresses": [
            {
                "city": "",
                "company": "",
                "country_id": "",
                "custom_attributes": [
                    {
                        "attribute_code": "",
                        "value": ""
                    }
                ],
                "customer_id": 0,
                "default_billing": False,
                "default_shipping": False,
                "extension_attributes": {},
                "fax": "",
                "firstname": "",
                "id": 0,
                "lastname": "",
                "middlename": "",
                "postcode": "",
                "prefix": "",
                "region": {
                    "extension_attributes": {},
                    "region": "",
                    "region_code": "",
                    "region_id": 0
                },
                "region_id": 0,
                "street": [],
                "suffix": "",
                "telephone": "",
                "vat_id": ""
            }
        ],
        "confirmation": "",
        "created_at": "",
        "created_in": "",
        "custom_attributes": [{}],
        "default_billing": "",
        "default_shipping": "",
        "disable_auto_group_change": 0,
        "dob": "",
        "email": "",
        "extension_attributes": {
            "amazon_id": "",
            "company_attributes": {
                "company_id": 0,
                "customer_id": 0,
                "extension_attributes": {},
                "job_title": "",
                "status": 0,
                "telephone": ""
            },
            "is_subscribed": False,
            "vertex_customer_code": ""
        },
        "firstname": "",
        "gender": 0,
        "group_id": 0,
        "id": 0,
        "lastname": "",
        "middlename": "",
        "prefix": "",
        "store_id": 0,
        "suffix": "",
        "taxvat": "",
        "updated_at": "",
        "website_id": 0
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/customers/validate"

payload <- "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/customers/validate")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\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/V1/customers/validate') do |req|
  req.body = "{\n  \"customer\": {\n    \"addresses\": [\n      {\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_id\": 0,\n        \"default_billing\": false,\n        \"default_shipping\": false,\n        \"extension_attributes\": {},\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"id\": 0,\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": {\n          \"extension_attributes\": {},\n          \"region\": \"\",\n          \"region_code\": \"\",\n          \"region_id\": 0\n        },\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\"\n      }\n    ],\n    \"confirmation\": \"\",\n    \"created_at\": \"\",\n    \"created_in\": \"\",\n    \"custom_attributes\": [\n      {}\n    ],\n    \"default_billing\": \"\",\n    \"default_shipping\": \"\",\n    \"disable_auto_group_change\": 0,\n    \"dob\": \"\",\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"amazon_id\": \"\",\n      \"company_attributes\": {\n        \"company_id\": 0,\n        \"customer_id\": 0,\n        \"extension_attributes\": {},\n        \"job_title\": \"\",\n        \"status\": 0,\n        \"telephone\": \"\"\n      },\n      \"is_subscribed\": false,\n      \"vertex_customer_code\": \"\"\n    },\n    \"firstname\": \"\",\n    \"gender\": 0,\n    \"group_id\": 0,\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"prefix\": \"\",\n    \"store_id\": 0,\n    \"suffix\": \"\",\n    \"taxvat\": \"\",\n    \"updated_at\": \"\",\n    \"website_id\": 0\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}}/V1/customers/validate";

    let payload = json!({"customer": json!({
            "addresses": (
                json!({
                    "city": "",
                    "company": "",
                    "country_id": "",
                    "custom_attributes": (
                        json!({
                            "attribute_code": "",
                            "value": ""
                        })
                    ),
                    "customer_id": 0,
                    "default_billing": false,
                    "default_shipping": false,
                    "extension_attributes": json!({}),
                    "fax": "",
                    "firstname": "",
                    "id": 0,
                    "lastname": "",
                    "middlename": "",
                    "postcode": "",
                    "prefix": "",
                    "region": json!({
                        "extension_attributes": json!({}),
                        "region": "",
                        "region_code": "",
                        "region_id": 0
                    }),
                    "region_id": 0,
                    "street": (),
                    "suffix": "",
                    "telephone": "",
                    "vat_id": ""
                })
            ),
            "confirmation": "",
            "created_at": "",
            "created_in": "",
            "custom_attributes": (json!({})),
            "default_billing": "",
            "default_shipping": "",
            "disable_auto_group_change": 0,
            "dob": "",
            "email": "",
            "extension_attributes": json!({
                "amazon_id": "",
                "company_attributes": json!({
                    "company_id": 0,
                    "customer_id": 0,
                    "extension_attributes": json!({}),
                    "job_title": "",
                    "status": 0,
                    "telephone": ""
                }),
                "is_subscribed": false,
                "vertex_customer_code": ""
            }),
            "firstname": "",
            "gender": 0,
            "group_id": 0,
            "id": 0,
            "lastname": "",
            "middlename": "",
            "prefix": "",
            "store_id": 0,
            "suffix": "",
            "taxvat": "",
            "updated_at": "",
            "website_id": 0
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/customers/validate \
  --header 'content-type: application/json' \
  --data '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  }
}'
echo '{
  "customer": {
    "addresses": [
      {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": {},
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": {
          "extension_attributes": {},
          "region": "",
          "region_code": "",
          "region_id": 0
        },
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      }
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [
      {}
    ],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": {
      "amazon_id": "",
      "company_attributes": {
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": {},
        "job_title": "",
        "status": 0,
        "telephone": ""
      },
      "is_subscribed": false,
      "vertex_customer_code": ""
    },
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  }
}' |  \
  http PUT {{baseUrl}}/V1/customers/validate \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "customer": {\n    "addresses": [\n      {\n        "city": "",\n        "company": "",\n        "country_id": "",\n        "custom_attributes": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ],\n        "customer_id": 0,\n        "default_billing": false,\n        "default_shipping": false,\n        "extension_attributes": {},\n        "fax": "",\n        "firstname": "",\n        "id": 0,\n        "lastname": "",\n        "middlename": "",\n        "postcode": "",\n        "prefix": "",\n        "region": {\n          "extension_attributes": {},\n          "region": "",\n          "region_code": "",\n          "region_id": 0\n        },\n        "region_id": 0,\n        "street": [],\n        "suffix": "",\n        "telephone": "",\n        "vat_id": ""\n      }\n    ],\n    "confirmation": "",\n    "created_at": "",\n    "created_in": "",\n    "custom_attributes": [\n      {}\n    ],\n    "default_billing": "",\n    "default_shipping": "",\n    "disable_auto_group_change": 0,\n    "dob": "",\n    "email": "",\n    "extension_attributes": {\n      "amazon_id": "",\n      "company_attributes": {\n        "company_id": 0,\n        "customer_id": 0,\n        "extension_attributes": {},\n        "job_title": "",\n        "status": 0,\n        "telephone": ""\n      },\n      "is_subscribed": false,\n      "vertex_customer_code": ""\n    },\n    "firstname": "",\n    "gender": 0,\n    "group_id": 0,\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "prefix": "",\n    "store_id": 0,\n    "suffix": "",\n    "taxvat": "",\n    "updated_at": "",\n    "website_id": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/customers/validate
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["customer": [
    "addresses": [
      [
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
          [
            "attribute_code": "",
            "value": ""
          ]
        ],
        "customer_id": 0,
        "default_billing": false,
        "default_shipping": false,
        "extension_attributes": [],
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": [
          "extension_attributes": [],
          "region": "",
          "region_code": "",
          "region_id": 0
        ],
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
      ]
    ],
    "confirmation": "",
    "created_at": "",
    "created_in": "",
    "custom_attributes": [[]],
    "default_billing": "",
    "default_shipping": "",
    "disable_auto_group_change": 0,
    "dob": "",
    "email": "",
    "extension_attributes": [
      "amazon_id": "",
      "company_attributes": [
        "company_id": 0,
        "customer_id": 0,
        "extension_attributes": [],
        "job_title": "",
        "status": 0,
        "telephone": ""
      ],
      "is_subscribed": false,
      "vertex_customer_code": ""
    ],
    "firstname": "",
    "gender": 0,
    "group_id": 0,
    "id": 0,
    "lastname": "",
    "middlename": "",
    "prefix": "",
    "store_id": 0,
    "suffix": "",
    "taxvat": "",
    "updated_at": "",
    "website_id": 0
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/customers/validate")! 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 directory-countries
{{baseUrl}}/V1/directory/countries
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/directory/countries");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/directory/countries")
require "http/client"

url = "{{baseUrl}}/V1/directory/countries"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/directory/countries"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/directory/countries");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/directory/countries"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/directory/countries HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/directory/countries")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/directory/countries"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/directory/countries")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/directory/countries")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/directory/countries');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/directory/countries'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/directory/countries';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/directory/countries',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/directory/countries")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/directory/countries',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/directory/countries'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/directory/countries');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/directory/countries'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/directory/countries';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/directory/countries"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/directory/countries" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/directory/countries",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/directory/countries');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/directory/countries');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/directory/countries');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/directory/countries' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/directory/countries' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/directory/countries")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/directory/countries"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/directory/countries"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/directory/countries")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/directory/countries') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/directory/countries";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/directory/countries
http GET {{baseUrl}}/V1/directory/countries
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/directory/countries
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/directory/countries")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET directory-countries-{countryId}
{{baseUrl}}/V1/directory/countries/:countryId
QUERY PARAMS

countryId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/directory/countries/:countryId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/directory/countries/:countryId")
require "http/client"

url = "{{baseUrl}}/V1/directory/countries/:countryId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/directory/countries/:countryId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/directory/countries/:countryId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/directory/countries/:countryId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/directory/countries/:countryId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/directory/countries/:countryId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/directory/countries/:countryId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/directory/countries/:countryId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/directory/countries/:countryId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/directory/countries/:countryId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/directory/countries/:countryId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/directory/countries/:countryId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/directory/countries/:countryId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/directory/countries/:countryId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/directory/countries/:countryId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/directory/countries/:countryId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/directory/countries/:countryId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/directory/countries/:countryId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/directory/countries/:countryId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/directory/countries/:countryId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/directory/countries/:countryId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/directory/countries/:countryId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/directory/countries/:countryId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/directory/countries/:countryId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/directory/countries/:countryId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/directory/countries/:countryId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/directory/countries/:countryId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/directory/countries/:countryId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/directory/countries/:countryId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/directory/countries/:countryId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/directory/countries/:countryId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/directory/countries/:countryId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/directory/countries/:countryId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/directory/countries/:countryId
http GET {{baseUrl}}/V1/directory/countries/:countryId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/directory/countries/:countryId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/directory/countries/:countryId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET directory-currency
{{baseUrl}}/V1/directory/currency
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/directory/currency");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/directory/currency")
require "http/client"

url = "{{baseUrl}}/V1/directory/currency"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/directory/currency"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/directory/currency");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/directory/currency"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/directory/currency HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/directory/currency")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/directory/currency"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/directory/currency")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/directory/currency")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/directory/currency');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/directory/currency'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/directory/currency';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/directory/currency',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/directory/currency")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/directory/currency',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/directory/currency'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/directory/currency');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/directory/currency'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/directory/currency';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/directory/currency"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/directory/currency" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/directory/currency",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/directory/currency');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/directory/currency');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/directory/currency');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/directory/currency' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/directory/currency' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/directory/currency")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/directory/currency"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/directory/currency"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/directory/currency")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/directory/currency') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/directory/currency";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/directory/currency
http GET {{baseUrl}}/V1/directory/currency
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/directory/currency
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/directory/currency")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST eav-attribute-sets
{{baseUrl}}/V1/eav/attribute-sets
BODY json

{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  },
  "entityTypeCode": "",
  "skeletonId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/eav/attribute-sets");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"entityTypeCode\": \"\",\n  \"skeletonId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/eav/attribute-sets" {:content-type :json
                                                                  :form-params {:attributeSet {:attribute_set_id 0
                                                                                               :attribute_set_name ""
                                                                                               :entity_type_id 0
                                                                                               :extension_attributes {}
                                                                                               :sort_order 0}
                                                                                :entityTypeCode ""
                                                                                :skeletonId 0}})
require "http/client"

url = "{{baseUrl}}/V1/eav/attribute-sets"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"entityTypeCode\": \"\",\n  \"skeletonId\": 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}}/V1/eav/attribute-sets"),
    Content = new StringContent("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"entityTypeCode\": \"\",\n  \"skeletonId\": 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}}/V1/eav/attribute-sets");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"entityTypeCode\": \"\",\n  \"skeletonId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/eav/attribute-sets"

	payload := strings.NewReader("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"entityTypeCode\": \"\",\n  \"skeletonId\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/eav/attribute-sets HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 204

{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  },
  "entityTypeCode": "",
  "skeletonId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/eav/attribute-sets")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"entityTypeCode\": \"\",\n  \"skeletonId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/eav/attribute-sets"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"entityTypeCode\": \"\",\n  \"skeletonId\": 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  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"entityTypeCode\": \"\",\n  \"skeletonId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/eav/attribute-sets")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/eav/attribute-sets")
  .header("content-type", "application/json")
  .body("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"entityTypeCode\": \"\",\n  \"skeletonId\": 0\n}")
  .asString();
const data = JSON.stringify({
  attributeSet: {
    attribute_set_id: 0,
    attribute_set_name: '',
    entity_type_id: 0,
    extension_attributes: {},
    sort_order: 0
  },
  entityTypeCode: '',
  skeletonId: 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}}/V1/eav/attribute-sets');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/eav/attribute-sets',
  headers: {'content-type': 'application/json'},
  data: {
    attributeSet: {
      attribute_set_id: 0,
      attribute_set_name: '',
      entity_type_id: 0,
      extension_attributes: {},
      sort_order: 0
    },
    entityTypeCode: '',
    skeletonId: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/eav/attribute-sets';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"attributeSet":{"attribute_set_id":0,"attribute_set_name":"","entity_type_id":0,"extension_attributes":{},"sort_order":0},"entityTypeCode":"","skeletonId":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}}/V1/eav/attribute-sets',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attributeSet": {\n    "attribute_set_id": 0,\n    "attribute_set_name": "",\n    "entity_type_id": 0,\n    "extension_attributes": {},\n    "sort_order": 0\n  },\n  "entityTypeCode": "",\n  "skeletonId": 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  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"entityTypeCode\": \"\",\n  \"skeletonId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/eav/attribute-sets")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/eav/attribute-sets',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  attributeSet: {
    attribute_set_id: 0,
    attribute_set_name: '',
    entity_type_id: 0,
    extension_attributes: {},
    sort_order: 0
  },
  entityTypeCode: '',
  skeletonId: 0
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/eav/attribute-sets',
  headers: {'content-type': 'application/json'},
  body: {
    attributeSet: {
      attribute_set_id: 0,
      attribute_set_name: '',
      entity_type_id: 0,
      extension_attributes: {},
      sort_order: 0
    },
    entityTypeCode: '',
    skeletonId: 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}}/V1/eav/attribute-sets');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attributeSet: {
    attribute_set_id: 0,
    attribute_set_name: '',
    entity_type_id: 0,
    extension_attributes: {},
    sort_order: 0
  },
  entityTypeCode: '',
  skeletonId: 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}}/V1/eav/attribute-sets',
  headers: {'content-type': 'application/json'},
  data: {
    attributeSet: {
      attribute_set_id: 0,
      attribute_set_name: '',
      entity_type_id: 0,
      extension_attributes: {},
      sort_order: 0
    },
    entityTypeCode: '',
    skeletonId: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/eav/attribute-sets';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"attributeSet":{"attribute_set_id":0,"attribute_set_name":"","entity_type_id":0,"extension_attributes":{},"sort_order":0},"entityTypeCode":"","skeletonId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attributeSet": @{ @"attribute_set_id": @0, @"attribute_set_name": @"", @"entity_type_id": @0, @"extension_attributes": @{  }, @"sort_order": @0 },
                              @"entityTypeCode": @"",
                              @"skeletonId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/eav/attribute-sets"]
                                                       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}}/V1/eav/attribute-sets" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"entityTypeCode\": \"\",\n  \"skeletonId\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/eav/attribute-sets",
  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([
    'attributeSet' => [
        'attribute_set_id' => 0,
        'attribute_set_name' => '',
        'entity_type_id' => 0,
        'extension_attributes' => [
                
        ],
        'sort_order' => 0
    ],
    'entityTypeCode' => '',
    'skeletonId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/eav/attribute-sets', [
  'body' => '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  },
  "entityTypeCode": "",
  "skeletonId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/eav/attribute-sets');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attributeSet' => [
    'attribute_set_id' => 0,
    'attribute_set_name' => '',
    'entity_type_id' => 0,
    'extension_attributes' => [
        
    ],
    'sort_order' => 0
  ],
  'entityTypeCode' => '',
  'skeletonId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attributeSet' => [
    'attribute_set_id' => 0,
    'attribute_set_name' => '',
    'entity_type_id' => 0,
    'extension_attributes' => [
        
    ],
    'sort_order' => 0
  ],
  'entityTypeCode' => '',
  'skeletonId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/eav/attribute-sets');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/eav/attribute-sets' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  },
  "entityTypeCode": "",
  "skeletonId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/eav/attribute-sets' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  },
  "entityTypeCode": "",
  "skeletonId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"entityTypeCode\": \"\",\n  \"skeletonId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/eav/attribute-sets", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/eav/attribute-sets"

payload = {
    "attributeSet": {
        "attribute_set_id": 0,
        "attribute_set_name": "",
        "entity_type_id": 0,
        "extension_attributes": {},
        "sort_order": 0
    },
    "entityTypeCode": "",
    "skeletonId": 0
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/eav/attribute-sets"

payload <- "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"entityTypeCode\": \"\",\n  \"skeletonId\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/eav/attribute-sets")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"entityTypeCode\": \"\",\n  \"skeletonId\": 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/V1/eav/attribute-sets') do |req|
  req.body = "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"entityTypeCode\": \"\",\n  \"skeletonId\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/eav/attribute-sets";

    let payload = json!({
        "attributeSet": json!({
            "attribute_set_id": 0,
            "attribute_set_name": "",
            "entity_type_id": 0,
            "extension_attributes": json!({}),
            "sort_order": 0
        }),
        "entityTypeCode": "",
        "skeletonId": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/eav/attribute-sets \
  --header 'content-type: application/json' \
  --data '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  },
  "entityTypeCode": "",
  "skeletonId": 0
}'
echo '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  },
  "entityTypeCode": "",
  "skeletonId": 0
}' |  \
  http POST {{baseUrl}}/V1/eav/attribute-sets \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "attributeSet": {\n    "attribute_set_id": 0,\n    "attribute_set_name": "",\n    "entity_type_id": 0,\n    "extension_attributes": {},\n    "sort_order": 0\n  },\n  "entityTypeCode": "",\n  "skeletonId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/eav/attribute-sets
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "attributeSet": [
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": [],
    "sort_order": 0
  ],
  "entityTypeCode": "",
  "skeletonId": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/eav/attribute-sets")! 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 eav-attribute-sets-{attributeSetId} (GET)
{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId
QUERY PARAMS

attributeSetId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")
require "http/client"

url = "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/eav/attribute-sets/:attributeSetId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/eav/attribute-sets/:attributeSetId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/eav/attribute-sets/:attributeSetId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/eav/attribute-sets/:attributeSetId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/eav/attribute-sets/:attributeSetId
http GET {{baseUrl}}/V1/eav/attribute-sets/:attributeSetId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/eav/attribute-sets/:attributeSetId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT eav-attribute-sets-{attributeSetId} (PUT)
{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId
QUERY PARAMS

attributeSetId
BODY json

{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId" {:content-type :json
                                                                                 :form-params {:attributeSet {:attribute_set_id 0
                                                                                                              :attribute_set_name ""
                                                                                                              :entity_type_id 0
                                                                                                              :extension_attributes {}
                                                                                                              :sort_order 0}}})
require "http/client"

url = "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\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}}/V1/eav/attribute-sets/:attributeSetId"),
    Content = new StringContent("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\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}}/V1/eav/attribute-sets/:attributeSetId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"

	payload := strings.NewReader("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/eav/attribute-sets/:attributeSetId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 161

{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\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  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")
  .header("content-type", "application/json")
  .body("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  attributeSet: {
    attribute_set_id: 0,
    attribute_set_name: '',
    entity_type_id: 0,
    extension_attributes: {},
    sort_order: 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}}/V1/eav/attribute-sets/:attributeSetId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId',
  headers: {'content-type': 'application/json'},
  data: {
    attributeSet: {
      attribute_set_id: 0,
      attribute_set_name: '',
      entity_type_id: 0,
      extension_attributes: {},
      sort_order: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"attributeSet":{"attribute_set_id":0,"attribute_set_name":"","entity_type_id":0,"extension_attributes":{},"sort_order":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}}/V1/eav/attribute-sets/:attributeSetId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attributeSet": {\n    "attribute_set_id": 0,\n    "attribute_set_name": "",\n    "entity_type_id": 0,\n    "extension_attributes": {},\n    "sort_order": 0\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  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/eav/attribute-sets/:attributeSetId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  attributeSet: {
    attribute_set_id: 0,
    attribute_set_name: '',
    entity_type_id: 0,
    extension_attributes: {},
    sort_order: 0
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId',
  headers: {'content-type': 'application/json'},
  body: {
    attributeSet: {
      attribute_set_id: 0,
      attribute_set_name: '',
      entity_type_id: 0,
      extension_attributes: {},
      sort_order: 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}}/V1/eav/attribute-sets/:attributeSetId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attributeSet: {
    attribute_set_id: 0,
    attribute_set_name: '',
    entity_type_id: 0,
    extension_attributes: {},
    sort_order: 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}}/V1/eav/attribute-sets/:attributeSetId',
  headers: {'content-type': 'application/json'},
  data: {
    attributeSet: {
      attribute_set_id: 0,
      attribute_set_name: '',
      entity_type_id: 0,
      extension_attributes: {},
      sort_order: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"attributeSet":{"attribute_set_id":0,"attribute_set_name":"","entity_type_id":0,"extension_attributes":{},"sort_order":0}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attributeSet": @{ @"attribute_set_id": @0, @"attribute_set_name": @"", @"entity_type_id": @0, @"extension_attributes": @{  }, @"sort_order": @0 } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"]
                                                       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}}/V1/eav/attribute-sets/:attributeSetId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId",
  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([
    'attributeSet' => [
        'attribute_set_id' => 0,
        'attribute_set_name' => '',
        'entity_type_id' => 0,
        'extension_attributes' => [
                
        ],
        'sort_order' => 0
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId', [
  'body' => '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attributeSet' => [
    'attribute_set_id' => 0,
    'attribute_set_name' => '',
    'entity_type_id' => 0,
    'extension_attributes' => [
        
    ],
    'sort_order' => 0
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attributeSet' => [
    'attribute_set_id' => 0,
    'attribute_set_name' => '',
    'entity_type_id' => 0,
    'extension_attributes' => [
        
    ],
    'sort_order' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/eav/attribute-sets/:attributeSetId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"

payload = { "attributeSet": {
        "attribute_set_id": 0,
        "attribute_set_name": "",
        "entity_type_id": 0,
        "extension_attributes": {},
        "sort_order": 0
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"

payload <- "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\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/V1/eav/attribute-sets/:attributeSetId') do |req|
  req.body = "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\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}}/V1/eav/attribute-sets/:attributeSetId";

    let payload = json!({"attributeSet": json!({
            "attribute_set_id": 0,
            "attribute_set_name": "",
            "entity_type_id": 0,
            "extension_attributes": json!({}),
            "sort_order": 0
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/eav/attribute-sets/:attributeSetId \
  --header 'content-type: application/json' \
  --data '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  }
}'
echo '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  }
}' |  \
  http PUT {{baseUrl}}/V1/eav/attribute-sets/:attributeSetId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "attributeSet": {\n    "attribute_set_id": 0,\n    "attribute_set_name": "",\n    "entity_type_id": 0,\n    "extension_attributes": {},\n    "sort_order": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/eav/attribute-sets/:attributeSetId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["attributeSet": [
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": [],
    "sort_order": 0
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")! 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()
DELETE eav-attribute-sets-{attributeSetId}
{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId
QUERY PARAMS

attributeSetId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")
require "http/client"

url = "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/eav/attribute-sets/:attributeSetId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"))
    .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}}/V1/eav/attribute-sets/:attributeSetId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")
  .asString();
const 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}}/V1/eav/attribute-sets/:attributeSetId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/eav/attribute-sets/:attributeSetId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId');

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}}/V1/eav/attribute-sets/:attributeSetId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/eav/attribute-sets/:attributeSetId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/eav/attribute-sets/:attributeSetId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/eav/attribute-sets/:attributeSetId
http DELETE {{baseUrl}}/V1/eav/attribute-sets/:attributeSetId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/eav/attribute-sets/:attributeSetId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/eav/attribute-sets/:attributeSetId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET eav-attribute-sets-list
{{baseUrl}}/V1/eav/attribute-sets/list
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/eav/attribute-sets/list");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/eav/attribute-sets/list")
require "http/client"

url = "{{baseUrl}}/V1/eav/attribute-sets/list"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/eav/attribute-sets/list"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/eav/attribute-sets/list");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/eav/attribute-sets/list"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/eav/attribute-sets/list HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/eav/attribute-sets/list")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/eav/attribute-sets/list"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/eav/attribute-sets/list")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/eav/attribute-sets/list")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/eav/attribute-sets/list');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/eav/attribute-sets/list'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/eav/attribute-sets/list';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/eav/attribute-sets/list',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/eav/attribute-sets/list")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/eav/attribute-sets/list',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/eav/attribute-sets/list'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/eav/attribute-sets/list');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/eav/attribute-sets/list'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/eav/attribute-sets/list';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/eav/attribute-sets/list"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/eav/attribute-sets/list" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/eav/attribute-sets/list",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/eav/attribute-sets/list');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/eav/attribute-sets/list');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/eav/attribute-sets/list');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/eav/attribute-sets/list' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/eav/attribute-sets/list' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/eav/attribute-sets/list")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/eav/attribute-sets/list"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/eav/attribute-sets/list"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/eav/attribute-sets/list")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/eav/attribute-sets/list') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/eav/attribute-sets/list";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/eav/attribute-sets/list
http GET {{baseUrl}}/V1/eav/attribute-sets/list
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/eav/attribute-sets/list
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/eav/attribute-sets/list")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST gift-wrappings (POST)
{{baseUrl}}/V1/gift-wrappings
BODY json

{
  "data": {
    "base_currency_code": "",
    "base_price": "",
    "design": "",
    "extension_attributes": {},
    "image_base64_content": "",
    "image_name": "",
    "image_url": "",
    "status": 0,
    "website_ids": [],
    "wrapping_id": 0
  },
  "storeId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/gift-wrappings");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/gift-wrappings" {:content-type :json
                                                              :form-params {:data {:base_currency_code ""
                                                                                   :base_price ""
                                                                                   :design ""
                                                                                   :extension_attributes {}
                                                                                   :image_base64_content ""
                                                                                   :image_name ""
                                                                                   :image_url ""
                                                                                   :status 0
                                                                                   :website_ids []
                                                                                   :wrapping_id 0}
                                                                            :storeId 0}})
require "http/client"

url = "{{baseUrl}}/V1/gift-wrappings"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 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}}/V1/gift-wrappings"),
    Content = new StringContent("{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 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}}/V1/gift-wrappings");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/gift-wrappings"

	payload := strings.NewReader("{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/gift-wrappings HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 273

{
  "data": {
    "base_currency_code": "",
    "base_price": "",
    "design": "",
    "extension_attributes": {},
    "image_base64_content": "",
    "image_name": "",
    "image_url": "",
    "status": 0,
    "website_ids": [],
    "wrapping_id": 0
  },
  "storeId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/gift-wrappings")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/gift-wrappings"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 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  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/gift-wrappings")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/gift-wrappings")
  .header("content-type", "application/json")
  .body("{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}")
  .asString();
const data = JSON.stringify({
  data: {
    base_currency_code: '',
    base_price: '',
    design: '',
    extension_attributes: {},
    image_base64_content: '',
    image_name: '',
    image_url: '',
    status: 0,
    website_ids: [],
    wrapping_id: 0
  },
  storeId: 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}}/V1/gift-wrappings');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/gift-wrappings',
  headers: {'content-type': 'application/json'},
  data: {
    data: {
      base_currency_code: '',
      base_price: '',
      design: '',
      extension_attributes: {},
      image_base64_content: '',
      image_name: '',
      image_url: '',
      status: 0,
      website_ids: [],
      wrapping_id: 0
    },
    storeId: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/gift-wrappings';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"data":{"base_currency_code":"","base_price":"","design":"","extension_attributes":{},"image_base64_content":"","image_name":"","image_url":"","status":0,"website_ids":[],"wrapping_id":0},"storeId":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}}/V1/gift-wrappings',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "data": {\n    "base_currency_code": "",\n    "base_price": "",\n    "design": "",\n    "extension_attributes": {},\n    "image_base64_content": "",\n    "image_name": "",\n    "image_url": "",\n    "status": 0,\n    "website_ids": [],\n    "wrapping_id": 0\n  },\n  "storeId": 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  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/gift-wrappings")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/gift-wrappings',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  data: {
    base_currency_code: '',
    base_price: '',
    design: '',
    extension_attributes: {},
    image_base64_content: '',
    image_name: '',
    image_url: '',
    status: 0,
    website_ids: [],
    wrapping_id: 0
  },
  storeId: 0
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/gift-wrappings',
  headers: {'content-type': 'application/json'},
  body: {
    data: {
      base_currency_code: '',
      base_price: '',
      design: '',
      extension_attributes: {},
      image_base64_content: '',
      image_name: '',
      image_url: '',
      status: 0,
      website_ids: [],
      wrapping_id: 0
    },
    storeId: 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}}/V1/gift-wrappings');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  data: {
    base_currency_code: '',
    base_price: '',
    design: '',
    extension_attributes: {},
    image_base64_content: '',
    image_name: '',
    image_url: '',
    status: 0,
    website_ids: [],
    wrapping_id: 0
  },
  storeId: 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}}/V1/gift-wrappings',
  headers: {'content-type': 'application/json'},
  data: {
    data: {
      base_currency_code: '',
      base_price: '',
      design: '',
      extension_attributes: {},
      image_base64_content: '',
      image_name: '',
      image_url: '',
      status: 0,
      website_ids: [],
      wrapping_id: 0
    },
    storeId: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/gift-wrappings';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"data":{"base_currency_code":"","base_price":"","design":"","extension_attributes":{},"image_base64_content":"","image_name":"","image_url":"","status":0,"website_ids":[],"wrapping_id":0},"storeId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"data": @{ @"base_currency_code": @"", @"base_price": @"", @"design": @"", @"extension_attributes": @{  }, @"image_base64_content": @"", @"image_name": @"", @"image_url": @"", @"status": @0, @"website_ids": @[  ], @"wrapping_id": @0 },
                              @"storeId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/gift-wrappings"]
                                                       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}}/V1/gift-wrappings" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/gift-wrappings",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'data' => [
        'base_currency_code' => '',
        'base_price' => '',
        'design' => '',
        'extension_attributes' => [
                
        ],
        'image_base64_content' => '',
        'image_name' => '',
        'image_url' => '',
        'status' => 0,
        'website_ids' => [
                
        ],
        'wrapping_id' => 0
    ],
    'storeId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/gift-wrappings', [
  'body' => '{
  "data": {
    "base_currency_code": "",
    "base_price": "",
    "design": "",
    "extension_attributes": {},
    "image_base64_content": "",
    "image_name": "",
    "image_url": "",
    "status": 0,
    "website_ids": [],
    "wrapping_id": 0
  },
  "storeId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/gift-wrappings');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'data' => [
    'base_currency_code' => '',
    'base_price' => '',
    'design' => '',
    'extension_attributes' => [
        
    ],
    'image_base64_content' => '',
    'image_name' => '',
    'image_url' => '',
    'status' => 0,
    'website_ids' => [
        
    ],
    'wrapping_id' => 0
  ],
  'storeId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'data' => [
    'base_currency_code' => '',
    'base_price' => '',
    'design' => '',
    'extension_attributes' => [
        
    ],
    'image_base64_content' => '',
    'image_name' => '',
    'image_url' => '',
    'status' => 0,
    'website_ids' => [
        
    ],
    'wrapping_id' => 0
  ],
  'storeId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/gift-wrappings');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/gift-wrappings' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "data": {
    "base_currency_code": "",
    "base_price": "",
    "design": "",
    "extension_attributes": {},
    "image_base64_content": "",
    "image_name": "",
    "image_url": "",
    "status": 0,
    "website_ids": [],
    "wrapping_id": 0
  },
  "storeId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/gift-wrappings' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "data": {
    "base_currency_code": "",
    "base_price": "",
    "design": "",
    "extension_attributes": {},
    "image_base64_content": "",
    "image_name": "",
    "image_url": "",
    "status": 0,
    "website_ids": [],
    "wrapping_id": 0
  },
  "storeId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/gift-wrappings", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/gift-wrappings"

payload = {
    "data": {
        "base_currency_code": "",
        "base_price": "",
        "design": "",
        "extension_attributes": {},
        "image_base64_content": "",
        "image_name": "",
        "image_url": "",
        "status": 0,
        "website_ids": [],
        "wrapping_id": 0
    },
    "storeId": 0
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/gift-wrappings"

payload <- "{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/gift-wrappings")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 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/V1/gift-wrappings') do |req|
  req.body = "{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/gift-wrappings";

    let payload = json!({
        "data": json!({
            "base_currency_code": "",
            "base_price": "",
            "design": "",
            "extension_attributes": json!({}),
            "image_base64_content": "",
            "image_name": "",
            "image_url": "",
            "status": 0,
            "website_ids": (),
            "wrapping_id": 0
        }),
        "storeId": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/gift-wrappings \
  --header 'content-type: application/json' \
  --data '{
  "data": {
    "base_currency_code": "",
    "base_price": "",
    "design": "",
    "extension_attributes": {},
    "image_base64_content": "",
    "image_name": "",
    "image_url": "",
    "status": 0,
    "website_ids": [],
    "wrapping_id": 0
  },
  "storeId": 0
}'
echo '{
  "data": {
    "base_currency_code": "",
    "base_price": "",
    "design": "",
    "extension_attributes": {},
    "image_base64_content": "",
    "image_name": "",
    "image_url": "",
    "status": 0,
    "website_ids": [],
    "wrapping_id": 0
  },
  "storeId": 0
}' |  \
  http POST {{baseUrl}}/V1/gift-wrappings \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "data": {\n    "base_currency_code": "",\n    "base_price": "",\n    "design": "",\n    "extension_attributes": {},\n    "image_base64_content": "",\n    "image_name": "",\n    "image_url": "",\n    "status": 0,\n    "website_ids": [],\n    "wrapping_id": 0\n  },\n  "storeId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/gift-wrappings
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "data": [
    "base_currency_code": "",
    "base_price": "",
    "design": "",
    "extension_attributes": [],
    "image_base64_content": "",
    "image_name": "",
    "image_url": "",
    "status": 0,
    "website_ids": [],
    "wrapping_id": 0
  ],
  "storeId": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/gift-wrappings")! 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 gift-wrappings
{{baseUrl}}/V1/gift-wrappings
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/gift-wrappings");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/gift-wrappings")
require "http/client"

url = "{{baseUrl}}/V1/gift-wrappings"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/gift-wrappings"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/gift-wrappings");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/gift-wrappings"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/gift-wrappings HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/gift-wrappings")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/gift-wrappings"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/gift-wrappings")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/gift-wrappings")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/gift-wrappings');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/gift-wrappings'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/gift-wrappings';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/gift-wrappings',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/gift-wrappings")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/gift-wrappings',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/gift-wrappings'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/gift-wrappings');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/gift-wrappings'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/gift-wrappings';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/gift-wrappings"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/gift-wrappings" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/gift-wrappings",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/gift-wrappings');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/gift-wrappings');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/gift-wrappings');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/gift-wrappings' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/gift-wrappings' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/gift-wrappings")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/gift-wrappings"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/gift-wrappings"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/gift-wrappings")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/gift-wrappings') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/gift-wrappings";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/gift-wrappings
http GET {{baseUrl}}/V1/gift-wrappings
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/gift-wrappings
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/gift-wrappings")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET gift-wrappings-{id} (GET)
{{baseUrl}}/V1/gift-wrappings/:id
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/gift-wrappings/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/gift-wrappings/:id")
require "http/client"

url = "{{baseUrl}}/V1/gift-wrappings/:id"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/gift-wrappings/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/gift-wrappings/:id");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/gift-wrappings/:id"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/gift-wrappings/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/gift-wrappings/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/gift-wrappings/:id"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/gift-wrappings/:id")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/gift-wrappings/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/gift-wrappings/:id');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/gift-wrappings/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/gift-wrappings/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/gift-wrappings/:id',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/gift-wrappings/:id")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/gift-wrappings/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/gift-wrappings/:id'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/gift-wrappings/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/gift-wrappings/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/gift-wrappings/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/gift-wrappings/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/gift-wrappings/:id" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/gift-wrappings/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/gift-wrappings/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/gift-wrappings/:id');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/gift-wrappings/:id');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/gift-wrappings/:id' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/gift-wrappings/:id' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/gift-wrappings/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/gift-wrappings/:id"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/gift-wrappings/:id"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/gift-wrappings/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/gift-wrappings/:id') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/gift-wrappings/:id";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/gift-wrappings/:id
http GET {{baseUrl}}/V1/gift-wrappings/:id
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/gift-wrappings/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/gift-wrappings/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE gift-wrappings-{id}
{{baseUrl}}/V1/gift-wrappings/:id
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/gift-wrappings/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/gift-wrappings/:id")
require "http/client"

url = "{{baseUrl}}/V1/gift-wrappings/:id"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/gift-wrappings/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/gift-wrappings/:id");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/gift-wrappings/:id"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/gift-wrappings/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/gift-wrappings/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/gift-wrappings/:id"))
    .method("DELETE", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/gift-wrappings/:id")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/gift-wrappings/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/V1/gift-wrappings/:id');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/gift-wrappings/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/gift-wrappings/:id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/gift-wrappings/:id',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/gift-wrappings/:id")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/gift-wrappings/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/gift-wrappings/:id'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/gift-wrappings/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/gift-wrappings/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/gift-wrappings/:id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/gift-wrappings/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/gift-wrappings/:id" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/gift-wrappings/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/gift-wrappings/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/gift-wrappings/:id');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/gift-wrappings/:id');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/gift-wrappings/:id' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/gift-wrappings/:id' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/gift-wrappings/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/gift-wrappings/:id"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/gift-wrappings/:id"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/gift-wrappings/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/gift-wrappings/:id') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/gift-wrappings/:id";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/gift-wrappings/:id
http DELETE {{baseUrl}}/V1/gift-wrappings/:id
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/gift-wrappings/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/gift-wrappings/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT gift-wrappings-{wrappingId}
{{baseUrl}}/V1/gift-wrappings/:wrappingId
QUERY PARAMS

wrappingId
BODY json

{
  "data": {
    "base_currency_code": "",
    "base_price": "",
    "design": "",
    "extension_attributes": {},
    "image_base64_content": "",
    "image_name": "",
    "image_url": "",
    "status": 0,
    "website_ids": [],
    "wrapping_id": 0
  },
  "storeId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/gift-wrappings/:wrappingId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/gift-wrappings/:wrappingId" {:content-type :json
                                                                         :form-params {:data {:base_currency_code ""
                                                                                              :base_price ""
                                                                                              :design ""
                                                                                              :extension_attributes {}
                                                                                              :image_base64_content ""
                                                                                              :image_name ""
                                                                                              :image_url ""
                                                                                              :status 0
                                                                                              :website_ids []
                                                                                              :wrapping_id 0}
                                                                                       :storeId 0}})
require "http/client"

url = "{{baseUrl}}/V1/gift-wrappings/:wrappingId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 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}}/V1/gift-wrappings/:wrappingId"),
    Content = new StringContent("{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 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}}/V1/gift-wrappings/:wrappingId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/gift-wrappings/:wrappingId"

	payload := strings.NewReader("{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/gift-wrappings/:wrappingId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 273

{
  "data": {
    "base_currency_code": "",
    "base_price": "",
    "design": "",
    "extension_attributes": {},
    "image_base64_content": "",
    "image_name": "",
    "image_url": "",
    "status": 0,
    "website_ids": [],
    "wrapping_id": 0
  },
  "storeId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/gift-wrappings/:wrappingId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/gift-wrappings/:wrappingId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 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  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/gift-wrappings/:wrappingId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/gift-wrappings/:wrappingId")
  .header("content-type", "application/json")
  .body("{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}")
  .asString();
const data = JSON.stringify({
  data: {
    base_currency_code: '',
    base_price: '',
    design: '',
    extension_attributes: {},
    image_base64_content: '',
    image_name: '',
    image_url: '',
    status: 0,
    website_ids: [],
    wrapping_id: 0
  },
  storeId: 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}}/V1/gift-wrappings/:wrappingId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/gift-wrappings/:wrappingId',
  headers: {'content-type': 'application/json'},
  data: {
    data: {
      base_currency_code: '',
      base_price: '',
      design: '',
      extension_attributes: {},
      image_base64_content: '',
      image_name: '',
      image_url: '',
      status: 0,
      website_ids: [],
      wrapping_id: 0
    },
    storeId: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/gift-wrappings/:wrappingId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"data":{"base_currency_code":"","base_price":"","design":"","extension_attributes":{},"image_base64_content":"","image_name":"","image_url":"","status":0,"website_ids":[],"wrapping_id":0},"storeId":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}}/V1/gift-wrappings/:wrappingId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "data": {\n    "base_currency_code": "",\n    "base_price": "",\n    "design": "",\n    "extension_attributes": {},\n    "image_base64_content": "",\n    "image_name": "",\n    "image_url": "",\n    "status": 0,\n    "website_ids": [],\n    "wrapping_id": 0\n  },\n  "storeId": 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  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/gift-wrappings/:wrappingId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/gift-wrappings/:wrappingId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  data: {
    base_currency_code: '',
    base_price: '',
    design: '',
    extension_attributes: {},
    image_base64_content: '',
    image_name: '',
    image_url: '',
    status: 0,
    website_ids: [],
    wrapping_id: 0
  },
  storeId: 0
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/gift-wrappings/:wrappingId',
  headers: {'content-type': 'application/json'},
  body: {
    data: {
      base_currency_code: '',
      base_price: '',
      design: '',
      extension_attributes: {},
      image_base64_content: '',
      image_name: '',
      image_url: '',
      status: 0,
      website_ids: [],
      wrapping_id: 0
    },
    storeId: 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}}/V1/gift-wrappings/:wrappingId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  data: {
    base_currency_code: '',
    base_price: '',
    design: '',
    extension_attributes: {},
    image_base64_content: '',
    image_name: '',
    image_url: '',
    status: 0,
    website_ids: [],
    wrapping_id: 0
  },
  storeId: 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}}/V1/gift-wrappings/:wrappingId',
  headers: {'content-type': 'application/json'},
  data: {
    data: {
      base_currency_code: '',
      base_price: '',
      design: '',
      extension_attributes: {},
      image_base64_content: '',
      image_name: '',
      image_url: '',
      status: 0,
      website_ids: [],
      wrapping_id: 0
    },
    storeId: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/gift-wrappings/:wrappingId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"data":{"base_currency_code":"","base_price":"","design":"","extension_attributes":{},"image_base64_content":"","image_name":"","image_url":"","status":0,"website_ids":[],"wrapping_id":0},"storeId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"data": @{ @"base_currency_code": @"", @"base_price": @"", @"design": @"", @"extension_attributes": @{  }, @"image_base64_content": @"", @"image_name": @"", @"image_url": @"", @"status": @0, @"website_ids": @[  ], @"wrapping_id": @0 },
                              @"storeId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/gift-wrappings/:wrappingId"]
                                                       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}}/V1/gift-wrappings/:wrappingId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/gift-wrappings/:wrappingId",
  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([
    'data' => [
        'base_currency_code' => '',
        'base_price' => '',
        'design' => '',
        'extension_attributes' => [
                
        ],
        'image_base64_content' => '',
        'image_name' => '',
        'image_url' => '',
        'status' => 0,
        'website_ids' => [
                
        ],
        'wrapping_id' => 0
    ],
    'storeId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/gift-wrappings/:wrappingId', [
  'body' => '{
  "data": {
    "base_currency_code": "",
    "base_price": "",
    "design": "",
    "extension_attributes": {},
    "image_base64_content": "",
    "image_name": "",
    "image_url": "",
    "status": 0,
    "website_ids": [],
    "wrapping_id": 0
  },
  "storeId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/gift-wrappings/:wrappingId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'data' => [
    'base_currency_code' => '',
    'base_price' => '',
    'design' => '',
    'extension_attributes' => [
        
    ],
    'image_base64_content' => '',
    'image_name' => '',
    'image_url' => '',
    'status' => 0,
    'website_ids' => [
        
    ],
    'wrapping_id' => 0
  ],
  'storeId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'data' => [
    'base_currency_code' => '',
    'base_price' => '',
    'design' => '',
    'extension_attributes' => [
        
    ],
    'image_base64_content' => '',
    'image_name' => '',
    'image_url' => '',
    'status' => 0,
    'website_ids' => [
        
    ],
    'wrapping_id' => 0
  ],
  'storeId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/gift-wrappings/:wrappingId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/gift-wrappings/:wrappingId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "data": {
    "base_currency_code": "",
    "base_price": "",
    "design": "",
    "extension_attributes": {},
    "image_base64_content": "",
    "image_name": "",
    "image_url": "",
    "status": 0,
    "website_ids": [],
    "wrapping_id": 0
  },
  "storeId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/gift-wrappings/:wrappingId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "data": {
    "base_currency_code": "",
    "base_price": "",
    "design": "",
    "extension_attributes": {},
    "image_base64_content": "",
    "image_name": "",
    "image_url": "",
    "status": 0,
    "website_ids": [],
    "wrapping_id": 0
  },
  "storeId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/gift-wrappings/:wrappingId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/gift-wrappings/:wrappingId"

payload = {
    "data": {
        "base_currency_code": "",
        "base_price": "",
        "design": "",
        "extension_attributes": {},
        "image_base64_content": "",
        "image_name": "",
        "image_url": "",
        "status": 0,
        "website_ids": [],
        "wrapping_id": 0
    },
    "storeId": 0
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/gift-wrappings/:wrappingId"

payload <- "{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 0\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/gift-wrappings/:wrappingId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 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/V1/gift-wrappings/:wrappingId') do |req|
  req.body = "{\n  \"data\": {\n    \"base_currency_code\": \"\",\n    \"base_price\": \"\",\n    \"design\": \"\",\n    \"extension_attributes\": {},\n    \"image_base64_content\": \"\",\n    \"image_name\": \"\",\n    \"image_url\": \"\",\n    \"status\": 0,\n    \"website_ids\": [],\n    \"wrapping_id\": 0\n  },\n  \"storeId\": 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}}/V1/gift-wrappings/:wrappingId";

    let payload = json!({
        "data": json!({
            "base_currency_code": "",
            "base_price": "",
            "design": "",
            "extension_attributes": json!({}),
            "image_base64_content": "",
            "image_name": "",
            "image_url": "",
            "status": 0,
            "website_ids": (),
            "wrapping_id": 0
        }),
        "storeId": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/gift-wrappings/:wrappingId \
  --header 'content-type: application/json' \
  --data '{
  "data": {
    "base_currency_code": "",
    "base_price": "",
    "design": "",
    "extension_attributes": {},
    "image_base64_content": "",
    "image_name": "",
    "image_url": "",
    "status": 0,
    "website_ids": [],
    "wrapping_id": 0
  },
  "storeId": 0
}'
echo '{
  "data": {
    "base_currency_code": "",
    "base_price": "",
    "design": "",
    "extension_attributes": {},
    "image_base64_content": "",
    "image_name": "",
    "image_url": "",
    "status": 0,
    "website_ids": [],
    "wrapping_id": 0
  },
  "storeId": 0
}' |  \
  http PUT {{baseUrl}}/V1/gift-wrappings/:wrappingId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "data": {\n    "base_currency_code": "",\n    "base_price": "",\n    "design": "",\n    "extension_attributes": {},\n    "image_base64_content": "",\n    "image_name": "",\n    "image_url": "",\n    "status": 0,\n    "website_ids": [],\n    "wrapping_id": 0\n  },\n  "storeId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/gift-wrappings/:wrappingId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "data": [
    "base_currency_code": "",
    "base_price": "",
    "design": "",
    "extension_attributes": [],
    "image_base64_content": "",
    "image_name": "",
    "image_url": "",
    "status": 0,
    "website_ids": [],
    "wrapping_id": 0
  ],
  "storeId": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/gift-wrappings/:wrappingId")! 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 giftregistry-mine-estimate-shipping-methods
{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods
BODY json

{
  "registryId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"registryId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods" {:content-type :json
                                                                                           :form-params {:registryId 0}})
require "http/client"

url = "{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"registryId\": 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}}/V1/giftregistry/mine/estimate-shipping-methods"),
    Content = new StringContent("{\n  \"registryId\": 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}}/V1/giftregistry/mine/estimate-shipping-methods");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"registryId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods"

	payload := strings.NewReader("{\n  \"registryId\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/giftregistry/mine/estimate-shipping-methods HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 21

{
  "registryId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"registryId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"registryId\": 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  \"registryId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods")
  .header("content-type", "application/json")
  .body("{\n  \"registryId\": 0\n}")
  .asString();
const data = JSON.stringify({
  registryId: 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}}/V1/giftregistry/mine/estimate-shipping-methods');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  data: {registryId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"registryId":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}}/V1/giftregistry/mine/estimate-shipping-methods',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "registryId": 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  \"registryId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/giftregistry/mine/estimate-shipping-methods',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({registryId: 0}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  body: {registryId: 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}}/V1/giftregistry/mine/estimate-shipping-methods');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  registryId: 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}}/V1/giftregistry/mine/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  data: {registryId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"registryId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"registryId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods"]
                                                       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}}/V1/giftregistry/mine/estimate-shipping-methods" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"registryId\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods",
  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([
    'registryId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods', [
  'body' => '{
  "registryId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'registryId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'registryId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "registryId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "registryId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"registryId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/giftregistry/mine/estimate-shipping-methods", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods"

payload = { "registryId": 0 }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods"

payload <- "{\n  \"registryId\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"registryId\": 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/V1/giftregistry/mine/estimate-shipping-methods') do |req|
  req.body = "{\n  \"registryId\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods";

    let payload = json!({"registryId": 0});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods \
  --header 'content-type: application/json' \
  --data '{
  "registryId": 0
}'
echo '{
  "registryId": 0
}' |  \
  http POST {{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "registryId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["registryId": 0] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/giftregistry/mine/estimate-shipping-methods")! 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 guest-carts
{{baseUrl}}/V1/guest-carts
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/guest-carts")
require "http/client"

url = "{{baseUrl}}/V1/guest-carts"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/guest-carts"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/guest-carts");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/guest-carts HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/guest-carts")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts"))
    .method("POST", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/guest-carts")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/guest-carts');

xhr.send(data);
import axios from 'axios';

const options = {method: 'POST', url: '{{baseUrl}}/V1/guest-carts'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'POST', url: '{{baseUrl}}/V1/guest-carts'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/guest-carts');

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}}/V1/guest-carts'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/guest-carts');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/guest-carts');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/V1/guest-carts")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/V1/guest-carts') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/guest-carts
http POST {{baseUrl}}/V1/guest-carts
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/V1/guest-carts
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT guest-carts-{cartId} (PUT)
{{baseUrl}}/V1/guest-carts/:cartId
QUERY PARAMS

cartId
BODY json

{
  "customerId": 0,
  "storeId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"customerId\": 0,\n  \"storeId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/guest-carts/:cartId" {:content-type :json
                                                                  :form-params {:customerId 0
                                                                                :storeId 0}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"customerId\": 0,\n  \"storeId\": 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}}/V1/guest-carts/:cartId"),
    Content = new StringContent("{\n  \"customerId\": 0,\n  \"storeId\": 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}}/V1/guest-carts/:cartId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"customerId\": 0,\n  \"storeId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId"

	payload := strings.NewReader("{\n  \"customerId\": 0,\n  \"storeId\": 0\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/guest-carts/:cartId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 37

{
  "customerId": 0,
  "storeId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/guest-carts/:cartId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"customerId\": 0,\n  \"storeId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"customerId\": 0,\n  \"storeId\": 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  \"customerId\": 0,\n  \"storeId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/guest-carts/:cartId")
  .header("content-type", "application/json")
  .body("{\n  \"customerId\": 0,\n  \"storeId\": 0\n}")
  .asString();
const data = JSON.stringify({
  customerId: 0,
  storeId: 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}}/V1/guest-carts/:cartId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/guest-carts/:cartId',
  headers: {'content-type': 'application/json'},
  data: {customerId: 0, storeId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"customerId":0,"storeId":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}}/V1/guest-carts/:cartId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "customerId": 0,\n  "storeId": 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  \"customerId\": 0,\n  \"storeId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({customerId: 0, storeId: 0}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/guest-carts/:cartId',
  headers: {'content-type': 'application/json'},
  body: {customerId: 0, storeId: 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}}/V1/guest-carts/:cartId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  customerId: 0,
  storeId: 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}}/V1/guest-carts/:cartId',
  headers: {'content-type': 'application/json'},
  data: {customerId: 0, storeId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"customerId":0,"storeId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"customerId": @0,
                              @"storeId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId"]
                                                       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}}/V1/guest-carts/:cartId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"customerId\": 0,\n  \"storeId\": 0\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId",
  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([
    'customerId' => 0,
    'storeId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/guest-carts/:cartId', [
  'body' => '{
  "customerId": 0,
  "storeId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'customerId' => 0,
  'storeId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'customerId' => 0,
  'storeId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "customerId": 0,
  "storeId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "customerId": 0,
  "storeId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"customerId\": 0,\n  \"storeId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/guest-carts/:cartId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId"

payload = {
    "customerId": 0,
    "storeId": 0
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId"

payload <- "{\n  \"customerId\": 0,\n  \"storeId\": 0\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"customerId\": 0,\n  \"storeId\": 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/V1/guest-carts/:cartId') do |req|
  req.body = "{\n  \"customerId\": 0,\n  \"storeId\": 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}}/V1/guest-carts/:cartId";

    let payload = json!({
        "customerId": 0,
        "storeId": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/guest-carts/:cartId \
  --header 'content-type: application/json' \
  --data '{
  "customerId": 0,
  "storeId": 0
}'
echo '{
  "customerId": 0,
  "storeId": 0
}' |  \
  http PUT {{baseUrl}}/V1/guest-carts/:cartId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "customerId": 0,\n  "storeId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "customerId": 0,
  "storeId": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId")! 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 guest-carts-{cartId}
{{baseUrl}}/V1/guest-carts/:cartId
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/guest-carts/:cartId")
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/guest-carts/:cartId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/guest-carts/:cartId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/guest-carts/:cartId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/guest-carts/:cartId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/guest-carts/:cartId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/guest-carts/:cartId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/guest-carts/:cartId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/guest-carts/:cartId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/guest-carts/:cartId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/guest-carts/:cartId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts/:cartId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/guest-carts/:cartId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/guest-carts/:cartId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/guest-carts/:cartId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/guest-carts/:cartId
http GET {{baseUrl}}/V1/guest-carts/:cartId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST guest-carts-{cartId}-billing-address (POST)
{{baseUrl}}/V1/guest-carts/:cartId/billing-address
QUERY PARAMS

cartId
BODY json

{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/billing-address");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/guest-carts/:cartId/billing-address" {:content-type :json
                                                                                   :form-params {:address {:city ""
                                                                                                           :company ""
                                                                                                           :country_id ""
                                                                                                           :custom_attributes [{:attribute_code ""
                                                                                                                                :value ""}]
                                                                                                           :customer_address_id 0
                                                                                                           :customer_id 0
                                                                                                           :email ""
                                                                                                           :extension_attributes {:checkout_fields [{}]
                                                                                                                                  :gift_registry_id 0}
                                                                                                           :fax ""
                                                                                                           :firstname ""
                                                                                                           :id 0
                                                                                                           :lastname ""
                                                                                                           :middlename ""
                                                                                                           :postcode ""
                                                                                                           :prefix ""
                                                                                                           :region ""
                                                                                                           :region_code ""
                                                                                                           :region_id 0
                                                                                                           :same_as_billing 0
                                                                                                           :save_in_address_book 0
                                                                                                           :street []
                                                                                                           :suffix ""
                                                                                                           :telephone ""
                                                                                                           :vat_id ""}
                                                                                                 :useForShipping false}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/billing-address"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": 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}}/V1/guest-carts/:cartId/billing-address"),
    Content = new StringContent("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": 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}}/V1/guest-carts/:cartId/billing-address");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/billing-address"

	payload := strings.NewReader("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/guest-carts/:cartId/billing-address HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 708

{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/guest-carts/:cartId/billing-address")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/billing-address"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": 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\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/billing-address")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/guest-carts/:cartId/billing-address")
  .header("content-type", "application/json")
  .body("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}")
  .asString();
const data = JSON.stringify({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  useForShipping: 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}}/V1/guest-carts/:cartId/billing-address');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/billing-address',
  headers: {'content-type': 'application/json'},
  data: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    useForShipping: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/billing-address';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"useForShipping":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}}/V1/guest-carts/:cartId/billing-address',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "useForShipping": 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\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/billing-address")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/billing-address',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  useForShipping: false
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/billing-address',
  headers: {'content-type': 'application/json'},
  body: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    useForShipping: 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}}/V1/guest-carts/:cartId/billing-address');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  useForShipping: 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}}/V1/guest-carts/:cartId/billing-address',
  headers: {'content-type': 'application/json'},
  data: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    useForShipping: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/billing-address';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"useForShipping":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" },
                              @"useForShipping": @NO };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/billing-address"]
                                                       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}}/V1/guest-carts/:cartId/billing-address" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/billing-address",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'useForShipping' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/guest-carts/:cartId/billing-address', [
  'body' => '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/billing-address');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'useForShipping' => null
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'useForShipping' => null
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/billing-address');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/billing-address' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/billing-address' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/guest-carts/:cartId/billing-address", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/billing-address"

payload = {
    "address": {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "extension_attributes": {
            "checkout_fields": [{}],
            "gift_registry_id": 0
        },
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "same_as_billing": 0,
        "save_in_address_book": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
    },
    "useForShipping": False
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/billing-address"

payload <- "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/billing-address")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": 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/V1/guest-carts/:cartId/billing-address') do |req|
  req.body = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/billing-address";

    let payload = json!({
        "address": json!({
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": json!({
                "checkout_fields": (json!({})),
                "gift_registry_id": 0
            }),
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": (),
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        }),
        "useForShipping": false
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/guest-carts/:cartId/billing-address \
  --header 'content-type: application/json' \
  --data '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}'
echo '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}' |  \
  http POST {{baseUrl}}/V1/guest-carts/:cartId/billing-address \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "address": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "useForShipping": false\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/billing-address
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "address": [
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": [
      "checkout_fields": [[]],
      "gift_registry_id": 0
    ],
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  ],
  "useForShipping": false
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/billing-address")! 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 guest-carts-{cartId}-billing-address
{{baseUrl}}/V1/guest-carts/:cartId/billing-address
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/billing-address");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/guest-carts/:cartId/billing-address")
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/billing-address"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/guest-carts/:cartId/billing-address"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/guest-carts/:cartId/billing-address");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/billing-address"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/guest-carts/:cartId/billing-address HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/guest-carts/:cartId/billing-address")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/billing-address"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/billing-address")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/guest-carts/:cartId/billing-address")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/guest-carts/:cartId/billing-address');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/billing-address'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/billing-address';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/billing-address',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/billing-address")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/billing-address',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/billing-address'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/guest-carts/:cartId/billing-address');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/billing-address'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/billing-address';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/billing-address"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts/:cartId/billing-address" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/billing-address",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/guest-carts/:cartId/billing-address');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/billing-address');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/billing-address');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/billing-address' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/billing-address' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/guest-carts/:cartId/billing-address")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/billing-address"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/billing-address"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/billing-address")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/guest-carts/:cartId/billing-address') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/billing-address";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/guest-carts/:cartId/billing-address
http GET {{baseUrl}}/V1/guest-carts/:cartId/billing-address
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/billing-address
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/billing-address")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST guest-carts-{cartId}-checkout-fields
{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields
QUERY PARAMS

cartId
BODY json

{
  "serviceSelection": [
    {
      "attribute_code": "",
      "value": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields" {:content-type :json
                                                                                   :form-params {:serviceSelection [{:attribute_code ""
                                                                                                                     :value ""}]}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\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}}/V1/guest-carts/:cartId/checkout-fields"),
    Content = new StringContent("{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\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}}/V1/guest-carts/:cartId/checkout-fields");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields"

	payload := strings.NewReader("{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/guest-carts/:cartId/checkout-fields HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 89

{
  "serviceSelection": [
    {
      "attribute_code": "",
      "value": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\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  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields")
  .header("content-type", "application/json")
  .body("{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  serviceSelection: [
    {
      attribute_code: '',
      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}}/V1/guest-carts/:cartId/checkout-fields');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields',
  headers: {'content-type': 'application/json'},
  data: {serviceSelection: [{attribute_code: '', value: ''}]}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"serviceSelection":[{"attribute_code":"","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}}/V1/guest-carts/:cartId/checkout-fields',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "serviceSelection": [\n    {\n      "attribute_code": "",\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  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/checkout-fields',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({serviceSelection: [{attribute_code: '', value: ''}]}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields',
  headers: {'content-type': 'application/json'},
  body: {serviceSelection: [{attribute_code: '', 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}}/V1/guest-carts/:cartId/checkout-fields');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  serviceSelection: [
    {
      attribute_code: '',
      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}}/V1/guest-carts/:cartId/checkout-fields',
  headers: {'content-type': 'application/json'},
  data: {serviceSelection: [{attribute_code: '', value: ''}]}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"serviceSelection":[{"attribute_code":"","value":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"serviceSelection": @[ @{ @"attribute_code": @"", @"value": @"" } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'serviceSelection' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields', [
  'body' => '{
  "serviceSelection": [
    {
      "attribute_code": "",
      "value": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'serviceSelection' => [
    [
        'attribute_code' => '',
        'value' => ''
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'serviceSelection' => [
    [
        'attribute_code' => '',
        'value' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "serviceSelection": [
    {
      "attribute_code": "",
      "value": ""
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "serviceSelection": [
    {
      "attribute_code": "",
      "value": ""
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/guest-carts/:cartId/checkout-fields", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields"

payload = { "serviceSelection": [
        {
            "attribute_code": "",
            "value": ""
        }
    ] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields"

payload <- "{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\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/V1/guest-carts/:cartId/checkout-fields') do |req|
  req.body = "{\n  \"serviceSelection\": [\n    {\n      \"attribute_code\": \"\",\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}}/V1/guest-carts/:cartId/checkout-fields";

    let payload = json!({"serviceSelection": (
            json!({
                "attribute_code": "",
                "value": ""
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/guest-carts/:cartId/checkout-fields \
  --header 'content-type: application/json' \
  --data '{
  "serviceSelection": [
    {
      "attribute_code": "",
      "value": ""
    }
  ]
}'
echo '{
  "serviceSelection": [
    {
      "attribute_code": "",
      "value": ""
    }
  ]
}' |  \
  http POST {{baseUrl}}/V1/guest-carts/:cartId/checkout-fields \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "serviceSelection": [\n    {\n      "attribute_code": "",\n      "value": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/checkout-fields
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["serviceSelection": [
    [
      "attribute_code": "",
      "value": ""
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/checkout-fields")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT guest-carts-{cartId}-collect-totals
{{baseUrl}}/V1/guest-carts/:cartId/collect-totals
QUERY PARAMS

cartId
BODY json

{
  "additionalData": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "gift_messages": [
        {
          "customer_id": 0,
          "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": false,
            "wrapping_allow_gift_receipt": false,
            "wrapping_id": 0
          },
          "gift_message_id": 0,
          "message": "",
          "recipient": "",
          "sender": ""
        }
      ]
    }
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  },
  "shippingCarrierCode": "",
  "shippingMethodCode": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/collect-totals");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/guest-carts/:cartId/collect-totals" {:content-type :json
                                                                                 :form-params {:additionalData {:custom_attributes [{:attribute_code ""
                                                                                                                                     :value ""}]
                                                                                                                :extension_attributes {:gift_messages [{:customer_id 0
                                                                                                                                                        :extension_attributes {:entity_id ""
                                                                                                                                                                               :entity_type ""
                                                                                                                                                                               :wrapping_add_printed_card false
                                                                                                                                                                               :wrapping_allow_gift_receipt false
                                                                                                                                                                               :wrapping_id 0}
                                                                                                                                                        :gift_message_id 0
                                                                                                                                                        :message ""
                                                                                                                                                        :recipient ""
                                                                                                                                                        :sender ""}]}}
                                                                                               :paymentMethod {:additional_data []
                                                                                                               :extension_attributes {:agreement_ids []}
                                                                                                               :method ""
                                                                                                               :po_number ""}
                                                                                               :shippingCarrierCode ""
                                                                                               :shippingMethodCode ""}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/collect-totals"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\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}}/V1/guest-carts/:cartId/collect-totals"),
    Content = new StringContent("{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\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}}/V1/guest-carts/:cartId/collect-totals");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/collect-totals"

	payload := strings.NewReader("{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/guest-carts/:cartId/collect-totals HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 800

{
  "additionalData": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "gift_messages": [
        {
          "customer_id": 0,
          "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": false,
            "wrapping_allow_gift_receipt": false,
            "wrapping_id": 0
          },
          "gift_message_id": 0,
          "message": "",
          "recipient": "",
          "sender": ""
        }
      ]
    }
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  },
  "shippingCarrierCode": "",
  "shippingMethodCode": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/guest-carts/:cartId/collect-totals")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/collect-totals"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\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  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/collect-totals")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/guest-carts/:cartId/collect-totals")
  .header("content-type", "application/json")
  .body("{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  additionalData: {
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    extension_attributes: {
      gift_messages: [
        {
          customer_id: 0,
          extension_attributes: {
            entity_id: '',
            entity_type: '',
            wrapping_add_printed_card: false,
            wrapping_allow_gift_receipt: false,
            wrapping_id: 0
          },
          gift_message_id: 0,
          message: '',
          recipient: '',
          sender: ''
        }
      ]
    }
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  },
  shippingCarrierCode: '',
  shippingMethodCode: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/guest-carts/:cartId/collect-totals');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/collect-totals',
  headers: {'content-type': 'application/json'},
  data: {
    additionalData: {
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {
        gift_messages: [
          {
            customer_id: 0,
            extension_attributes: {
              entity_id: '',
              entity_type: '',
              wrapping_add_printed_card: false,
              wrapping_allow_gift_receipt: false,
              wrapping_id: 0
            },
            gift_message_id: 0,
            message: '',
            recipient: '',
            sender: ''
          }
        ]
      }
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    },
    shippingCarrierCode: '',
    shippingMethodCode: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/collect-totals';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"additionalData":{"custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{"gift_messages":[{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""}]}},"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""},"shippingCarrierCode":"","shippingMethodCode":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/collect-totals',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "additionalData": {\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "extension_attributes": {\n      "gift_messages": [\n        {\n          "customer_id": 0,\n          "extension_attributes": {\n            "entity_id": "",\n            "entity_type": "",\n            "wrapping_add_printed_card": false,\n            "wrapping_allow_gift_receipt": false,\n            "wrapping_id": 0\n          },\n          "gift_message_id": 0,\n          "message": "",\n          "recipient": "",\n          "sender": ""\n        }\n      ]\n    }\n  },\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\n  },\n  "shippingCarrierCode": "",\n  "shippingMethodCode": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/collect-totals")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/collect-totals',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  additionalData: {
    custom_attributes: [{attribute_code: '', value: ''}],
    extension_attributes: {
      gift_messages: [
        {
          customer_id: 0,
          extension_attributes: {
            entity_id: '',
            entity_type: '',
            wrapping_add_printed_card: false,
            wrapping_allow_gift_receipt: false,
            wrapping_id: 0
          },
          gift_message_id: 0,
          message: '',
          recipient: '',
          sender: ''
        }
      ]
    }
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {agreement_ids: []},
    method: '',
    po_number: ''
  },
  shippingCarrierCode: '',
  shippingMethodCode: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/collect-totals',
  headers: {'content-type': 'application/json'},
  body: {
    additionalData: {
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {
        gift_messages: [
          {
            customer_id: 0,
            extension_attributes: {
              entity_id: '',
              entity_type: '',
              wrapping_add_printed_card: false,
              wrapping_allow_gift_receipt: false,
              wrapping_id: 0
            },
            gift_message_id: 0,
            message: '',
            recipient: '',
            sender: ''
          }
        ]
      }
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    },
    shippingCarrierCode: '',
    shippingMethodCode: ''
  },
  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}}/V1/guest-carts/:cartId/collect-totals');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  additionalData: {
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    extension_attributes: {
      gift_messages: [
        {
          customer_id: 0,
          extension_attributes: {
            entity_id: '',
            entity_type: '',
            wrapping_add_printed_card: false,
            wrapping_allow_gift_receipt: false,
            wrapping_id: 0
          },
          gift_message_id: 0,
          message: '',
          recipient: '',
          sender: ''
        }
      ]
    }
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  },
  shippingCarrierCode: '',
  shippingMethodCode: ''
});

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}}/V1/guest-carts/:cartId/collect-totals',
  headers: {'content-type': 'application/json'},
  data: {
    additionalData: {
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {
        gift_messages: [
          {
            customer_id: 0,
            extension_attributes: {
              entity_id: '',
              entity_type: '',
              wrapping_add_printed_card: false,
              wrapping_allow_gift_receipt: false,
              wrapping_id: 0
            },
            gift_message_id: 0,
            message: '',
            recipient: '',
            sender: ''
          }
        ]
      }
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    },
    shippingCarrierCode: '',
    shippingMethodCode: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/collect-totals';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"additionalData":{"custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{"gift_messages":[{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""}]}},"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""},"shippingCarrierCode":"","shippingMethodCode":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"additionalData": @{ @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"extension_attributes": @{ @"gift_messages": @[ @{ @"customer_id": @0, @"extension_attributes": @{ @"entity_id": @"", @"entity_type": @"", @"wrapping_add_printed_card": @NO, @"wrapping_allow_gift_receipt": @NO, @"wrapping_id": @0 }, @"gift_message_id": @0, @"message": @"", @"recipient": @"", @"sender": @"" } ] } },
                              @"paymentMethod": @{ @"additional_data": @[  ], @"extension_attributes": @{ @"agreement_ids": @[  ] }, @"method": @"", @"po_number": @"" },
                              @"shippingCarrierCode": @"",
                              @"shippingMethodCode": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/collect-totals"]
                                                       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}}/V1/guest-carts/:cartId/collect-totals" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/collect-totals",
  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([
    'additionalData' => [
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'extension_attributes' => [
                'gift_messages' => [
                                [
                                                                'customer_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                'entity_id' => '',
                                                                                                                                'entity_type' => '',
                                                                                                                                'wrapping_add_printed_card' => null,
                                                                                                                                'wrapping_allow_gift_receipt' => null,
                                                                                                                                'wrapping_id' => 0
                                                                ],
                                                                'gift_message_id' => 0,
                                                                'message' => '',
                                                                'recipient' => '',
                                                                'sender' => ''
                                ]
                ]
        ]
    ],
    'paymentMethod' => [
        'additional_data' => [
                
        ],
        'extension_attributes' => [
                'agreement_ids' => [
                                
                ]
        ],
        'method' => '',
        'po_number' => ''
    ],
    'shippingCarrierCode' => '',
    'shippingMethodCode' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/guest-carts/:cartId/collect-totals', [
  'body' => '{
  "additionalData": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "gift_messages": [
        {
          "customer_id": 0,
          "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": false,
            "wrapping_allow_gift_receipt": false,
            "wrapping_id": 0
          },
          "gift_message_id": 0,
          "message": "",
          "recipient": "",
          "sender": ""
        }
      ]
    }
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  },
  "shippingCarrierCode": "",
  "shippingMethodCode": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/collect-totals');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'additionalData' => [
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'extension_attributes' => [
        'gift_messages' => [
                [
                                'customer_id' => 0,
                                'extension_attributes' => [
                                                                'entity_id' => '',
                                                                'entity_type' => '',
                                                                'wrapping_add_printed_card' => null,
                                                                'wrapping_allow_gift_receipt' => null,
                                                                'wrapping_id' => 0
                                ],
                                'gift_message_id' => 0,
                                'message' => '',
                                'recipient' => '',
                                'sender' => ''
                ]
        ]
    ]
  ],
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ],
  'shippingCarrierCode' => '',
  'shippingMethodCode' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'additionalData' => [
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'extension_attributes' => [
        'gift_messages' => [
                [
                                'customer_id' => 0,
                                'extension_attributes' => [
                                                                'entity_id' => '',
                                                                'entity_type' => '',
                                                                'wrapping_add_printed_card' => null,
                                                                'wrapping_allow_gift_receipt' => null,
                                                                'wrapping_id' => 0
                                ],
                                'gift_message_id' => 0,
                                'message' => '',
                                'recipient' => '',
                                'sender' => ''
                ]
        ]
    ]
  ],
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ],
  'shippingCarrierCode' => '',
  'shippingMethodCode' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/collect-totals');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/collect-totals' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "additionalData": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "gift_messages": [
        {
          "customer_id": 0,
          "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": false,
            "wrapping_allow_gift_receipt": false,
            "wrapping_id": 0
          },
          "gift_message_id": 0,
          "message": "",
          "recipient": "",
          "sender": ""
        }
      ]
    }
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  },
  "shippingCarrierCode": "",
  "shippingMethodCode": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/collect-totals' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "additionalData": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "gift_messages": [
        {
          "customer_id": 0,
          "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": false,
            "wrapping_allow_gift_receipt": false,
            "wrapping_id": 0
          },
          "gift_message_id": 0,
          "message": "",
          "recipient": "",
          "sender": ""
        }
      ]
    }
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  },
  "shippingCarrierCode": "",
  "shippingMethodCode": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/guest-carts/:cartId/collect-totals", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/collect-totals"

payload = {
    "additionalData": {
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "extension_attributes": { "gift_messages": [
                {
                    "customer_id": 0,
                    "extension_attributes": {
                        "entity_id": "",
                        "entity_type": "",
                        "wrapping_add_printed_card": False,
                        "wrapping_allow_gift_receipt": False,
                        "wrapping_id": 0
                    },
                    "gift_message_id": 0,
                    "message": "",
                    "recipient": "",
                    "sender": ""
                }
            ] }
    },
    "paymentMethod": {
        "additional_data": [],
        "extension_attributes": { "agreement_ids": [] },
        "method": "",
        "po_number": ""
    },
    "shippingCarrierCode": "",
    "shippingMethodCode": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/collect-totals"

payload <- "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/collect-totals")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\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/V1/guest-carts/:cartId/collect-totals') do |req|
  req.body = "{\n  \"additionalData\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"gift_messages\": [\n        {\n          \"customer_id\": 0,\n          \"extension_attributes\": {\n            \"entity_id\": \"\",\n            \"entity_type\": \"\",\n            \"wrapping_add_printed_card\": false,\n            \"wrapping_allow_gift_receipt\": false,\n            \"wrapping_id\": 0\n          },\n          \"gift_message_id\": 0,\n          \"message\": \"\",\n          \"recipient\": \"\",\n          \"sender\": \"\"\n        }\n      ]\n    }\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  },\n  \"shippingCarrierCode\": \"\",\n  \"shippingMethodCode\": \"\"\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}}/V1/guest-carts/:cartId/collect-totals";

    let payload = json!({
        "additionalData": json!({
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "extension_attributes": json!({"gift_messages": (
                    json!({
                        "customer_id": 0,
                        "extension_attributes": json!({
                            "entity_id": "",
                            "entity_type": "",
                            "wrapping_add_printed_card": false,
                            "wrapping_allow_gift_receipt": false,
                            "wrapping_id": 0
                        }),
                        "gift_message_id": 0,
                        "message": "",
                        "recipient": "",
                        "sender": ""
                    })
                )})
        }),
        "paymentMethod": json!({
            "additional_data": (),
            "extension_attributes": json!({"agreement_ids": ()}),
            "method": "",
            "po_number": ""
        }),
        "shippingCarrierCode": "",
        "shippingMethodCode": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/guest-carts/:cartId/collect-totals \
  --header 'content-type: application/json' \
  --data '{
  "additionalData": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "gift_messages": [
        {
          "customer_id": 0,
          "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": false,
            "wrapping_allow_gift_receipt": false,
            "wrapping_id": 0
          },
          "gift_message_id": 0,
          "message": "",
          "recipient": "",
          "sender": ""
        }
      ]
    }
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  },
  "shippingCarrierCode": "",
  "shippingMethodCode": ""
}'
echo '{
  "additionalData": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "gift_messages": [
        {
          "customer_id": 0,
          "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": false,
            "wrapping_allow_gift_receipt": false,
            "wrapping_id": 0
          },
          "gift_message_id": 0,
          "message": "",
          "recipient": "",
          "sender": ""
        }
      ]
    }
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  },
  "shippingCarrierCode": "",
  "shippingMethodCode": ""
}' |  \
  http PUT {{baseUrl}}/V1/guest-carts/:cartId/collect-totals \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "additionalData": {\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "extension_attributes": {\n      "gift_messages": [\n        {\n          "customer_id": 0,\n          "extension_attributes": {\n            "entity_id": "",\n            "entity_type": "",\n            "wrapping_add_printed_card": false,\n            "wrapping_allow_gift_receipt": false,\n            "wrapping_id": 0\n          },\n          "gift_message_id": 0,\n          "message": "",\n          "recipient": "",\n          "sender": ""\n        }\n      ]\n    }\n  },\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\n  },\n  "shippingCarrierCode": "",\n  "shippingMethodCode": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/collect-totals
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "additionalData": [
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "extension_attributes": ["gift_messages": [
        [
          "customer_id": 0,
          "extension_attributes": [
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": false,
            "wrapping_allow_gift_receipt": false,
            "wrapping_id": 0
          ],
          "gift_message_id": 0,
          "message": "",
          "recipient": "",
          "sender": ""
        ]
      ]]
  ],
  "paymentMethod": [
    "additional_data": [],
    "extension_attributes": ["agreement_ids": []],
    "method": "",
    "po_number": ""
  ],
  "shippingCarrierCode": "",
  "shippingMethodCode": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/collect-totals")! 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 guest-carts-{cartId}-collection-point-search-request (PUT)
{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request
QUERY PARAMS

cartId
BODY json

{
  "countryId": "",
  "postcode": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request" {:content-type :json
                                                                                                  :form-params {:countryId ""
                                                                                                                :postcode ""}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\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}}/V1/guest-carts/:cartId/collection-point/search-request"),
    Content = new StringContent("{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\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}}/V1/guest-carts/:cartId/collection-point/search-request");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request"

	payload := strings.NewReader("{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/guest-carts/:cartId/collection-point/search-request HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 39

{
  "countryId": "",
  "postcode": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\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  \"countryId\": \"\",\n  \"postcode\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request")
  .header("content-type", "application/json")
  .body("{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  countryId: '',
  postcode: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request',
  headers: {'content-type': 'application/json'},
  data: {countryId: '', postcode: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"countryId":"","postcode":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "countryId": "",\n  "postcode": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/collection-point/search-request',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({countryId: '', postcode: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request',
  headers: {'content-type': 'application/json'},
  body: {countryId: '', postcode: ''},
  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}}/V1/guest-carts/:cartId/collection-point/search-request');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  countryId: '',
  postcode: ''
});

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}}/V1/guest-carts/:cartId/collection-point/search-request',
  headers: {'content-type': 'application/json'},
  data: {countryId: '', postcode: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"countryId":"","postcode":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"countryId": @"",
                              @"postcode": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request"]
                                                       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}}/V1/guest-carts/:cartId/collection-point/search-request" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request",
  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([
    'countryId' => '',
    'postcode' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request', [
  'body' => '{
  "countryId": "",
  "postcode": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'countryId' => '',
  'postcode' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'countryId' => '',
  'postcode' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "countryId": "",
  "postcode": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "countryId": "",
  "postcode": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/guest-carts/:cartId/collection-point/search-request", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request"

payload = {
    "countryId": "",
    "postcode": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request"

payload <- "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\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/V1/guest-carts/:cartId/collection-point/search-request') do |req|
  req.body = "{\n  \"countryId\": \"\",\n  \"postcode\": \"\"\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}}/V1/guest-carts/:cartId/collection-point/search-request";

    let payload = json!({
        "countryId": "",
        "postcode": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request \
  --header 'content-type: application/json' \
  --data '{
  "countryId": "",
  "postcode": ""
}'
echo '{
  "countryId": "",
  "postcode": ""
}' |  \
  http PUT {{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "countryId": "",\n  "postcode": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "countryId": "",
  "postcode": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request")! 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()
DELETE guest-carts-{cartId}-collection-point-search-request
{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request")
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/guest-carts/:cartId/collection-point/search-request HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request"))
    .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}}/V1/guest-carts/:cartId/collection-point/search-request")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request")
  .asString();
const 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}}/V1/guest-carts/:cartId/collection-point/search-request');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/collection-point/search-request',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request');

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}}/V1/guest-carts/:cartId/collection-point/search-request'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/guest-carts/:cartId/collection-point/search-request")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/guest-carts/:cartId/collection-point/search-request') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request
http DELETE {{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-request")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET guest-carts-{cartId}-collection-point-search-result
{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result")
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/guest-carts/:cartId/collection-point/search-result HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/collection-point/search-result',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/guest-carts/:cartId/collection-point/search-result")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/guest-carts/:cartId/collection-point/search-result') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result
http GET {{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/search-result")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST guest-carts-{cartId}-collection-point-select
{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select
QUERY PARAMS

cartId
BODY json

{
  "entityId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"entityId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select" {:content-type :json
                                                                                           :form-params {:entityId 0}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"entityId\": 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}}/V1/guest-carts/:cartId/collection-point/select"),
    Content = new StringContent("{\n  \"entityId\": 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}}/V1/guest-carts/:cartId/collection-point/select");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"entityId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select"

	payload := strings.NewReader("{\n  \"entityId\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/guest-carts/:cartId/collection-point/select HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "entityId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"entityId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"entityId\": 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  \"entityId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select")
  .header("content-type", "application/json")
  .body("{\n  \"entityId\": 0\n}")
  .asString();
const data = JSON.stringify({
  entityId: 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}}/V1/guest-carts/:cartId/collection-point/select');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select',
  headers: {'content-type': 'application/json'},
  data: {entityId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entityId":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}}/V1/guest-carts/:cartId/collection-point/select',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "entityId": 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  \"entityId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/collection-point/select',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({entityId: 0}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select',
  headers: {'content-type': 'application/json'},
  body: {entityId: 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}}/V1/guest-carts/:cartId/collection-point/select');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  entityId: 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}}/V1/guest-carts/:cartId/collection-point/select',
  headers: {'content-type': 'application/json'},
  data: {entityId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entityId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"entityId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select"]
                                                       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}}/V1/guest-carts/:cartId/collection-point/select" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"entityId\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select",
  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([
    'entityId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select', [
  'body' => '{
  "entityId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'entityId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'entityId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entityId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entityId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"entityId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/guest-carts/:cartId/collection-point/select", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select"

payload = { "entityId": 0 }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select"

payload <- "{\n  \"entityId\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"entityId\": 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/V1/guest-carts/:cartId/collection-point/select') do |req|
  req.body = "{\n  \"entityId\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select";

    let payload = json!({"entityId": 0});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/guest-carts/:cartId/collection-point/select \
  --header 'content-type: application/json' \
  --data '{
  "entityId": 0
}'
echo '{
  "entityId": 0
}' |  \
  http POST {{baseUrl}}/V1/guest-carts/:cartId/collection-point/select \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "entityId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/collection-point/select
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["entityId": 0] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/collection-point/select")! 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 guest-carts-{cartId}-coupons (GET)
{{baseUrl}}/V1/guest-carts/:cartId/coupons
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/coupons");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/guest-carts/:cartId/coupons")
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/coupons"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/guest-carts/:cartId/coupons"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/guest-carts/:cartId/coupons");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/coupons"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/guest-carts/:cartId/coupons HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/guest-carts/:cartId/coupons")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/coupons"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/coupons")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/guest-carts/:cartId/coupons")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/guest-carts/:cartId/coupons');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/coupons'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/coupons';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/coupons',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/coupons")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/coupons',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/coupons'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/guest-carts/:cartId/coupons');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/coupons'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/coupons';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/coupons"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts/:cartId/coupons" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/coupons",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/guest-carts/:cartId/coupons');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/coupons');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/coupons');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/coupons' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/coupons' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/guest-carts/:cartId/coupons")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/coupons"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/coupons"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/coupons")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/guest-carts/:cartId/coupons') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/coupons";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/guest-carts/:cartId/coupons
http GET {{baseUrl}}/V1/guest-carts/:cartId/coupons
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/coupons
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/coupons")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE guest-carts-{cartId}-coupons
{{baseUrl}}/V1/guest-carts/:cartId/coupons
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/coupons");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/guest-carts/:cartId/coupons")
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/coupons"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/guest-carts/:cartId/coupons"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/guest-carts/:cartId/coupons");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/coupons"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/guest-carts/:cartId/coupons HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/guest-carts/:cartId/coupons")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/coupons"))
    .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}}/V1/guest-carts/:cartId/coupons")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/guest-carts/:cartId/coupons")
  .asString();
const 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}}/V1/guest-carts/:cartId/coupons');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/coupons'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/coupons';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/coupons',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/coupons")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/coupons',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/coupons'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/guest-carts/:cartId/coupons');

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}}/V1/guest-carts/:cartId/coupons'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/coupons';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/coupons"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts/:cartId/coupons" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/coupons",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/guest-carts/:cartId/coupons');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/coupons');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/coupons');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/coupons' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/coupons' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/guest-carts/:cartId/coupons")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/coupons"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/coupons"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/coupons")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/guest-carts/:cartId/coupons') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/coupons";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/guest-carts/:cartId/coupons
http DELETE {{baseUrl}}/V1/guest-carts/:cartId/coupons
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/coupons
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/coupons")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT guest-carts-{cartId}-coupons-{couponCode}
{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode
QUERY PARAMS

cartId
couponCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode")
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode"

response = HTTP::Client.put url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode");
var request = new RestRequest("", Method.Put);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode"

	req, _ := http.NewRequest("PUT", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/guest-carts/:cartId/coupons/:couponCode HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode"))
    .method("PUT", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode")
  .put(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode';
const options = {method: 'PUT'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode',
  method: 'PUT',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode")
  .put(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/coupons/:couponCode',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode');

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}}/V1/guest-carts/:cartId/coupons/:couponCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode';
const options = {method: 'PUT'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode" in

Client.call `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode');
$request->setMethod(HTTP_METH_PUT);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode');
$request->setRequestMethod('PUT');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode' -Method PUT 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode' -Method PUT 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("PUT", "/baseUrl/V1/guest-carts/:cartId/coupons/:couponCode")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode"

response = requests.put(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode"

response <- VERB("PUT", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/V1/guest-carts/:cartId/coupons/:couponCode') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode
http PUT {{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode
wget --quiet \
  --method PUT \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/coupons/:couponCode")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST guest-carts-{cartId}-delivery-option
{{baseUrl}}/V1/guest-carts/:cartId/delivery-option
QUERY PARAMS

cartId
BODY json

{
  "selectedOption": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/delivery-option");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"selectedOption\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/guest-carts/:cartId/delivery-option" {:content-type :json
                                                                                   :form-params {:selectedOption ""}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/delivery-option"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"selectedOption\": \"\"\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}}/V1/guest-carts/:cartId/delivery-option"),
    Content = new StringContent("{\n  \"selectedOption\": \"\"\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}}/V1/guest-carts/:cartId/delivery-option");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"selectedOption\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/delivery-option"

	payload := strings.NewReader("{\n  \"selectedOption\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/guest-carts/:cartId/delivery-option HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 26

{
  "selectedOption": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/guest-carts/:cartId/delivery-option")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"selectedOption\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/delivery-option"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"selectedOption\": \"\"\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  \"selectedOption\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/delivery-option")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/guest-carts/:cartId/delivery-option")
  .header("content-type", "application/json")
  .body("{\n  \"selectedOption\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  selectedOption: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/guest-carts/:cartId/delivery-option');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/delivery-option',
  headers: {'content-type': 'application/json'},
  data: {selectedOption: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/delivery-option';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"selectedOption":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/delivery-option',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "selectedOption": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"selectedOption\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/delivery-option")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/delivery-option',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({selectedOption: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/delivery-option',
  headers: {'content-type': 'application/json'},
  body: {selectedOption: ''},
  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}}/V1/guest-carts/:cartId/delivery-option');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  selectedOption: ''
});

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}}/V1/guest-carts/:cartId/delivery-option',
  headers: {'content-type': 'application/json'},
  data: {selectedOption: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/delivery-option';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"selectedOption":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"selectedOption": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/delivery-option"]
                                                       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}}/V1/guest-carts/:cartId/delivery-option" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"selectedOption\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/delivery-option",
  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([
    'selectedOption' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/guest-carts/:cartId/delivery-option', [
  'body' => '{
  "selectedOption": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/delivery-option');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'selectedOption' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'selectedOption' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/delivery-option');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/delivery-option' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "selectedOption": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/delivery-option' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "selectedOption": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"selectedOption\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/guest-carts/:cartId/delivery-option", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/delivery-option"

payload = { "selectedOption": "" }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/delivery-option"

payload <- "{\n  \"selectedOption\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/delivery-option")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"selectedOption\": \"\"\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/V1/guest-carts/:cartId/delivery-option') do |req|
  req.body = "{\n  \"selectedOption\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/delivery-option";

    let payload = json!({"selectedOption": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/guest-carts/:cartId/delivery-option \
  --header 'content-type: application/json' \
  --data '{
  "selectedOption": ""
}'
echo '{
  "selectedOption": ""
}' |  \
  http POST {{baseUrl}}/V1/guest-carts/:cartId/delivery-option \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "selectedOption": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/delivery-option
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["selectedOption": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/delivery-option")! 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 guest-carts-{cartId}-estimate-shipping-methods
{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods
QUERY PARAMS

cartId
BODY json

{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods" {:content-type :json
                                                                                             :form-params {:address {:city ""
                                                                                                                     :company ""
                                                                                                                     :country_id ""
                                                                                                                     :custom_attributes [{:attribute_code ""
                                                                                                                                          :value ""}]
                                                                                                                     :customer_address_id 0
                                                                                                                     :customer_id 0
                                                                                                                     :email ""
                                                                                                                     :extension_attributes {:checkout_fields [{}]
                                                                                                                                            :gift_registry_id 0}
                                                                                                                     :fax ""
                                                                                                                     :firstname ""
                                                                                                                     :id 0
                                                                                                                     :lastname ""
                                                                                                                     :middlename ""
                                                                                                                     :postcode ""
                                                                                                                     :prefix ""
                                                                                                                     :region ""
                                                                                                                     :region_code ""
                                                                                                                     :region_id 0
                                                                                                                     :same_as_billing 0
                                                                                                                     :save_in_address_book 0
                                                                                                                     :street []
                                                                                                                     :suffix ""
                                                                                                                     :telephone ""
                                                                                                                     :vat_id ""}}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\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}}/V1/guest-carts/:cartId/estimate-shipping-methods"),
    Content = new StringContent("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\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}}/V1/guest-carts/:cartId/estimate-shipping-methods");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods"

	payload := strings.NewReader("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/guest-carts/:cartId/estimate-shipping-methods HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 681

{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\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\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods")
  .header("content-type", "application/json")
  .body("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_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}}/V1/guest-carts/:cartId/estimate-shipping-methods');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  data: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_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}}/V1/guest-carts/:cartId/estimate-shipping-methods',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\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\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/estimate-shipping-methods',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  body: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_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}}/V1/guest-carts/:cartId/estimate-shipping-methods');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_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}}/V1/guest-carts/:cartId/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  data: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods"]
                                                       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}}/V1/guest-carts/:cartId/estimate-shipping-methods" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods', [
  'body' => '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/guest-carts/:cartId/estimate-shipping-methods", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods"

payload = { "address": {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "extension_attributes": {
            "checkout_fields": [{}],
            "gift_registry_id": 0
        },
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "same_as_billing": 0,
        "save_in_address_book": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods"

payload <- "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\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/V1/guest-carts/:cartId/estimate-shipping-methods') do |req|
  req.body = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods";

    let payload = json!({"address": json!({
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": json!({
                "checkout_fields": (json!({})),
                "gift_registry_id": 0
            }),
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": (),
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods \
  --header 'content-type: application/json' \
  --data '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}'
echo '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "address": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["address": [
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": [
      "checkout_fields": [[]],
      "gift_registry_id": 0
    ],
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/estimate-shipping-methods")! 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 guest-carts-{cartId}-gift-message (POST)
{{baseUrl}}/V1/guest-carts/:cartId/gift-message
QUERY PARAMS

cartId
BODY json

{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/gift-message");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/guest-carts/:cartId/gift-message" {:content-type :json
                                                                                :form-params {:giftMessage {:customer_id 0
                                                                                                            :extension_attributes {:entity_id ""
                                                                                                                                   :entity_type ""
                                                                                                                                   :wrapping_add_printed_card false
                                                                                                                                   :wrapping_allow_gift_receipt false
                                                                                                                                   :wrapping_id 0}
                                                                                                            :gift_message_id 0
                                                                                                            :message ""
                                                                                                            :recipient ""
                                                                                                            :sender ""}}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/gift-message"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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}}/V1/guest-carts/:cartId/gift-message"),
    Content = new StringContent("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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}}/V1/guest-carts/:cartId/gift-message");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/gift-message"

	payload := strings.NewReader("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/guest-carts/:cartId/gift-message HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 325

{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/guest-carts/:cartId/gift-message")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/gift-message"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/gift-message")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/guest-carts/:cartId/gift-message")
  .header("content-type", "application/json")
  .body("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/guest-carts/:cartId/gift-message');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/gift-message',
  headers: {'content-type': 'application/json'},
  data: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/gift-message';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftMessage":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/gift-message',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "giftMessage": {\n    "customer_id": 0,\n    "extension_attributes": {\n      "entity_id": "",\n      "entity_type": "",\n      "wrapping_add_printed_card": false,\n      "wrapping_allow_gift_receipt": false,\n      "wrapping_id": 0\n    },\n    "gift_message_id": 0,\n    "message": "",\n    "recipient": "",\n    "sender": ""\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  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/gift-message")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/gift-message',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/gift-message',
  headers: {'content-type': 'application/json'},
  body: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  },
  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}}/V1/guest-carts/:cartId/gift-message');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
});

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}}/V1/guest-carts/:cartId/gift-message',
  headers: {'content-type': 'application/json'},
  data: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/gift-message';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftMessage":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"giftMessage": @{ @"customer_id": @0, @"extension_attributes": @{ @"entity_id": @"", @"entity_type": @"", @"wrapping_add_printed_card": @NO, @"wrapping_allow_gift_receipt": @NO, @"wrapping_id": @0 }, @"gift_message_id": @0, @"message": @"", @"recipient": @"", @"sender": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/gift-message"]
                                                       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}}/V1/guest-carts/:cartId/gift-message" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/gift-message",
  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([
    'giftMessage' => [
        'customer_id' => 0,
        'extension_attributes' => [
                'entity_id' => '',
                'entity_type' => '',
                'wrapping_add_printed_card' => null,
                'wrapping_allow_gift_receipt' => null,
                'wrapping_id' => 0
        ],
        'gift_message_id' => 0,
        'message' => '',
        'recipient' => '',
        'sender' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/guest-carts/:cartId/gift-message', [
  'body' => '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/gift-message');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'giftMessage' => [
    'customer_id' => 0,
    'extension_attributes' => [
        'entity_id' => '',
        'entity_type' => '',
        'wrapping_add_printed_card' => null,
        'wrapping_allow_gift_receipt' => null,
        'wrapping_id' => 0
    ],
    'gift_message_id' => 0,
    'message' => '',
    'recipient' => '',
    'sender' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'giftMessage' => [
    'customer_id' => 0,
    'extension_attributes' => [
        'entity_id' => '',
        'entity_type' => '',
        'wrapping_add_printed_card' => null,
        'wrapping_allow_gift_receipt' => null,
        'wrapping_id' => 0
    ],
    'gift_message_id' => 0,
    'message' => '',
    'recipient' => '',
    'sender' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/gift-message');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/gift-message' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/gift-message' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/guest-carts/:cartId/gift-message", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/gift-message"

payload = { "giftMessage": {
        "customer_id": 0,
        "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": False,
            "wrapping_allow_gift_receipt": False,
            "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/gift-message"

payload <- "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/gift-message")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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/V1/guest-carts/:cartId/gift-message') do |req|
  req.body = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/gift-message";

    let payload = json!({"giftMessage": json!({
            "customer_id": 0,
            "extension_attributes": json!({
                "entity_id": "",
                "entity_type": "",
                "wrapping_add_printed_card": false,
                "wrapping_allow_gift_receipt": false,
                "wrapping_id": 0
            }),
            "gift_message_id": 0,
            "message": "",
            "recipient": "",
            "sender": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/guest-carts/:cartId/gift-message \
  --header 'content-type: application/json' \
  --data '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
echo '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/guest-carts/:cartId/gift-message \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "giftMessage": {\n    "customer_id": 0,\n    "extension_attributes": {\n      "entity_id": "",\n      "entity_type": "",\n      "wrapping_add_printed_card": false,\n      "wrapping_allow_gift_receipt": false,\n      "wrapping_id": 0\n    },\n    "gift_message_id": 0,\n    "message": "",\n    "recipient": "",\n    "sender": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/gift-message
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["giftMessage": [
    "customer_id": 0,
    "extension_attributes": [
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    ],
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/gift-message")! 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 guest-carts-{cartId}-gift-message
{{baseUrl}}/V1/guest-carts/:cartId/gift-message
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/gift-message");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/guest-carts/:cartId/gift-message")
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/gift-message"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/guest-carts/:cartId/gift-message"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/guest-carts/:cartId/gift-message");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/gift-message"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/guest-carts/:cartId/gift-message HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/guest-carts/:cartId/gift-message")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/gift-message"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/gift-message")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/guest-carts/:cartId/gift-message")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/guest-carts/:cartId/gift-message');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/gift-message'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/gift-message';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/gift-message',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/gift-message")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/gift-message',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/gift-message'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/guest-carts/:cartId/gift-message');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/gift-message'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/gift-message';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/gift-message"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts/:cartId/gift-message" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/gift-message",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/guest-carts/:cartId/gift-message');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/gift-message');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/gift-message');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/gift-message' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/gift-message' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/guest-carts/:cartId/gift-message")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/gift-message"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/gift-message"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/gift-message")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/guest-carts/:cartId/gift-message') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/gift-message";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/guest-carts/:cartId/gift-message
http GET {{baseUrl}}/V1/guest-carts/:cartId/gift-message
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/gift-message
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/gift-message")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST guest-carts-{cartId}-gift-message-{itemId} (POST)
{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId
QUERY PARAMS

cartId
itemId
BODY json

{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId" {:content-type :json
                                                                                        :form-params {:giftMessage {:customer_id 0
                                                                                                                    :extension_attributes {:entity_id ""
                                                                                                                                           :entity_type ""
                                                                                                                                           :wrapping_add_printed_card false
                                                                                                                                           :wrapping_allow_gift_receipt false
                                                                                                                                           :wrapping_id 0}
                                                                                                                    :gift_message_id 0
                                                                                                                    :message ""
                                                                                                                    :recipient ""
                                                                                                                    :sender ""}}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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}}/V1/guest-carts/:cartId/gift-message/:itemId"),
    Content = new StringContent("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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}}/V1/guest-carts/:cartId/gift-message/:itemId");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId"

	payload := strings.NewReader("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/guest-carts/:cartId/gift-message/:itemId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 325

{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId")
  .header("content-type", "application/json")
  .body("{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId',
  headers: {'content-type': 'application/json'},
  data: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftMessage":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "giftMessage": {\n    "customer_id": 0,\n    "extension_attributes": {\n      "entity_id": "",\n      "entity_type": "",\n      "wrapping_add_printed_card": false,\n      "wrapping_allow_gift_receipt": false,\n      "wrapping_id": 0\n    },\n    "gift_message_id": 0,\n    "message": "",\n    "recipient": "",\n    "sender": ""\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  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/gift-message/:itemId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId',
  headers: {'content-type': 'application/json'},
  body: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  },
  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}}/V1/guest-carts/:cartId/gift-message/:itemId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  giftMessage: {
    customer_id: 0,
    extension_attributes: {
      entity_id: '',
      entity_type: '',
      wrapping_add_printed_card: false,
      wrapping_allow_gift_receipt: false,
      wrapping_id: 0
    },
    gift_message_id: 0,
    message: '',
    recipient: '',
    sender: ''
  }
});

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}}/V1/guest-carts/:cartId/gift-message/:itemId',
  headers: {'content-type': 'application/json'},
  data: {
    giftMessage: {
      customer_id: 0,
      extension_attributes: {
        entity_id: '',
        entity_type: '',
        wrapping_add_printed_card: false,
        wrapping_allow_gift_receipt: false,
        wrapping_id: 0
      },
      gift_message_id: 0,
      message: '',
      recipient: '',
      sender: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftMessage":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"giftMessage": @{ @"customer_id": @0, @"extension_attributes": @{ @"entity_id": @"", @"entity_type": @"", @"wrapping_add_printed_card": @NO, @"wrapping_allow_gift_receipt": @NO, @"wrapping_id": @0 }, @"gift_message_id": @0, @"message": @"", @"recipient": @"", @"sender": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId"]
                                                       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}}/V1/guest-carts/:cartId/gift-message/:itemId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId",
  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([
    'giftMessage' => [
        'customer_id' => 0,
        'extension_attributes' => [
                'entity_id' => '',
                'entity_type' => '',
                'wrapping_add_printed_card' => null,
                'wrapping_allow_gift_receipt' => null,
                'wrapping_id' => 0
        ],
        'gift_message_id' => 0,
        'message' => '',
        'recipient' => '',
        'sender' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId', [
  'body' => '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'giftMessage' => [
    'customer_id' => 0,
    'extension_attributes' => [
        'entity_id' => '',
        'entity_type' => '',
        'wrapping_add_printed_card' => null,
        'wrapping_allow_gift_receipt' => null,
        'wrapping_id' => 0
    ],
    'gift_message_id' => 0,
    'message' => '',
    'recipient' => '',
    'sender' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'giftMessage' => [
    'customer_id' => 0,
    'extension_attributes' => [
        'entity_id' => '',
        'entity_type' => '',
        'wrapping_add_printed_card' => null,
        'wrapping_allow_gift_receipt' => null,
        'wrapping_id' => 0
    ],
    'gift_message_id' => 0,
    'message' => '',
    'recipient' => '',
    'sender' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/guest-carts/:cartId/gift-message/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId"

payload = { "giftMessage": {
        "customer_id": 0,
        "extension_attributes": {
            "entity_id": "",
            "entity_type": "",
            "wrapping_add_printed_card": False,
            "wrapping_allow_gift_receipt": False,
            "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId"

payload <- "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\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/V1/guest-carts/:cartId/gift-message/:itemId') do |req|
  req.body = "{\n  \"giftMessage\": {\n    \"customer_id\": 0,\n    \"extension_attributes\": {\n      \"entity_id\": \"\",\n      \"entity_type\": \"\",\n      \"wrapping_add_printed_card\": false,\n      \"wrapping_allow_gift_receipt\": false,\n      \"wrapping_id\": 0\n    },\n    \"gift_message_id\": 0,\n    \"message\": \"\",\n    \"recipient\": \"\",\n    \"sender\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId";

    let payload = json!({"giftMessage": json!({
            "customer_id": 0,
            "extension_attributes": json!({
                "entity_id": "",
                "entity_type": "",
                "wrapping_add_printed_card": false,
                "wrapping_allow_gift_receipt": false,
                "wrapping_id": 0
            }),
            "gift_message_id": 0,
            "message": "",
            "recipient": "",
            "sender": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId \
  --header 'content-type: application/json' \
  --data '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}'
echo '{
  "giftMessage": {
    "customer_id": 0,
    "extension_attributes": {
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    },
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "giftMessage": {\n    "customer_id": 0,\n    "extension_attributes": {\n      "entity_id": "",\n      "entity_type": "",\n      "wrapping_add_printed_card": false,\n      "wrapping_allow_gift_receipt": false,\n      "wrapping_id": 0\n    },\n    "gift_message_id": 0,\n    "message": "",\n    "recipient": "",\n    "sender": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["giftMessage": [
    "customer_id": 0,
    "extension_attributes": [
      "entity_id": "",
      "entity_type": "",
      "wrapping_add_printed_card": false,
      "wrapping_allow_gift_receipt": false,
      "wrapping_id": 0
    ],
    "gift_message_id": 0,
    "message": "",
    "recipient": "",
    "sender": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId")! 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 guest-carts-{cartId}-gift-message-{itemId}
{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId
QUERY PARAMS

cartId
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId")
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/guest-carts/:cartId/gift-message/:itemId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/gift-message/:itemId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/guest-carts/:cartId/gift-message/:itemId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/guest-carts/:cartId/gift-message/:itemId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId
http GET {{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/gift-message/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST guest-carts-{cartId}-items (POST)
{{baseUrl}}/V1/guest-carts/:cartId/items
QUERY PARAMS

cartId
BODY json

{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/items");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/guest-carts/:cartId/items" {:content-type :json
                                                                         :form-params {:cartItem {:extension_attributes {:negotiable_quote_item {:extension_attributes {}
                                                                                                                                                 :item_id 0
                                                                                                                                                 :original_discount_amount ""
                                                                                                                                                 :original_price ""
                                                                                                                                                 :original_tax_amount ""}}
                                                                                                  :item_id 0
                                                                                                  :name ""
                                                                                                  :price ""
                                                                                                  :product_option {:extension_attributes {:bundle_options [{:extension_attributes {}
                                                                                                                                                            :option_id 0
                                                                                                                                                            :option_qty 0
                                                                                                                                                            :option_selections []}]
                                                                                                                                          :configurable_item_options [{:extension_attributes {}
                                                                                                                                                                       :option_id ""
                                                                                                                                                                       :option_value 0}]
                                                                                                                                          :custom_options [{:extension_attributes {:file_info {:base64_encoded_data ""
                                                                                                                                                                                               :name ""
                                                                                                                                                                                               :type ""}}
                                                                                                                                                            :option_id ""
                                                                                                                                                            :option_value ""}]
                                                                                                                                          :downloadable_option {:downloadable_links []}
                                                                                                                                          :giftcard_item_option {:custom_giftcard_amount ""
                                                                                                                                                                 :extension_attributes {}
                                                                                                                                                                 :giftcard_amount ""
                                                                                                                                                                 :giftcard_message ""
                                                                                                                                                                 :giftcard_recipient_email ""
                                                                                                                                                                 :giftcard_recipient_name ""
                                                                                                                                                                 :giftcard_sender_email ""
                                                                                                                                                                 :giftcard_sender_name ""}}}
                                                                                                  :product_type ""
                                                                                                  :qty ""
                                                                                                  :quote_id ""
                                                                                                  :sku ""}}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/items"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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}}/V1/guest-carts/:cartId/items"),
    Content = new StringContent("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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}}/V1/guest-carts/:cartId/items");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/items"

	payload := strings.NewReader("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/guest-carts/:cartId/items HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1573

{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/guest-carts/:cartId/items")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/items"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/items")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/guest-carts/:cartId/items")
  .header("content-type", "application/json")
  .body("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [
          {
            extension_attributes: {},
            option_id: 0,
            option_qty: 0,
            option_selections: []
          }
        ],
        configurable_item_options: [
          {
            extension_attributes: {},
            option_id: '',
            option_value: 0
          }
        ],
        custom_options: [
          {
            extension_attributes: {
              file_info: {
                base64_encoded_data: '',
                name: '',
                type: ''
              }
            },
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {
          downloadable_links: []
        },
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/guest-carts/:cartId/items');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/items',
  headers: {'content-type': 'application/json'},
  data: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/items';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"cartItem":{"extension_attributes":{"negotiable_quote_item":{"extension_attributes":{},"item_id":0,"original_discount_amount":"","original_price":"","original_tax_amount":""}},"item_id":0,"name":"","price":"","product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty":"","quote_id":"","sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/items',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "cartItem": {\n    "extension_attributes": {\n      "negotiable_quote_item": {\n        "extension_attributes": {},\n        "item_id": 0,\n        "original_discount_amount": "",\n        "original_price": "",\n        "original_tax_amount": ""\n      }\n    },\n    "item_id": 0,\n    "name": "",\n    "price": "",\n    "product_option": {\n      "extension_attributes": {\n        "bundle_options": [\n          {\n            "extension_attributes": {},\n            "option_id": 0,\n            "option_qty": 0,\n            "option_selections": []\n          }\n        ],\n        "configurable_item_options": [\n          {\n            "extension_attributes": {},\n            "option_id": "",\n            "option_value": 0\n          }\n        ],\n        "custom_options": [\n          {\n            "extension_attributes": {\n              "file_info": {\n                "base64_encoded_data": "",\n                "name": "",\n                "type": ""\n              }\n            },\n            "option_id": "",\n            "option_value": ""\n          }\n        ],\n        "downloadable_option": {\n          "downloadable_links": []\n        },\n        "giftcard_item_option": {\n          "custom_giftcard_amount": "",\n          "extension_attributes": {},\n          "giftcard_amount": "",\n          "giftcard_message": "",\n          "giftcard_recipient_email": "",\n          "giftcard_recipient_name": "",\n          "giftcard_sender_email": "",\n          "giftcard_sender_name": ""\n        }\n      }\n    },\n    "product_type": "",\n    "qty": "",\n    "quote_id": "",\n    "sku": ""\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  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/items")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/items',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
        configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
        custom_options: [
          {
            extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {downloadable_links: []},
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/items',
  headers: {'content-type': 'application/json'},
  body: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  },
  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}}/V1/guest-carts/:cartId/items');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [
          {
            extension_attributes: {},
            option_id: 0,
            option_qty: 0,
            option_selections: []
          }
        ],
        configurable_item_options: [
          {
            extension_attributes: {},
            option_id: '',
            option_value: 0
          }
        ],
        custom_options: [
          {
            extension_attributes: {
              file_info: {
                base64_encoded_data: '',
                name: '',
                type: ''
              }
            },
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {
          downloadable_links: []
        },
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
});

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}}/V1/guest-carts/:cartId/items',
  headers: {'content-type': 'application/json'},
  data: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/items';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"cartItem":{"extension_attributes":{"negotiable_quote_item":{"extension_attributes":{},"item_id":0,"original_discount_amount":"","original_price":"","original_tax_amount":""}},"item_id":0,"name":"","price":"","product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty":"","quote_id":"","sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"cartItem": @{ @"extension_attributes": @{ @"negotiable_quote_item": @{ @"extension_attributes": @{  }, @"item_id": @0, @"original_discount_amount": @"", @"original_price": @"", @"original_tax_amount": @"" } }, @"item_id": @0, @"name": @"", @"price": @"", @"product_option": @{ @"extension_attributes": @{ @"bundle_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @0, @"option_qty": @0, @"option_selections": @[  ] } ], @"configurable_item_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @"", @"option_value": @0 } ], @"custom_options": @[ @{ @"extension_attributes": @{ @"file_info": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" } }, @"option_id": @"", @"option_value": @"" } ], @"downloadable_option": @{ @"downloadable_links": @[  ] }, @"giftcard_item_option": @{ @"custom_giftcard_amount": @"", @"extension_attributes": @{  }, @"giftcard_amount": @"", @"giftcard_message": @"", @"giftcard_recipient_email": @"", @"giftcard_recipient_name": @"", @"giftcard_sender_email": @"", @"giftcard_sender_name": @"" } } }, @"product_type": @"", @"qty": @"", @"quote_id": @"", @"sku": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/items"]
                                                       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}}/V1/guest-carts/:cartId/items" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/items",
  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([
    'cartItem' => [
        'extension_attributes' => [
                'negotiable_quote_item' => [
                                'extension_attributes' => [
                                                                
                                ],
                                'item_id' => 0,
                                'original_discount_amount' => '',
                                'original_price' => '',
                                'original_tax_amount' => ''
                ]
        ],
        'item_id' => 0,
        'name' => '',
        'price' => '',
        'product_option' => [
                'extension_attributes' => [
                                'bundle_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'option_id' => 0,
                                                                                                                                'option_qty' => 0,
                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'configurable_item_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'option_id' => '',
                                                                                                                                'option_value' => 0
                                                                ]
                                ],
                                'custom_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'option_id' => '',
                                                                                                                                'option_value' => ''
                                                                ]
                                ],
                                'downloadable_option' => [
                                                                'downloadable_links' => [
                                                                                                                                
                                                                ]
                                ],
                                'giftcard_item_option' => [
                                                                'custom_giftcard_amount' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'giftcard_amount' => '',
                                                                'giftcard_message' => '',
                                                                'giftcard_recipient_email' => '',
                                                                'giftcard_recipient_name' => '',
                                                                'giftcard_sender_email' => '',
                                                                'giftcard_sender_name' => ''
                                ]
                ]
        ],
        'product_type' => '',
        'qty' => '',
        'quote_id' => '',
        'sku' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/guest-carts/:cartId/items', [
  'body' => '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/items');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'cartItem' => [
    'extension_attributes' => [
        'negotiable_quote_item' => [
                'extension_attributes' => [
                                
                ],
                'item_id' => 0,
                'original_discount_amount' => '',
                'original_price' => '',
                'original_tax_amount' => ''
        ]
    ],
    'item_id' => 0,
    'name' => '',
    'price' => '',
    'product_option' => [
        'extension_attributes' => [
                'bundle_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'option_qty' => 0,
                                                                'option_selections' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'configurable_item_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => 0
                                ]
                ],
                'custom_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ]
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => ''
                                ]
                ],
                'downloadable_option' => [
                                'downloadable_links' => [
                                                                
                                ]
                ],
                'giftcard_item_option' => [
                                'custom_giftcard_amount' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'giftcard_amount' => '',
                                'giftcard_message' => '',
                                'giftcard_recipient_email' => '',
                                'giftcard_recipient_name' => '',
                                'giftcard_sender_email' => '',
                                'giftcard_sender_name' => ''
                ]
        ]
    ],
    'product_type' => '',
    'qty' => '',
    'quote_id' => '',
    'sku' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'cartItem' => [
    'extension_attributes' => [
        'negotiable_quote_item' => [
                'extension_attributes' => [
                                
                ],
                'item_id' => 0,
                'original_discount_amount' => '',
                'original_price' => '',
                'original_tax_amount' => ''
        ]
    ],
    'item_id' => 0,
    'name' => '',
    'price' => '',
    'product_option' => [
        'extension_attributes' => [
                'bundle_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'option_qty' => 0,
                                                                'option_selections' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'configurable_item_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => 0
                                ]
                ],
                'custom_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ]
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => ''
                                ]
                ],
                'downloadable_option' => [
                                'downloadable_links' => [
                                                                
                                ]
                ],
                'giftcard_item_option' => [
                                'custom_giftcard_amount' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'giftcard_amount' => '',
                                'giftcard_message' => '',
                                'giftcard_recipient_email' => '',
                                'giftcard_recipient_name' => '',
                                'giftcard_sender_email' => '',
                                'giftcard_sender_name' => ''
                ]
        ]
    ],
    'product_type' => '',
    'qty' => '',
    'quote_id' => '',
    'sku' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/items');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/items' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/items' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/guest-carts/:cartId/items", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/items"

payload = { "cartItem": {
        "extension_attributes": { "negotiable_quote_item": {
                "extension_attributes": {},
                "item_id": 0,
                "original_discount_amount": "",
                "original_price": "",
                "original_tax_amount": ""
            } },
        "item_id": 0,
        "name": "",
        "price": "",
        "product_option": { "extension_attributes": {
                "bundle_options": [
                    {
                        "extension_attributes": {},
                        "option_id": 0,
                        "option_qty": 0,
                        "option_selections": []
                    }
                ],
                "configurable_item_options": [
                    {
                        "extension_attributes": {},
                        "option_id": "",
                        "option_value": 0
                    }
                ],
                "custom_options": [
                    {
                        "extension_attributes": { "file_info": {
                                "base64_encoded_data": "",
                                "name": "",
                                "type": ""
                            } },
                        "option_id": "",
                        "option_value": ""
                    }
                ],
                "downloadable_option": { "downloadable_links": [] },
                "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                }
            } },
        "product_type": "",
        "qty": "",
        "quote_id": "",
        "sku": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/items"

payload <- "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/items")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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/V1/guest-carts/:cartId/items') do |req|
  req.body = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/items";

    let payload = json!({"cartItem": json!({
            "extension_attributes": json!({"negotiable_quote_item": json!({
                    "extension_attributes": json!({}),
                    "item_id": 0,
                    "original_discount_amount": "",
                    "original_price": "",
                    "original_tax_amount": ""
                })}),
            "item_id": 0,
            "name": "",
            "price": "",
            "product_option": json!({"extension_attributes": json!({
                    "bundle_options": (
                        json!({
                            "extension_attributes": json!({}),
                            "option_id": 0,
                            "option_qty": 0,
                            "option_selections": ()
                        })
                    ),
                    "configurable_item_options": (
                        json!({
                            "extension_attributes": json!({}),
                            "option_id": "",
                            "option_value": 0
                        })
                    ),
                    "custom_options": (
                        json!({
                            "extension_attributes": json!({"file_info": json!({
                                    "base64_encoded_data": "",
                                    "name": "",
                                    "type": ""
                                })}),
                            "option_id": "",
                            "option_value": ""
                        })
                    ),
                    "downloadable_option": json!({"downloadable_links": ()}),
                    "giftcard_item_option": json!({
                        "custom_giftcard_amount": "",
                        "extension_attributes": json!({}),
                        "giftcard_amount": "",
                        "giftcard_message": "",
                        "giftcard_recipient_email": "",
                        "giftcard_recipient_name": "",
                        "giftcard_sender_email": "",
                        "giftcard_sender_name": ""
                    })
                })}),
            "product_type": "",
            "qty": "",
            "quote_id": "",
            "sku": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/guest-carts/:cartId/items \
  --header 'content-type: application/json' \
  --data '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
echo '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/guest-carts/:cartId/items \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "cartItem": {\n    "extension_attributes": {\n      "negotiable_quote_item": {\n        "extension_attributes": {},\n        "item_id": 0,\n        "original_discount_amount": "",\n        "original_price": "",\n        "original_tax_amount": ""\n      }\n    },\n    "item_id": 0,\n    "name": "",\n    "price": "",\n    "product_option": {\n      "extension_attributes": {\n        "bundle_options": [\n          {\n            "extension_attributes": {},\n            "option_id": 0,\n            "option_qty": 0,\n            "option_selections": []\n          }\n        ],\n        "configurable_item_options": [\n          {\n            "extension_attributes": {},\n            "option_id": "",\n            "option_value": 0\n          }\n        ],\n        "custom_options": [\n          {\n            "extension_attributes": {\n              "file_info": {\n                "base64_encoded_data": "",\n                "name": "",\n                "type": ""\n              }\n            },\n            "option_id": "",\n            "option_value": ""\n          }\n        ],\n        "downloadable_option": {\n          "downloadable_links": []\n        },\n        "giftcard_item_option": {\n          "custom_giftcard_amount": "",\n          "extension_attributes": {},\n          "giftcard_amount": "",\n          "giftcard_message": "",\n          "giftcard_recipient_email": "",\n          "giftcard_recipient_name": "",\n          "giftcard_sender_email": "",\n          "giftcard_sender_name": ""\n        }\n      }\n    },\n    "product_type": "",\n    "qty": "",\n    "quote_id": "",\n    "sku": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/items
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["cartItem": [
    "extension_attributes": ["negotiable_quote_item": [
        "extension_attributes": [],
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      ]],
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": ["extension_attributes": [
        "bundle_options": [
          [
            "extension_attributes": [],
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          ]
        ],
        "configurable_item_options": [
          [
            "extension_attributes": [],
            "option_id": "",
            "option_value": 0
          ]
        ],
        "custom_options": [
          [
            "extension_attributes": ["file_info": [
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              ]],
            "option_id": "",
            "option_value": ""
          ]
        ],
        "downloadable_option": ["downloadable_links": []],
        "giftcard_item_option": [
          "custom_giftcard_amount": "",
          "extension_attributes": [],
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        ]
      ]],
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/items")! 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 guest-carts-{cartId}-items
{{baseUrl}}/V1/guest-carts/:cartId/items
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/items");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/guest-carts/:cartId/items")
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/items"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/guest-carts/:cartId/items"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/guest-carts/:cartId/items");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/items"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/guest-carts/:cartId/items HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/guest-carts/:cartId/items")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/items"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/items")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/guest-carts/:cartId/items")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/guest-carts/:cartId/items');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/guest-carts/:cartId/items'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/items';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/items',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/items")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/items',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/guest-carts/:cartId/items'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/guest-carts/:cartId/items');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/guest-carts/:cartId/items'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/items';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/items"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts/:cartId/items" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/items",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/guest-carts/:cartId/items');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/items');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/items');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/items' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/items' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/guest-carts/:cartId/items")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/items"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/items"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/items")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/guest-carts/:cartId/items') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/items";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/guest-carts/:cartId/items
http GET {{baseUrl}}/V1/guest-carts/:cartId/items
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/items
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/items")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT guest-carts-{cartId}-items-{itemId} (PUT)
{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId
QUERY PARAMS

cartId
itemId
BODY json

{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId" {:content-type :json
                                                                                :form-params {:cartItem {:extension_attributes {:negotiable_quote_item {:extension_attributes {}
                                                                                                                                                        :item_id 0
                                                                                                                                                        :original_discount_amount ""
                                                                                                                                                        :original_price ""
                                                                                                                                                        :original_tax_amount ""}}
                                                                                                         :item_id 0
                                                                                                         :name ""
                                                                                                         :price ""
                                                                                                         :product_option {:extension_attributes {:bundle_options [{:extension_attributes {}
                                                                                                                                                                   :option_id 0
                                                                                                                                                                   :option_qty 0
                                                                                                                                                                   :option_selections []}]
                                                                                                                                                 :configurable_item_options [{:extension_attributes {}
                                                                                                                                                                              :option_id ""
                                                                                                                                                                              :option_value 0}]
                                                                                                                                                 :custom_options [{:extension_attributes {:file_info {:base64_encoded_data ""
                                                                                                                                                                                                      :name ""
                                                                                                                                                                                                      :type ""}}
                                                                                                                                                                   :option_id ""
                                                                                                                                                                   :option_value ""}]
                                                                                                                                                 :downloadable_option {:downloadable_links []}
                                                                                                                                                 :giftcard_item_option {:custom_giftcard_amount ""
                                                                                                                                                                        :extension_attributes {}
                                                                                                                                                                        :giftcard_amount ""
                                                                                                                                                                        :giftcard_message ""
                                                                                                                                                                        :giftcard_recipient_email ""
                                                                                                                                                                        :giftcard_recipient_name ""
                                                                                                                                                                        :giftcard_sender_email ""
                                                                                                                                                                        :giftcard_sender_name ""}}}
                                                                                                         :product_type ""
                                                                                                         :qty ""
                                                                                                         :quote_id ""
                                                                                                         :sku ""}}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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}}/V1/guest-carts/:cartId/items/:itemId"),
    Content = new StringContent("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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}}/V1/guest-carts/:cartId/items/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId"

	payload := strings.NewReader("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/guest-carts/:cartId/items/:itemId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1573

{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId")
  .header("content-type", "application/json")
  .body("{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [
          {
            extension_attributes: {},
            option_id: 0,
            option_qty: 0,
            option_selections: []
          }
        ],
        configurable_item_options: [
          {
            extension_attributes: {},
            option_id: '',
            option_value: 0
          }
        ],
        custom_options: [
          {
            extension_attributes: {
              file_info: {
                base64_encoded_data: '',
                name: '',
                type: ''
              }
            },
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {
          downloadable_links: []
        },
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId',
  headers: {'content-type': 'application/json'},
  data: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"cartItem":{"extension_attributes":{"negotiable_quote_item":{"extension_attributes":{},"item_id":0,"original_discount_amount":"","original_price":"","original_tax_amount":""}},"item_id":0,"name":"","price":"","product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty":"","quote_id":"","sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "cartItem": {\n    "extension_attributes": {\n      "negotiable_quote_item": {\n        "extension_attributes": {},\n        "item_id": 0,\n        "original_discount_amount": "",\n        "original_price": "",\n        "original_tax_amount": ""\n      }\n    },\n    "item_id": 0,\n    "name": "",\n    "price": "",\n    "product_option": {\n      "extension_attributes": {\n        "bundle_options": [\n          {\n            "extension_attributes": {},\n            "option_id": 0,\n            "option_qty": 0,\n            "option_selections": []\n          }\n        ],\n        "configurable_item_options": [\n          {\n            "extension_attributes": {},\n            "option_id": "",\n            "option_value": 0\n          }\n        ],\n        "custom_options": [\n          {\n            "extension_attributes": {\n              "file_info": {\n                "base64_encoded_data": "",\n                "name": "",\n                "type": ""\n              }\n            },\n            "option_id": "",\n            "option_value": ""\n          }\n        ],\n        "downloadable_option": {\n          "downloadable_links": []\n        },\n        "giftcard_item_option": {\n          "custom_giftcard_amount": "",\n          "extension_attributes": {},\n          "giftcard_amount": "",\n          "giftcard_message": "",\n          "giftcard_recipient_email": "",\n          "giftcard_recipient_name": "",\n          "giftcard_sender_email": "",\n          "giftcard_sender_name": ""\n        }\n      }\n    },\n    "product_type": "",\n    "qty": "",\n    "quote_id": "",\n    "sku": ""\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  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/items/:itemId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
        configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
        custom_options: [
          {
            extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {downloadable_links: []},
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId',
  headers: {'content-type': 'application/json'},
  body: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  },
  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}}/V1/guest-carts/:cartId/items/:itemId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  cartItem: {
    extension_attributes: {
      negotiable_quote_item: {
        extension_attributes: {},
        item_id: 0,
        original_discount_amount: '',
        original_price: '',
        original_tax_amount: ''
      }
    },
    item_id: 0,
    name: '',
    price: '',
    product_option: {
      extension_attributes: {
        bundle_options: [
          {
            extension_attributes: {},
            option_id: 0,
            option_qty: 0,
            option_selections: []
          }
        ],
        configurable_item_options: [
          {
            extension_attributes: {},
            option_id: '',
            option_value: 0
          }
        ],
        custom_options: [
          {
            extension_attributes: {
              file_info: {
                base64_encoded_data: '',
                name: '',
                type: ''
              }
            },
            option_id: '',
            option_value: ''
          }
        ],
        downloadable_option: {
          downloadable_links: []
        },
        giftcard_item_option: {
          custom_giftcard_amount: '',
          extension_attributes: {},
          giftcard_amount: '',
          giftcard_message: '',
          giftcard_recipient_email: '',
          giftcard_recipient_name: '',
          giftcard_sender_email: '',
          giftcard_sender_name: ''
        }
      }
    },
    product_type: '',
    qty: '',
    quote_id: '',
    sku: ''
  }
});

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}}/V1/guest-carts/:cartId/items/:itemId',
  headers: {'content-type': 'application/json'},
  data: {
    cartItem: {
      extension_attributes: {
        negotiable_quote_item: {
          extension_attributes: {},
          item_id: 0,
          original_discount_amount: '',
          original_price: '',
          original_tax_amount: ''
        }
      },
      item_id: 0,
      name: '',
      price: '',
      product_option: {
        extension_attributes: {
          bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
          configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
          custom_options: [
            {
              extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
              option_id: '',
              option_value: ''
            }
          ],
          downloadable_option: {downloadable_links: []},
          giftcard_item_option: {
            custom_giftcard_amount: '',
            extension_attributes: {},
            giftcard_amount: '',
            giftcard_message: '',
            giftcard_recipient_email: '',
            giftcard_recipient_name: '',
            giftcard_sender_email: '',
            giftcard_sender_name: ''
          }
        }
      },
      product_type: '',
      qty: '',
      quote_id: '',
      sku: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"cartItem":{"extension_attributes":{"negotiable_quote_item":{"extension_attributes":{},"item_id":0,"original_discount_amount":"","original_price":"","original_tax_amount":""}},"item_id":0,"name":"","price":"","product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty":"","quote_id":"","sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"cartItem": @{ @"extension_attributes": @{ @"negotiable_quote_item": @{ @"extension_attributes": @{  }, @"item_id": @0, @"original_discount_amount": @"", @"original_price": @"", @"original_tax_amount": @"" } }, @"item_id": @0, @"name": @"", @"price": @"", @"product_option": @{ @"extension_attributes": @{ @"bundle_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @0, @"option_qty": @0, @"option_selections": @[  ] } ], @"configurable_item_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @"", @"option_value": @0 } ], @"custom_options": @[ @{ @"extension_attributes": @{ @"file_info": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" } }, @"option_id": @"", @"option_value": @"" } ], @"downloadable_option": @{ @"downloadable_links": @[  ] }, @"giftcard_item_option": @{ @"custom_giftcard_amount": @"", @"extension_attributes": @{  }, @"giftcard_amount": @"", @"giftcard_message": @"", @"giftcard_recipient_email": @"", @"giftcard_recipient_name": @"", @"giftcard_sender_email": @"", @"giftcard_sender_name": @"" } } }, @"product_type": @"", @"qty": @"", @"quote_id": @"", @"sku": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/items/: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}}/V1/guest-carts/:cartId/items/:itemId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/items/: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([
    'cartItem' => [
        'extension_attributes' => [
                'negotiable_quote_item' => [
                                'extension_attributes' => [
                                                                
                                ],
                                'item_id' => 0,
                                'original_discount_amount' => '',
                                'original_price' => '',
                                'original_tax_amount' => ''
                ]
        ],
        'item_id' => 0,
        'name' => '',
        'price' => '',
        'product_option' => [
                'extension_attributes' => [
                                'bundle_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'option_id' => 0,
                                                                                                                                'option_qty' => 0,
                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'configurable_item_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'option_id' => '',
                                                                                                                                'option_value' => 0
                                                                ]
                                ],
                                'custom_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'option_id' => '',
                                                                                                                                'option_value' => ''
                                                                ]
                                ],
                                'downloadable_option' => [
                                                                'downloadable_links' => [
                                                                                                                                
                                                                ]
                                ],
                                'giftcard_item_option' => [
                                                                'custom_giftcard_amount' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'giftcard_amount' => '',
                                                                'giftcard_message' => '',
                                                                'giftcard_recipient_email' => '',
                                                                'giftcard_recipient_name' => '',
                                                                'giftcard_sender_email' => '',
                                                                'giftcard_sender_name' => ''
                                ]
                ]
        ],
        'product_type' => '',
        'qty' => '',
        'quote_id' => '',
        'sku' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId', [
  'body' => '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'cartItem' => [
    'extension_attributes' => [
        'negotiable_quote_item' => [
                'extension_attributes' => [
                                
                ],
                'item_id' => 0,
                'original_discount_amount' => '',
                'original_price' => '',
                'original_tax_amount' => ''
        ]
    ],
    'item_id' => 0,
    'name' => '',
    'price' => '',
    'product_option' => [
        'extension_attributes' => [
                'bundle_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'option_qty' => 0,
                                                                'option_selections' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'configurable_item_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => 0
                                ]
                ],
                'custom_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ]
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => ''
                                ]
                ],
                'downloadable_option' => [
                                'downloadable_links' => [
                                                                
                                ]
                ],
                'giftcard_item_option' => [
                                'custom_giftcard_amount' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'giftcard_amount' => '',
                                'giftcard_message' => '',
                                'giftcard_recipient_email' => '',
                                'giftcard_recipient_name' => '',
                                'giftcard_sender_email' => '',
                                'giftcard_sender_name' => ''
                ]
        ]
    ],
    'product_type' => '',
    'qty' => '',
    'quote_id' => '',
    'sku' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'cartItem' => [
    'extension_attributes' => [
        'negotiable_quote_item' => [
                'extension_attributes' => [
                                
                ],
                'item_id' => 0,
                'original_discount_amount' => '',
                'original_price' => '',
                'original_tax_amount' => ''
        ]
    ],
    'item_id' => 0,
    'name' => '',
    'price' => '',
    'product_option' => [
        'extension_attributes' => [
                'bundle_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'option_qty' => 0,
                                                                'option_selections' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'configurable_item_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => 0
                                ]
                ],
                'custom_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ]
                                                                ],
                                                                'option_id' => '',
                                                                'option_value' => ''
                                ]
                ],
                'downloadable_option' => [
                                'downloadable_links' => [
                                                                
                                ]
                ],
                'giftcard_item_option' => [
                                'custom_giftcard_amount' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'giftcard_amount' => '',
                                'giftcard_message' => '',
                                'giftcard_recipient_email' => '',
                                'giftcard_recipient_name' => '',
                                'giftcard_sender_email' => '',
                                'giftcard_sender_name' => ''
                ]
        ]
    ],
    'product_type' => '',
    'qty' => '',
    'quote_id' => '',
    'sku' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/guest-carts/:cartId/items/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId"

payload = { "cartItem": {
        "extension_attributes": { "negotiable_quote_item": {
                "extension_attributes": {},
                "item_id": 0,
                "original_discount_amount": "",
                "original_price": "",
                "original_tax_amount": ""
            } },
        "item_id": 0,
        "name": "",
        "price": "",
        "product_option": { "extension_attributes": {
                "bundle_options": [
                    {
                        "extension_attributes": {},
                        "option_id": 0,
                        "option_qty": 0,
                        "option_selections": []
                    }
                ],
                "configurable_item_options": [
                    {
                        "extension_attributes": {},
                        "option_id": "",
                        "option_value": 0
                    }
                ],
                "custom_options": [
                    {
                        "extension_attributes": { "file_info": {
                                "base64_encoded_data": "",
                                "name": "",
                                "type": ""
                            } },
                        "option_id": "",
                        "option_value": ""
                    }
                ],
                "downloadable_option": { "downloadable_links": [] },
                "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                }
            } },
        "product_type": "",
        "qty": "",
        "quote_id": "",
        "sku": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId"

payload <- "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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/V1/guest-carts/:cartId/items/:itemId') do |req|
  req.body = "{\n  \"cartItem\": {\n    \"extension_attributes\": {\n      \"negotiable_quote_item\": {\n        \"extension_attributes\": {},\n        \"item_id\": 0,\n        \"original_discount_amount\": \"\",\n        \"original_price\": \"\",\n        \"original_tax_amount\": \"\"\n      }\n    },\n    \"item_id\": 0,\n    \"name\": \"\",\n    \"price\": \"\",\n    \"product_option\": {\n      \"extension_attributes\": {\n        \"bundle_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"option_qty\": 0,\n            \"option_selections\": []\n          }\n        ],\n        \"configurable_item_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": \"\",\n            \"option_value\": 0\n          }\n        ],\n        \"custom_options\": [\n          {\n            \"extension_attributes\": {\n              \"file_info\": {\n                \"base64_encoded_data\": \"\",\n                \"name\": \"\",\n                \"type\": \"\"\n              }\n            },\n            \"option_id\": \"\",\n            \"option_value\": \"\"\n          }\n        ],\n        \"downloadable_option\": {\n          \"downloadable_links\": []\n        },\n        \"giftcard_item_option\": {\n          \"custom_giftcard_amount\": \"\",\n          \"extension_attributes\": {},\n          \"giftcard_amount\": \"\",\n          \"giftcard_message\": \"\",\n          \"giftcard_recipient_email\": \"\",\n          \"giftcard_recipient_name\": \"\",\n          \"giftcard_sender_email\": \"\",\n          \"giftcard_sender_name\": \"\"\n        }\n      }\n    },\n    \"product_type\": \"\",\n    \"qty\": \"\",\n    \"quote_id\": \"\",\n    \"sku\": \"\"\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}}/V1/guest-carts/:cartId/items/:itemId";

    let payload = json!({"cartItem": json!({
            "extension_attributes": json!({"negotiable_quote_item": json!({
                    "extension_attributes": json!({}),
                    "item_id": 0,
                    "original_discount_amount": "",
                    "original_price": "",
                    "original_tax_amount": ""
                })}),
            "item_id": 0,
            "name": "",
            "price": "",
            "product_option": json!({"extension_attributes": json!({
                    "bundle_options": (
                        json!({
                            "extension_attributes": json!({}),
                            "option_id": 0,
                            "option_qty": 0,
                            "option_selections": ()
                        })
                    ),
                    "configurable_item_options": (
                        json!({
                            "extension_attributes": json!({}),
                            "option_id": "",
                            "option_value": 0
                        })
                    ),
                    "custom_options": (
                        json!({
                            "extension_attributes": json!({"file_info": json!({
                                    "base64_encoded_data": "",
                                    "name": "",
                                    "type": ""
                                })}),
                            "option_id": "",
                            "option_value": ""
                        })
                    ),
                    "downloadable_option": json!({"downloadable_links": ()}),
                    "giftcard_item_option": json!({
                        "custom_giftcard_amount": "",
                        "extension_attributes": json!({}),
                        "giftcard_amount": "",
                        "giftcard_message": "",
                        "giftcard_recipient_email": "",
                        "giftcard_recipient_name": "",
                        "giftcard_sender_email": "",
                        "giftcard_sender_name": ""
                    })
                })}),
            "product_type": "",
            "qty": "",
            "quote_id": "",
            "sku": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/guest-carts/:cartId/items/:itemId \
  --header 'content-type: application/json' \
  --data '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}'
echo '{
  "cartItem": {
    "extension_attributes": {
      "negotiable_quote_item": {
        "extension_attributes": {},
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      }
    },
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": {
      "extension_attributes": {
        "bundle_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          }
        ],
        "configurable_item_options": [
          {
            "extension_attributes": {},
            "option_id": "",
            "option_value": 0
          }
        ],
        "custom_options": [
          {
            "extension_attributes": {
              "file_info": {
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              }
            },
            "option_id": "",
            "option_value": ""
          }
        ],
        "downloadable_option": {
          "downloadable_links": []
        },
        "giftcard_item_option": {
          "custom_giftcard_amount": "",
          "extension_attributes": {},
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        }
      }
    },
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/guest-carts/:cartId/items/:itemId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "cartItem": {\n    "extension_attributes": {\n      "negotiable_quote_item": {\n        "extension_attributes": {},\n        "item_id": 0,\n        "original_discount_amount": "",\n        "original_price": "",\n        "original_tax_amount": ""\n      }\n    },\n    "item_id": 0,\n    "name": "",\n    "price": "",\n    "product_option": {\n      "extension_attributes": {\n        "bundle_options": [\n          {\n            "extension_attributes": {},\n            "option_id": 0,\n            "option_qty": 0,\n            "option_selections": []\n          }\n        ],\n        "configurable_item_options": [\n          {\n            "extension_attributes": {},\n            "option_id": "",\n            "option_value": 0\n          }\n        ],\n        "custom_options": [\n          {\n            "extension_attributes": {\n              "file_info": {\n                "base64_encoded_data": "",\n                "name": "",\n                "type": ""\n              }\n            },\n            "option_id": "",\n            "option_value": ""\n          }\n        ],\n        "downloadable_option": {\n          "downloadable_links": []\n        },\n        "giftcard_item_option": {\n          "custom_giftcard_amount": "",\n          "extension_attributes": {},\n          "giftcard_amount": "",\n          "giftcard_message": "",\n          "giftcard_recipient_email": "",\n          "giftcard_recipient_name": "",\n          "giftcard_sender_email": "",\n          "giftcard_sender_name": ""\n        }\n      }\n    },\n    "product_type": "",\n    "qty": "",\n    "quote_id": "",\n    "sku": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/items/:itemId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["cartItem": [
    "extension_attributes": ["negotiable_quote_item": [
        "extension_attributes": [],
        "item_id": 0,
        "original_discount_amount": "",
        "original_price": "",
        "original_tax_amount": ""
      ]],
    "item_id": 0,
    "name": "",
    "price": "",
    "product_option": ["extension_attributes": [
        "bundle_options": [
          [
            "extension_attributes": [],
            "option_id": 0,
            "option_qty": 0,
            "option_selections": []
          ]
        ],
        "configurable_item_options": [
          [
            "extension_attributes": [],
            "option_id": "",
            "option_value": 0
          ]
        ],
        "custom_options": [
          [
            "extension_attributes": ["file_info": [
                "base64_encoded_data": "",
                "name": "",
                "type": ""
              ]],
            "option_id": "",
            "option_value": ""
          ]
        ],
        "downloadable_option": ["downloadable_links": []],
        "giftcard_item_option": [
          "custom_giftcard_amount": "",
          "extension_attributes": [],
          "giftcard_amount": "",
          "giftcard_message": "",
          "giftcard_recipient_email": "",
          "giftcard_recipient_name": "",
          "giftcard_sender_email": "",
          "giftcard_sender_name": ""
        ]
      ]],
    "product_type": "",
    "qty": "",
    "quote_id": "",
    "sku": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/items/: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()
DELETE guest-carts-{cartId}-items-{itemId}
{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId
QUERY PARAMS

cartId
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId")
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/guest-carts/:cartId/items/:itemId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId"))
    .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}}/V1/guest-carts/:cartId/items/:itemId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId")
  .asString();
const 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}}/V1/guest-carts/:cartId/items/:itemId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/items/:itemId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId');

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}}/V1/guest-carts/:cartId/items/:itemId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/guest-carts/:cartId/items/:itemId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/guest-carts/:cartId/items/:itemId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/guest-carts/:cartId/items/:itemId
http DELETE {{baseUrl}}/V1/guest-carts/:cartId/items/:itemId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/items/:itemId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/items/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT guest-carts-{cartId}-order
{{baseUrl}}/V1/guest-carts/:cartId/order
QUERY PARAMS

cartId
BODY json

{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/order");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/guest-carts/:cartId/order" {:content-type :json
                                                                        :form-params {:paymentMethod {:additional_data []
                                                                                                      :extension_attributes {:agreement_ids []}
                                                                                                      :method ""
                                                                                                      :po_number ""}}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/order"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/guest-carts/:cartId/order"),
    Content = new StringContent("{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/guest-carts/:cartId/order");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/order"

	payload := strings.NewReader("{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/guest-carts/:cartId/order HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 156

{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/guest-carts/:cartId/order")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/order"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/order")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/guest-carts/:cartId/order")
  .header("content-type", "application/json")
  .body("{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/guest-carts/:cartId/order');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/order',
  headers: {'content-type': 'application/json'},
  data: {
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/order';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/order',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\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  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/order")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/order',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  paymentMethod: {
    additional_data: [],
    extension_attributes: {agreement_ids: []},
    method: '',
    po_number: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/order',
  headers: {'content-type': 'application/json'},
  body: {
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/guest-carts/:cartId/order');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/order',
  headers: {'content-type': 'application/json'},
  data: {
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/order';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"paymentMethod": @{ @"additional_data": @[  ], @"extension_attributes": @{ @"agreement_ids": @[  ] }, @"method": @"", @"po_number": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/order"]
                                                       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}}/V1/guest-carts/:cartId/order" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/order",
  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([
    'paymentMethod' => [
        'additional_data' => [
                
        ],
        'extension_attributes' => [
                'agreement_ids' => [
                                
                ]
        ],
        'method' => '',
        'po_number' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/guest-carts/:cartId/order', [
  'body' => '{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/order');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/order');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/order' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/order' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/guest-carts/:cartId/order", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/order"

payload = { "paymentMethod": {
        "additional_data": [],
        "extension_attributes": { "agreement_ids": [] },
        "method": "",
        "po_number": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/order"

payload <- "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/order")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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/V1/guest-carts/:cartId/order') do |req|
  req.body = "{\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/guest-carts/:cartId/order";

    let payload = json!({"paymentMethod": json!({
            "additional_data": (),
            "extension_attributes": json!({"agreement_ids": ()}),
            "method": "",
            "po_number": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/guest-carts/:cartId/order \
  --header 'content-type: application/json' \
  --data '{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
echo '{
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/guest-carts/:cartId/order \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/order
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["paymentMethod": [
    "additional_data": [],
    "extension_attributes": ["agreement_ids": []],
    "method": "",
    "po_number": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/order")! 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 guest-carts-{cartId}-payment-information (POST)
{{baseUrl}}/V1/guest-carts/:cartId/payment-information
QUERY PARAMS

cartId
BODY json

{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/payment-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/guest-carts/:cartId/payment-information" {:content-type :json
                                                                                       :form-params {:billingAddress {:city ""
                                                                                                                      :company ""
                                                                                                                      :country_id ""
                                                                                                                      :custom_attributes [{:attribute_code ""
                                                                                                                                           :value ""}]
                                                                                                                      :customer_address_id 0
                                                                                                                      :customer_id 0
                                                                                                                      :email ""
                                                                                                                      :extension_attributes {:checkout_fields [{}]
                                                                                                                                             :gift_registry_id 0}
                                                                                                                      :fax ""
                                                                                                                      :firstname ""
                                                                                                                      :id 0
                                                                                                                      :lastname ""
                                                                                                                      :middlename ""
                                                                                                                      :postcode ""
                                                                                                                      :prefix ""
                                                                                                                      :region ""
                                                                                                                      :region_code ""
                                                                                                                      :region_id 0
                                                                                                                      :same_as_billing 0
                                                                                                                      :save_in_address_book 0
                                                                                                                      :street []
                                                                                                                      :suffix ""
                                                                                                                      :telephone ""
                                                                                                                      :vat_id ""}
                                                                                                     :email ""
                                                                                                     :paymentMethod {:additional_data []
                                                                                                                     :extension_attributes {:agreement_ids []}
                                                                                                                     :method ""
                                                                                                                     :po_number ""}}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/payment-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/guest-carts/:cartId/payment-information"),
    Content = new StringContent("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/guest-carts/:cartId/payment-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/payment-information"

	payload := strings.NewReader("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/guest-carts/:cartId/payment-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 857

{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/guest-carts/:cartId/payment-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/payment-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/payment-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/guest-carts/:cartId/payment-information")
  .header("content-type", "application/json")
  .body("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  email: '',
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/guest-carts/:cartId/payment-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/payment-information',
  headers: {'content-type': 'application/json'},
  data: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    email: '',
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/payment-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"billingAddress":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"email":"","paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/payment-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "billingAddress": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "email": "",\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\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  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/payment-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/payment-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  email: '',
  paymentMethod: {
    additional_data: [],
    extension_attributes: {agreement_ids: []},
    method: '',
    po_number: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/payment-information',
  headers: {'content-type': 'application/json'},
  body: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    email: '',
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/guest-carts/:cartId/payment-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  email: '',
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/payment-information',
  headers: {'content-type': 'application/json'},
  data: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    email: '',
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/payment-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"billingAddress":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"email":"","paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"billingAddress": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" },
                              @"email": @"",
                              @"paymentMethod": @{ @"additional_data": @[  ], @"extension_attributes": @{ @"agreement_ids": @[  ] }, @"method": @"", @"po_number": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/payment-information"]
                                                       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}}/V1/guest-carts/:cartId/payment-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/payment-information",
  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([
    'billingAddress' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'email' => '',
    'paymentMethod' => [
        'additional_data' => [
                
        ],
        'extension_attributes' => [
                'agreement_ids' => [
                                
                ]
        ],
        'method' => '',
        'po_number' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/guest-carts/:cartId/payment-information', [
  'body' => '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/payment-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'billingAddress' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'email' => '',
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'billingAddress' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'email' => '',
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/payment-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/payment-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/payment-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/guest-carts/:cartId/payment-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/payment-information"

payload = {
    "billingAddress": {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "extension_attributes": {
            "checkout_fields": [{}],
            "gift_registry_id": 0
        },
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "same_as_billing": 0,
        "save_in_address_book": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
    },
    "email": "",
    "paymentMethod": {
        "additional_data": [],
        "extension_attributes": { "agreement_ids": [] },
        "method": "",
        "po_number": ""
    }
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/payment-information"

payload <- "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/payment-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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/V1/guest-carts/:cartId/payment-information') do |req|
  req.body = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/payment-information";

    let payload = json!({
        "billingAddress": json!({
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": json!({
                "checkout_fields": (json!({})),
                "gift_registry_id": 0
            }),
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": (),
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        }),
        "email": "",
        "paymentMethod": json!({
            "additional_data": (),
            "extension_attributes": json!({"agreement_ids": ()}),
            "method": "",
            "po_number": ""
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/guest-carts/:cartId/payment-information \
  --header 'content-type: application/json' \
  --data '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
echo '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/guest-carts/:cartId/payment-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "billingAddress": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "email": "",\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/payment-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "billingAddress": [
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": [
      "checkout_fields": [[]],
      "gift_registry_id": 0
    ],
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  ],
  "email": "",
  "paymentMethod": [
    "additional_data": [],
    "extension_attributes": ["agreement_ids": []],
    "method": "",
    "po_number": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/payment-information")! 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 guest-carts-{cartId}-payment-information
{{baseUrl}}/V1/guest-carts/:cartId/payment-information
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/payment-information");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/guest-carts/:cartId/payment-information")
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/payment-information"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/guest-carts/:cartId/payment-information"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/guest-carts/:cartId/payment-information");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/payment-information"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/guest-carts/:cartId/payment-information HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/guest-carts/:cartId/payment-information")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/payment-information"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/payment-information")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/guest-carts/:cartId/payment-information")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/guest-carts/:cartId/payment-information');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/payment-information'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/payment-information';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/payment-information',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/payment-information")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/payment-information',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/payment-information'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/guest-carts/:cartId/payment-information');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/payment-information'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/payment-information';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/payment-information"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts/:cartId/payment-information" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/payment-information",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/guest-carts/:cartId/payment-information');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/payment-information');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/payment-information');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/payment-information' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/payment-information' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/guest-carts/:cartId/payment-information")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/payment-information"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/payment-information"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/payment-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/guest-carts/:cartId/payment-information') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/payment-information";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/guest-carts/:cartId/payment-information
http GET {{baseUrl}}/V1/guest-carts/:cartId/payment-information
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/payment-information
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/payment-information")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET guest-carts-{cartId}-payment-methods
{{baseUrl}}/V1/guest-carts/:cartId/payment-methods
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/payment-methods");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/guest-carts/:cartId/payment-methods")
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/payment-methods"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/guest-carts/:cartId/payment-methods"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/guest-carts/:cartId/payment-methods");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/payment-methods"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/guest-carts/:cartId/payment-methods HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/guest-carts/:cartId/payment-methods")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/payment-methods"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/payment-methods")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/guest-carts/:cartId/payment-methods")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/guest-carts/:cartId/payment-methods');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/payment-methods'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/payment-methods';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/payment-methods',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/payment-methods")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/payment-methods',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/payment-methods'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/guest-carts/:cartId/payment-methods');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/payment-methods'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/payment-methods';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/payment-methods"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts/:cartId/payment-methods" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/payment-methods",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/guest-carts/:cartId/payment-methods');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/payment-methods');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/payment-methods');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/payment-methods' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/payment-methods' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/guest-carts/:cartId/payment-methods")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/payment-methods"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/payment-methods"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/payment-methods")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/guest-carts/:cartId/payment-methods') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/payment-methods";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/guest-carts/:cartId/payment-methods
http GET {{baseUrl}}/V1/guest-carts/:cartId/payment-methods
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/payment-methods
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/payment-methods")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT guest-carts-{cartId}-selected-payment-method (PUT)
{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method
QUERY PARAMS

cartId
BODY json

{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method" {:content-type :json
                                                                                          :form-params {:method {:additional_data []
                                                                                                                 :extension_attributes {:agreement_ids []}
                                                                                                                 :method ""
                                                                                                                 :po_number ""}}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/guest-carts/:cartId/selected-payment-method"),
    Content = new StringContent("{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/guest-carts/:cartId/selected-payment-method");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method"

	payload := strings.NewReader("{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/guest-carts/:cartId/selected-payment-method HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 149

{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method")
  .header("content-type", "application/json")
  .body("{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  method: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method',
  headers: {'content-type': 'application/json'},
  data: {
    method: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"method":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "method": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\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  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/selected-payment-method',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  method: {
    additional_data: [],
    extension_attributes: {agreement_ids: []},
    method: '',
    po_number: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method',
  headers: {'content-type': 'application/json'},
  body: {
    method: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  method: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method',
  headers: {'content-type': 'application/json'},
  data: {
    method: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"method":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"method": @{ @"additional_data": @[  ], @"extension_attributes": @{ @"agreement_ids": @[  ] }, @"method": @"", @"po_number": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method"]
                                                       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}}/V1/guest-carts/:cartId/selected-payment-method" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method",
  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([
    'method' => [
        'additional_data' => [
                
        ],
        'extension_attributes' => [
                'agreement_ids' => [
                                
                ]
        ],
        'method' => '',
        'po_number' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method', [
  'body' => '{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'method' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'method' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/guest-carts/:cartId/selected-payment-method", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method"

payload = { "method": {
        "additional_data": [],
        "extension_attributes": { "agreement_ids": [] },
        "method": "",
        "po_number": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method"

payload <- "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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/V1/guest-carts/:cartId/selected-payment-method') do |req|
  req.body = "{\n  \"method\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/guest-carts/:cartId/selected-payment-method";

    let payload = json!({"method": json!({
            "additional_data": (),
            "extension_attributes": json!({"agreement_ids": ()}),
            "method": "",
            "po_number": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method \
  --header 'content-type: application/json' \
  --data '{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
echo '{
  "method": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "method": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["method": [
    "additional_data": [],
    "extension_attributes": ["agreement_ids": []],
    "method": "",
    "po_number": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method")! 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 guest-carts-{cartId}-selected-payment-method
{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method")
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/guest-carts/:cartId/selected-payment-method HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/selected-payment-method',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/guest-carts/:cartId/selected-payment-method")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/guest-carts/:cartId/selected-payment-method') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method
http GET {{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/selected-payment-method")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST guest-carts-{cartId}-set-payment-information
{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information
QUERY PARAMS

cartId
BODY json

{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information" {:content-type :json
                                                                                           :form-params {:billingAddress {:city ""
                                                                                                                          :company ""
                                                                                                                          :country_id ""
                                                                                                                          :custom_attributes [{:attribute_code ""
                                                                                                                                               :value ""}]
                                                                                                                          :customer_address_id 0
                                                                                                                          :customer_id 0
                                                                                                                          :email ""
                                                                                                                          :extension_attributes {:checkout_fields [{}]
                                                                                                                                                 :gift_registry_id 0}
                                                                                                                          :fax ""
                                                                                                                          :firstname ""
                                                                                                                          :id 0
                                                                                                                          :lastname ""
                                                                                                                          :middlename ""
                                                                                                                          :postcode ""
                                                                                                                          :prefix ""
                                                                                                                          :region ""
                                                                                                                          :region_code ""
                                                                                                                          :region_id 0
                                                                                                                          :same_as_billing 0
                                                                                                                          :save_in_address_book 0
                                                                                                                          :street []
                                                                                                                          :suffix ""
                                                                                                                          :telephone ""
                                                                                                                          :vat_id ""}
                                                                                                         :email ""
                                                                                                         :paymentMethod {:additional_data []
                                                                                                                         :extension_attributes {:agreement_ids []}
                                                                                                                         :method ""
                                                                                                                         :po_number ""}}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/guest-carts/:cartId/set-payment-information"),
    Content = new StringContent("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/guest-carts/:cartId/set-payment-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information"

	payload := strings.NewReader("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/guest-carts/:cartId/set-payment-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 857

{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information")
  .header("content-type", "application/json")
  .body("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  email: '',
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information',
  headers: {'content-type': 'application/json'},
  data: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    email: '',
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"billingAddress":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"email":"","paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "billingAddress": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "email": "",\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\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  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/set-payment-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  email: '',
  paymentMethod: {
    additional_data: [],
    extension_attributes: {agreement_ids: []},
    method: '',
    po_number: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information',
  headers: {'content-type': 'application/json'},
  body: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    email: '',
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  email: '',
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information',
  headers: {'content-type': 'application/json'},
  data: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    email: '',
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"billingAddress":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"email":"","paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"billingAddress": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" },
                              @"email": @"",
                              @"paymentMethod": @{ @"additional_data": @[  ], @"extension_attributes": @{ @"agreement_ids": @[  ] }, @"method": @"", @"po_number": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information"]
                                                       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}}/V1/guest-carts/:cartId/set-payment-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information",
  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([
    'billingAddress' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'email' => '',
    'paymentMethod' => [
        'additional_data' => [
                
        ],
        'extension_attributes' => [
                'agreement_ids' => [
                                
                ]
        ],
        'method' => '',
        'po_number' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information', [
  'body' => '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'billingAddress' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'email' => '',
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'billingAddress' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'email' => '',
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/guest-carts/:cartId/set-payment-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information"

payload = {
    "billingAddress": {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "extension_attributes": {
            "checkout_fields": [{}],
            "gift_registry_id": 0
        },
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "same_as_billing": 0,
        "save_in_address_book": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
    },
    "email": "",
    "paymentMethod": {
        "additional_data": [],
        "extension_attributes": { "agreement_ids": [] },
        "method": "",
        "po_number": ""
    }
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information"

payload <- "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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/V1/guest-carts/:cartId/set-payment-information') do |req|
  req.body = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information";

    let payload = json!({
        "billingAddress": json!({
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": json!({
                "checkout_fields": (json!({})),
                "gift_registry_id": 0
            }),
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": (),
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        }),
        "email": "",
        "paymentMethod": json!({
            "additional_data": (),
            "extension_attributes": json!({"agreement_ids": ()}),
            "method": "",
            "po_number": ""
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/guest-carts/:cartId/set-payment-information \
  --header 'content-type: application/json' \
  --data '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
echo '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/guest-carts/:cartId/set-payment-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "billingAddress": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "email": "",\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/set-payment-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "billingAddress": [
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": [
      "checkout_fields": [[]],
      "gift_registry_id": 0
    ],
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  ],
  "email": "",
  "paymentMethod": [
    "additional_data": [],
    "extension_attributes": ["agreement_ids": []],
    "method": "",
    "po_number": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/set-payment-information")! 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 guest-carts-{cartId}-shipping-information
{{baseUrl}}/V1/guest-carts/:cartId/shipping-information
QUERY PARAMS

cartId
BODY json

{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/shipping-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/guest-carts/:cartId/shipping-information" {:content-type :json
                                                                                        :form-params {:addressInformation {:billing_address {:city ""
                                                                                                                                             :company ""
                                                                                                                                             :country_id ""
                                                                                                                                             :custom_attributes [{:attribute_code ""
                                                                                                                                                                  :value ""}]
                                                                                                                                             :customer_address_id 0
                                                                                                                                             :customer_id 0
                                                                                                                                             :email ""
                                                                                                                                             :extension_attributes {:checkout_fields [{}]
                                                                                                                                                                    :gift_registry_id 0}
                                                                                                                                             :fax ""
                                                                                                                                             :firstname ""
                                                                                                                                             :id 0
                                                                                                                                             :lastname ""
                                                                                                                                             :middlename ""
                                                                                                                                             :postcode ""
                                                                                                                                             :prefix ""
                                                                                                                                             :region ""
                                                                                                                                             :region_code ""
                                                                                                                                             :region_id 0
                                                                                                                                             :same_as_billing 0
                                                                                                                                             :save_in_address_book 0
                                                                                                                                             :street []
                                                                                                                                             :suffix ""
                                                                                                                                             :telephone ""
                                                                                                                                             :vat_id ""}
                                                                                                                           :custom_attributes [{}]
                                                                                                                           :extension_attributes {}
                                                                                                                           :shipping_address {}
                                                                                                                           :shipping_carrier_code ""
                                                                                                                           :shipping_method_code ""}}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/shipping-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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}}/V1/guest-carts/:cartId/shipping-information"),
    Content = new StringContent("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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}}/V1/guest-carts/:cartId/shipping-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/shipping-information"

	payload := strings.NewReader("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/guest-carts/:cartId/shipping-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 959

{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/guest-carts/:cartId/shipping-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/shipping-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/shipping-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/guest-carts/:cartId/shipping-information")
  .header("content-type", "application/json")
  .body("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  addressInformation: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [
      {}
    ],
    extension_attributes: {},
    shipping_address: {},
    shipping_carrier_code: '',
    shipping_method_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}}/V1/guest-carts/:cartId/shipping-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/shipping-information',
  headers: {'content-type': 'application/json'},
  data: {
    addressInformation: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_address: {},
      shipping_carrier_code: '',
      shipping_method_code: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/shipping-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressInformation":{"billing_address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"custom_attributes":[{}],"extension_attributes":{},"shipping_address":{},"shipping_carrier_code":"","shipping_method_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}}/V1/guest-carts/:cartId/shipping-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "addressInformation": {\n    "billing_address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "custom_attributes": [\n      {}\n    ],\n    "extension_attributes": {},\n    "shipping_address": {},\n    "shipping_carrier_code": "",\n    "shipping_method_code": ""\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  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/shipping-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/shipping-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  addressInformation: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [{}],
    extension_attributes: {},
    shipping_address: {},
    shipping_carrier_code: '',
    shipping_method_code: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/shipping-information',
  headers: {'content-type': 'application/json'},
  body: {
    addressInformation: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_address: {},
      shipping_carrier_code: '',
      shipping_method_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}}/V1/guest-carts/:cartId/shipping-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  addressInformation: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [
      {}
    ],
    extension_attributes: {},
    shipping_address: {},
    shipping_carrier_code: '',
    shipping_method_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}}/V1/guest-carts/:cartId/shipping-information',
  headers: {'content-type': 'application/json'},
  data: {
    addressInformation: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_address: {},
      shipping_carrier_code: '',
      shipping_method_code: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/shipping-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressInformation":{"billing_address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"custom_attributes":[{}],"extension_attributes":{},"shipping_address":{},"shipping_carrier_code":"","shipping_method_code":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"addressInformation": @{ @"billing_address": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" }, @"custom_attributes": @[ @{  } ], @"extension_attributes": @{  }, @"shipping_address": @{  }, @"shipping_carrier_code": @"", @"shipping_method_code": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/shipping-information"]
                                                       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}}/V1/guest-carts/:cartId/shipping-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/shipping-information",
  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([
    'addressInformation' => [
        'billing_address' => [
                'city' => '',
                'company' => '',
                'country_id' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_address_id' => 0,
                'customer_id' => 0,
                'email' => '',
                'extension_attributes' => [
                                'checkout_fields' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'gift_registry_id' => 0
                ],
                'fax' => '',
                'firstname' => '',
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'postcode' => '',
                'prefix' => '',
                'region' => '',
                'region_code' => '',
                'region_id' => 0,
                'same_as_billing' => 0,
                'save_in_address_book' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => ''
        ],
        'custom_attributes' => [
                [
                                
                ]
        ],
        'extension_attributes' => [
                
        ],
        'shipping_address' => [
                
        ],
        'shipping_carrier_code' => '',
        'shipping_method_code' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/guest-carts/:cartId/shipping-information', [
  'body' => '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/shipping-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'addressInformation' => [
    'billing_address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'extension_attributes' => [
        
    ],
    'shipping_address' => [
        
    ],
    'shipping_carrier_code' => '',
    'shipping_method_code' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'addressInformation' => [
    'billing_address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'extension_attributes' => [
        
    ],
    'shipping_address' => [
        
    ],
    'shipping_carrier_code' => '',
    'shipping_method_code' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/shipping-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/shipping-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/shipping-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/guest-carts/:cartId/shipping-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/shipping-information"

payload = { "addressInformation": {
        "billing_address": {
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": [
                {
                    "attribute_code": "",
                    "value": ""
                }
            ],
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": {
                "checkout_fields": [{}],
                "gift_registry_id": 0
            },
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": [],
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        },
        "custom_attributes": [{}],
        "extension_attributes": {},
        "shipping_address": {},
        "shipping_carrier_code": "",
        "shipping_method_code": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/shipping-information"

payload <- "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/shipping-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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/V1/guest-carts/:cartId/shipping-information') do |req|
  req.body = "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/shipping-information";

    let payload = json!({"addressInformation": json!({
            "billing_address": json!({
                "city": "",
                "company": "",
                "country_id": "",
                "custom_attributes": (
                    json!({
                        "attribute_code": "",
                        "value": ""
                    })
                ),
                "customer_address_id": 0,
                "customer_id": 0,
                "email": "",
                "extension_attributes": json!({
                    "checkout_fields": (json!({})),
                    "gift_registry_id": 0
                }),
                "fax": "",
                "firstname": "",
                "id": 0,
                "lastname": "",
                "middlename": "",
                "postcode": "",
                "prefix": "",
                "region": "",
                "region_code": "",
                "region_id": 0,
                "same_as_billing": 0,
                "save_in_address_book": 0,
                "street": (),
                "suffix": "",
                "telephone": "",
                "vat_id": ""
            }),
            "custom_attributes": (json!({})),
            "extension_attributes": json!({}),
            "shipping_address": json!({}),
            "shipping_carrier_code": "",
            "shipping_method_code": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/guest-carts/:cartId/shipping-information \
  --header 'content-type: application/json' \
  --data '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
echo '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/guest-carts/:cartId/shipping-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "addressInformation": {\n    "billing_address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "custom_attributes": [\n      {}\n    ],\n    "extension_attributes": {},\n    "shipping_address": {},\n    "shipping_carrier_code": "",\n    "shipping_method_code": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/shipping-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["addressInformation": [
    "billing_address": [
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        [
          "attribute_code": "",
          "value": ""
        ]
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": [
        "checkout_fields": [[]],
        "gift_registry_id": 0
      ],
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    ],
    "custom_attributes": [[]],
    "extension_attributes": [],
    "shipping_address": [],
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/shipping-information")! 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 guest-carts-{cartId}-shipping-methods
{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods")
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/guest-carts/:cartId/shipping-methods HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/shipping-methods',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/guest-carts/:cartId/shipping-methods")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/guest-carts/:cartId/shipping-methods') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/guest-carts/:cartId/shipping-methods
http GET {{baseUrl}}/V1/guest-carts/:cartId/shipping-methods
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/shipping-methods
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/shipping-methods")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET guest-carts-{cartId}-totals
{{baseUrl}}/V1/guest-carts/:cartId/totals
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/totals");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/guest-carts/:cartId/totals")
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/totals"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/guest-carts/:cartId/totals"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/guest-carts/:cartId/totals");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/totals"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/guest-carts/:cartId/totals HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/guest-carts/:cartId/totals")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/totals"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/totals")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/guest-carts/:cartId/totals")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/guest-carts/:cartId/totals');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/totals'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/totals';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/guest-carts/:cartId/totals',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/totals")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/totals',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/totals'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/guest-carts/:cartId/totals');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/totals'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/totals';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/totals"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/guest-carts/:cartId/totals" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/totals",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/guest-carts/:cartId/totals');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/totals');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/totals');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/totals' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/totals' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/guest-carts/:cartId/totals")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/totals"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/totals"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/totals")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/guest-carts/:cartId/totals') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/totals";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/guest-carts/:cartId/totals
http GET {{baseUrl}}/V1/guest-carts/:cartId/totals
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/totals
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/totals")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST guest-carts-{cartId}-totals-information
{{baseUrl}}/V1/guest-carts/:cartId/totals-information
QUERY PARAMS

cartId
BODY json

{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-carts/:cartId/totals-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/guest-carts/:cartId/totals-information" {:content-type :json
                                                                                      :form-params {:addressInformation {:address {:city ""
                                                                                                                                   :company ""
                                                                                                                                   :country_id ""
                                                                                                                                   :custom_attributes [{:attribute_code ""
                                                                                                                                                        :value ""}]
                                                                                                                                   :customer_address_id 0
                                                                                                                                   :customer_id 0
                                                                                                                                   :email ""
                                                                                                                                   :extension_attributes {:checkout_fields [{}]
                                                                                                                                                          :gift_registry_id 0}
                                                                                                                                   :fax ""
                                                                                                                                   :firstname ""
                                                                                                                                   :id 0
                                                                                                                                   :lastname ""
                                                                                                                                   :middlename ""
                                                                                                                                   :postcode ""
                                                                                                                                   :prefix ""
                                                                                                                                   :region ""
                                                                                                                                   :region_code ""
                                                                                                                                   :region_id 0
                                                                                                                                   :same_as_billing 0
                                                                                                                                   :save_in_address_book 0
                                                                                                                                   :street []
                                                                                                                                   :suffix ""
                                                                                                                                   :telephone ""
                                                                                                                                   :vat_id ""}
                                                                                                                         :custom_attributes [{}]
                                                                                                                         :extension_attributes {}
                                                                                                                         :shipping_carrier_code ""
                                                                                                                         :shipping_method_code ""}}})
require "http/client"

url = "{{baseUrl}}/V1/guest-carts/:cartId/totals-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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}}/V1/guest-carts/:cartId/totals-information"),
    Content = new StringContent("{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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}}/V1/guest-carts/:cartId/totals-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-carts/:cartId/totals-information"

	payload := strings.NewReader("{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/guest-carts/:cartId/totals-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 923

{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/guest-carts/:cartId/totals-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-carts/:cartId/totals-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/totals-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/guest-carts/:cartId/totals-information")
  .header("content-type", "application/json")
  .body("{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  addressInformation: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [
      {}
    ],
    extension_attributes: {},
    shipping_carrier_code: '',
    shipping_method_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}}/V1/guest-carts/:cartId/totals-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/totals-information',
  headers: {'content-type': 'application/json'},
  data: {
    addressInformation: {
      address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_carrier_code: '',
      shipping_method_code: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-carts/:cartId/totals-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressInformation":{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"custom_attributes":[{}],"extension_attributes":{},"shipping_carrier_code":"","shipping_method_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}}/V1/guest-carts/:cartId/totals-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "addressInformation": {\n    "address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "custom_attributes": [\n      {}\n    ],\n    "extension_attributes": {},\n    "shipping_carrier_code": "",\n    "shipping_method_code": ""\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  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-carts/:cartId/totals-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-carts/:cartId/totals-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  addressInformation: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [{}],
    extension_attributes: {},
    shipping_carrier_code: '',
    shipping_method_code: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-carts/:cartId/totals-information',
  headers: {'content-type': 'application/json'},
  body: {
    addressInformation: {
      address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_carrier_code: '',
      shipping_method_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}}/V1/guest-carts/:cartId/totals-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  addressInformation: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [
      {}
    ],
    extension_attributes: {},
    shipping_carrier_code: '',
    shipping_method_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}}/V1/guest-carts/:cartId/totals-information',
  headers: {'content-type': 'application/json'},
  data: {
    addressInformation: {
      address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_carrier_code: '',
      shipping_method_code: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-carts/:cartId/totals-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressInformation":{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"custom_attributes":[{}],"extension_attributes":{},"shipping_carrier_code":"","shipping_method_code":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"addressInformation": @{ @"address": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" }, @"custom_attributes": @[ @{  } ], @"extension_attributes": @{  }, @"shipping_carrier_code": @"", @"shipping_method_code": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-carts/:cartId/totals-information"]
                                                       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}}/V1/guest-carts/:cartId/totals-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-carts/:cartId/totals-information",
  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([
    'addressInformation' => [
        'address' => [
                'city' => '',
                'company' => '',
                'country_id' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_address_id' => 0,
                'customer_id' => 0,
                'email' => '',
                'extension_attributes' => [
                                'checkout_fields' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'gift_registry_id' => 0
                ],
                'fax' => '',
                'firstname' => '',
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'postcode' => '',
                'prefix' => '',
                'region' => '',
                'region_code' => '',
                'region_id' => 0,
                'same_as_billing' => 0,
                'save_in_address_book' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => ''
        ],
        'custom_attributes' => [
                [
                                
                ]
        ],
        'extension_attributes' => [
                
        ],
        'shipping_carrier_code' => '',
        'shipping_method_code' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/guest-carts/:cartId/totals-information', [
  'body' => '{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-carts/:cartId/totals-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'addressInformation' => [
    'address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'extension_attributes' => [
        
    ],
    'shipping_carrier_code' => '',
    'shipping_method_code' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'addressInformation' => [
    'address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'extension_attributes' => [
        
    ],
    'shipping_carrier_code' => '',
    'shipping_method_code' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-carts/:cartId/totals-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-carts/:cartId/totals-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-carts/:cartId/totals-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/guest-carts/:cartId/totals-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-carts/:cartId/totals-information"

payload = { "addressInformation": {
        "address": {
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": [
                {
                    "attribute_code": "",
                    "value": ""
                }
            ],
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": {
                "checkout_fields": [{}],
                "gift_registry_id": 0
            },
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": [],
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        },
        "custom_attributes": [{}],
        "extension_attributes": {},
        "shipping_carrier_code": "",
        "shipping_method_code": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-carts/:cartId/totals-information"

payload <- "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-carts/:cartId/totals-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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/V1/guest-carts/:cartId/totals-information') do |req|
  req.body = "{\n  \"addressInformation\": {\n    \"address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-carts/:cartId/totals-information";

    let payload = json!({"addressInformation": json!({
            "address": json!({
                "city": "",
                "company": "",
                "country_id": "",
                "custom_attributes": (
                    json!({
                        "attribute_code": "",
                        "value": ""
                    })
                ),
                "customer_address_id": 0,
                "customer_id": 0,
                "email": "",
                "extension_attributes": json!({
                    "checkout_fields": (json!({})),
                    "gift_registry_id": 0
                }),
                "fax": "",
                "firstname": "",
                "id": 0,
                "lastname": "",
                "middlename": "",
                "postcode": "",
                "prefix": "",
                "region": "",
                "region_code": "",
                "region_id": 0,
                "same_as_billing": 0,
                "save_in_address_book": 0,
                "street": (),
                "suffix": "",
                "telephone": "",
                "vat_id": ""
            }),
            "custom_attributes": (json!({})),
            "extension_attributes": json!({}),
            "shipping_carrier_code": "",
            "shipping_method_code": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/guest-carts/:cartId/totals-information \
  --header 'content-type: application/json' \
  --data '{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
echo '{
  "addressInformation": {
    "address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/guest-carts/:cartId/totals-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "addressInformation": {\n    "address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "custom_attributes": [\n      {}\n    ],\n    "extension_attributes": {},\n    "shipping_carrier_code": "",\n    "shipping_method_code": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-carts/:cartId/totals-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["addressInformation": [
    "address": [
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        [
          "attribute_code": "",
          "value": ""
        ]
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": [
        "checkout_fields": [[]],
        "gift_registry_id": 0
      ],
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    ],
    "custom_attributes": [[]],
    "extension_attributes": [],
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-carts/:cartId/totals-information")! 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 guest-giftregistry-{cartId}-estimate-shipping-methods
{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods
QUERY PARAMS

cartId
BODY json

{
  "registryId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"registryId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods" {:content-type :json
                                                                                                    :form-params {:registryId 0}})
require "http/client"

url = "{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"registryId\": 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}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods"),
    Content = new StringContent("{\n  \"registryId\": 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}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"registryId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods"

	payload := strings.NewReader("{\n  \"registryId\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/guest-giftregistry/:cartId/estimate-shipping-methods HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 21

{
  "registryId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"registryId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"registryId\": 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  \"registryId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods")
  .header("content-type", "application/json")
  .body("{\n  \"registryId\": 0\n}")
  .asString();
const data = JSON.stringify({
  registryId: 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}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  data: {registryId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"registryId":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}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "registryId": 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  \"registryId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/guest-giftregistry/:cartId/estimate-shipping-methods',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({registryId: 0}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  body: {registryId: 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}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  registryId: 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}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  data: {registryId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"registryId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"registryId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods"]
                                                       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}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"registryId\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods",
  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([
    'registryId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods', [
  'body' => '{
  "registryId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'registryId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'registryId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "registryId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "registryId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"registryId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/guest-giftregistry/:cartId/estimate-shipping-methods", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods"

payload = { "registryId": 0 }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods"

payload <- "{\n  \"registryId\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"registryId\": 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/V1/guest-giftregistry/:cartId/estimate-shipping-methods') do |req|
  req.body = "{\n  \"registryId\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods";

    let payload = json!({"registryId": 0});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods \
  --header 'content-type: application/json' \
  --data '{
  "registryId": 0
}'
echo '{
  "registryId": 0
}' |  \
  http POST {{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "registryId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["registryId": 0] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/guest-giftregistry/:cartId/estimate-shipping-methods")! 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 hierarchy-{id}
{{baseUrl}}/V1/hierarchy/:id
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/hierarchy/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/hierarchy/:id")
require "http/client"

url = "{{baseUrl}}/V1/hierarchy/:id"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/hierarchy/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/hierarchy/:id");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/hierarchy/:id"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/hierarchy/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/hierarchy/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/hierarchy/:id"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/hierarchy/:id")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/hierarchy/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/hierarchy/:id');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/hierarchy/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/hierarchy/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/hierarchy/:id',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/hierarchy/:id")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/hierarchy/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/hierarchy/:id'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/hierarchy/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/hierarchy/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/hierarchy/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/hierarchy/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/hierarchy/:id" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/hierarchy/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/hierarchy/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/hierarchy/:id');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/hierarchy/:id');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/hierarchy/:id' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/hierarchy/:id' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/hierarchy/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/hierarchy/:id"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/hierarchy/:id"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/hierarchy/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/hierarchy/:id') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/hierarchy/:id";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/hierarchy/:id
http GET {{baseUrl}}/V1/hierarchy/:id
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/hierarchy/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/hierarchy/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT hierarchy-move-{id}
{{baseUrl}}/V1/hierarchy/move/:id
QUERY PARAMS

id
BODY json

{
  "newParentId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/hierarchy/move/:id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"newParentId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/hierarchy/move/:id" {:content-type :json
                                                                 :form-params {:newParentId 0}})
require "http/client"

url = "{{baseUrl}}/V1/hierarchy/move/:id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"newParentId\": 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}}/V1/hierarchy/move/:id"),
    Content = new StringContent("{\n  \"newParentId\": 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}}/V1/hierarchy/move/:id");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"newParentId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/hierarchy/move/:id"

	payload := strings.NewReader("{\n  \"newParentId\": 0\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/hierarchy/move/:id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 22

{
  "newParentId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/hierarchy/move/:id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"newParentId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/hierarchy/move/:id"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"newParentId\": 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  \"newParentId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/hierarchy/move/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/hierarchy/move/:id")
  .header("content-type", "application/json")
  .body("{\n  \"newParentId\": 0\n}")
  .asString();
const data = JSON.stringify({
  newParentId: 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}}/V1/hierarchy/move/:id');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/hierarchy/move/:id',
  headers: {'content-type': 'application/json'},
  data: {newParentId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/hierarchy/move/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"newParentId":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}}/V1/hierarchy/move/:id',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "newParentId": 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  \"newParentId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/hierarchy/move/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/hierarchy/move/:id',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({newParentId: 0}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/hierarchy/move/:id',
  headers: {'content-type': 'application/json'},
  body: {newParentId: 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}}/V1/hierarchy/move/:id');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  newParentId: 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}}/V1/hierarchy/move/:id',
  headers: {'content-type': 'application/json'},
  data: {newParentId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/hierarchy/move/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"newParentId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"newParentId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/hierarchy/move/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/hierarchy/move/:id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"newParentId\": 0\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/hierarchy/move/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'newParentId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/hierarchy/move/:id', [
  'body' => '{
  "newParentId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/hierarchy/move/:id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'newParentId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'newParentId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/hierarchy/move/:id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/hierarchy/move/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "newParentId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/hierarchy/move/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "newParentId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"newParentId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/hierarchy/move/:id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/hierarchy/move/:id"

payload = { "newParentId": 0 }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/hierarchy/move/:id"

payload <- "{\n  \"newParentId\": 0\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/hierarchy/move/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"newParentId\": 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/V1/hierarchy/move/:id') do |req|
  req.body = "{\n  \"newParentId\": 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}}/V1/hierarchy/move/:id";

    let payload = json!({"newParentId": 0});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/hierarchy/move/:id \
  --header 'content-type: application/json' \
  --data '{
  "newParentId": 0
}'
echo '{
  "newParentId": 0
}' |  \
  http PUT {{baseUrl}}/V1/hierarchy/move/:id \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "newParentId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/hierarchy/move/:id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["newParentId": 0] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/hierarchy/move/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST integration-admin-token
{{baseUrl}}/V1/integration/admin/token
BODY json

{
  "password": "",
  "username": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/integration/admin/token");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"password\": \"\",\n  \"username\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/integration/admin/token" {:content-type :json
                                                                       :form-params {:password ""
                                                                                     :username ""}})
require "http/client"

url = "{{baseUrl}}/V1/integration/admin/token"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"password\": \"\",\n  \"username\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/integration/admin/token"),
    Content = new StringContent("{\n  \"password\": \"\",\n  \"username\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/integration/admin/token");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"password\": \"\",\n  \"username\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/integration/admin/token"

	payload := strings.NewReader("{\n  \"password\": \"\",\n  \"username\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/integration/admin/token HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 38

{
  "password": "",
  "username": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/integration/admin/token")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"password\": \"\",\n  \"username\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/integration/admin/token"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"password\": \"\",\n  \"username\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"password\": \"\",\n  \"username\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/integration/admin/token")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/integration/admin/token")
  .header("content-type", "application/json")
  .body("{\n  \"password\": \"\",\n  \"username\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  password: '',
  username: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/integration/admin/token');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/integration/admin/token',
  headers: {'content-type': 'application/json'},
  data: {password: '', username: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/integration/admin/token';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"password":"","username":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/integration/admin/token',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "password": "",\n  "username": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"password\": \"\",\n  \"username\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/integration/admin/token")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/integration/admin/token',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({password: '', username: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/integration/admin/token',
  headers: {'content-type': 'application/json'},
  body: {password: '', username: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/integration/admin/token');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  password: '',
  username: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/integration/admin/token',
  headers: {'content-type': 'application/json'},
  data: {password: '', username: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/integration/admin/token';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"password":"","username":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"password": @"",
                              @"username": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/integration/admin/token"]
                                                       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}}/V1/integration/admin/token" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"password\": \"\",\n  \"username\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/integration/admin/token",
  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([
    'password' => '',
    'username' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/integration/admin/token', [
  'body' => '{
  "password": "",
  "username": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/integration/admin/token');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'password' => '',
  'username' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'password' => '',
  'username' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/integration/admin/token');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/integration/admin/token' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "password": "",
  "username": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/integration/admin/token' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "password": "",
  "username": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"password\": \"\",\n  \"username\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/integration/admin/token", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/integration/admin/token"

payload = {
    "password": "",
    "username": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/integration/admin/token"

payload <- "{\n  \"password\": \"\",\n  \"username\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/integration/admin/token")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"password\": \"\",\n  \"username\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/V1/integration/admin/token') do |req|
  req.body = "{\n  \"password\": \"\",\n  \"username\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/integration/admin/token";

    let payload = json!({
        "password": "",
        "username": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/integration/admin/token \
  --header 'content-type: application/json' \
  --data '{
  "password": "",
  "username": ""
}'
echo '{
  "password": "",
  "username": ""
}' |  \
  http POST {{baseUrl}}/V1/integration/admin/token \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "password": "",\n  "username": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/integration/admin/token
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "password": "",
  "username": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/integration/admin/token")! 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 integration-customer-token
{{baseUrl}}/V1/integration/customer/token
BODY json

{
  "password": "",
  "username": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/integration/customer/token");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"password\": \"\",\n  \"username\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/integration/customer/token" {:content-type :json
                                                                          :form-params {:password ""
                                                                                        :username ""}})
require "http/client"

url = "{{baseUrl}}/V1/integration/customer/token"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"password\": \"\",\n  \"username\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/integration/customer/token"),
    Content = new StringContent("{\n  \"password\": \"\",\n  \"username\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/integration/customer/token");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"password\": \"\",\n  \"username\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/integration/customer/token"

	payload := strings.NewReader("{\n  \"password\": \"\",\n  \"username\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/integration/customer/token HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 38

{
  "password": "",
  "username": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/integration/customer/token")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"password\": \"\",\n  \"username\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/integration/customer/token"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"password\": \"\",\n  \"username\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"password\": \"\",\n  \"username\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/integration/customer/token")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/integration/customer/token")
  .header("content-type", "application/json")
  .body("{\n  \"password\": \"\",\n  \"username\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  password: '',
  username: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/integration/customer/token');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/integration/customer/token',
  headers: {'content-type': 'application/json'},
  data: {password: '', username: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/integration/customer/token';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"password":"","username":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/integration/customer/token',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "password": "",\n  "username": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"password\": \"\",\n  \"username\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/integration/customer/token")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/integration/customer/token',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({password: '', username: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/integration/customer/token',
  headers: {'content-type': 'application/json'},
  body: {password: '', username: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/integration/customer/token');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  password: '',
  username: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/integration/customer/token',
  headers: {'content-type': 'application/json'},
  data: {password: '', username: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/integration/customer/token';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"password":"","username":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"password": @"",
                              @"username": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/integration/customer/token"]
                                                       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}}/V1/integration/customer/token" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"password\": \"\",\n  \"username\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/integration/customer/token",
  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([
    'password' => '',
    'username' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/integration/customer/token', [
  'body' => '{
  "password": "",
  "username": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/integration/customer/token');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'password' => '',
  'username' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'password' => '',
  'username' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/integration/customer/token');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/integration/customer/token' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "password": "",
  "username": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/integration/customer/token' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "password": "",
  "username": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"password\": \"\",\n  \"username\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/integration/customer/token", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/integration/customer/token"

payload = {
    "password": "",
    "username": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/integration/customer/token"

payload <- "{\n  \"password\": \"\",\n  \"username\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/integration/customer/token")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"password\": \"\",\n  \"username\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/V1/integration/customer/token') do |req|
  req.body = "{\n  \"password\": \"\",\n  \"username\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/integration/customer/token";

    let payload = json!({
        "password": "",
        "username": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/integration/customer/token \
  --header 'content-type: application/json' \
  --data '{
  "password": "",
  "username": ""
}'
echo '{
  "password": "",
  "username": ""
}' |  \
  http POST {{baseUrl}}/V1/integration/customer/token \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "password": "",\n  "username": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/integration/customer/token
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "password": "",
  "username": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/integration/customer/token")! 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 invoice-{invoiceId}-refund
{{baseUrl}}/V1/invoice/:invoiceId/refund
QUERY PARAMS

invoiceId
BODY json

{
  "appendComment": false,
  "arguments": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "extension_attributes": {
      "return_to_stock_items": []
    },
    "shipping_amount": ""
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "isOnline": false,
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/invoice/:invoiceId/refund");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"isOnline\": false,\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/invoice/:invoiceId/refund" {:content-type :json
                                                                         :form-params {:appendComment false
                                                                                       :arguments {:adjustment_negative ""
                                                                                                   :adjustment_positive ""
                                                                                                   :extension_attributes {:return_to_stock_items []}
                                                                                                   :shipping_amount ""}
                                                                                       :comment {:comment ""
                                                                                                 :extension_attributes {}
                                                                                                 :is_visible_on_front 0}
                                                                                       :isOnline false
                                                                                       :items [{:extension_attributes {}
                                                                                                :order_item_id 0
                                                                                                :qty ""}]
                                                                                       :notify false}})
require "http/client"

url = "{{baseUrl}}/V1/invoice/:invoiceId/refund"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"isOnline\": false,\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": 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}}/V1/invoice/:invoiceId/refund"),
    Content = new StringContent("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"isOnline\": false,\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": 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}}/V1/invoice/:invoiceId/refund");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"isOnline\": false,\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/invoice/:invoiceId/refund"

	payload := strings.NewReader("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"isOnline\": false,\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/invoice/:invoiceId/refund HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 455

{
  "appendComment": false,
  "arguments": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "extension_attributes": {
      "return_to_stock_items": []
    },
    "shipping_amount": ""
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "isOnline": false,
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/invoice/:invoiceId/refund")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"isOnline\": false,\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/invoice/:invoiceId/refund"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"isOnline\": false,\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": 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  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"isOnline\": false,\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/invoice/:invoiceId/refund")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/invoice/:invoiceId/refund")
  .header("content-type", "application/json")
  .body("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"isOnline\": false,\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}")
  .asString();
const data = JSON.stringify({
  appendComment: false,
  arguments: {
    adjustment_negative: '',
    adjustment_positive: '',
    extension_attributes: {
      return_to_stock_items: []
    },
    shipping_amount: ''
  },
  comment: {
    comment: '',
    extension_attributes: {},
    is_visible_on_front: 0
  },
  isOnline: false,
  items: [
    {
      extension_attributes: {},
      order_item_id: 0,
      qty: ''
    }
  ],
  notify: 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}}/V1/invoice/:invoiceId/refund');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/invoice/:invoiceId/refund',
  headers: {'content-type': 'application/json'},
  data: {
    appendComment: false,
    arguments: {
      adjustment_negative: '',
      adjustment_positive: '',
      extension_attributes: {return_to_stock_items: []},
      shipping_amount: ''
    },
    comment: {comment: '', extension_attributes: {}, is_visible_on_front: 0},
    isOnline: false,
    items: [{extension_attributes: {}, order_item_id: 0, qty: ''}],
    notify: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/invoice/:invoiceId/refund';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"appendComment":false,"arguments":{"adjustment_negative":"","adjustment_positive":"","extension_attributes":{"return_to_stock_items":[]},"shipping_amount":""},"comment":{"comment":"","extension_attributes":{},"is_visible_on_front":0},"isOnline":false,"items":[{"extension_attributes":{},"order_item_id":0,"qty":""}],"notify":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}}/V1/invoice/:invoiceId/refund',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "appendComment": false,\n  "arguments": {\n    "adjustment_negative": "",\n    "adjustment_positive": "",\n    "extension_attributes": {\n      "return_to_stock_items": []\n    },\n    "shipping_amount": ""\n  },\n  "comment": {\n    "comment": "",\n    "extension_attributes": {},\n    "is_visible_on_front": 0\n  },\n  "isOnline": false,\n  "items": [\n    {\n      "extension_attributes": {},\n      "order_item_id": 0,\n      "qty": ""\n    }\n  ],\n  "notify": 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  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"isOnline\": false,\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/invoice/:invoiceId/refund")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/invoice/:invoiceId/refund',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  appendComment: false,
  arguments: {
    adjustment_negative: '',
    adjustment_positive: '',
    extension_attributes: {return_to_stock_items: []},
    shipping_amount: ''
  },
  comment: {comment: '', extension_attributes: {}, is_visible_on_front: 0},
  isOnline: false,
  items: [{extension_attributes: {}, order_item_id: 0, qty: ''}],
  notify: false
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/invoice/:invoiceId/refund',
  headers: {'content-type': 'application/json'},
  body: {
    appendComment: false,
    arguments: {
      adjustment_negative: '',
      adjustment_positive: '',
      extension_attributes: {return_to_stock_items: []},
      shipping_amount: ''
    },
    comment: {comment: '', extension_attributes: {}, is_visible_on_front: 0},
    isOnline: false,
    items: [{extension_attributes: {}, order_item_id: 0, qty: ''}],
    notify: 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}}/V1/invoice/:invoiceId/refund');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  appendComment: false,
  arguments: {
    adjustment_negative: '',
    adjustment_positive: '',
    extension_attributes: {
      return_to_stock_items: []
    },
    shipping_amount: ''
  },
  comment: {
    comment: '',
    extension_attributes: {},
    is_visible_on_front: 0
  },
  isOnline: false,
  items: [
    {
      extension_attributes: {},
      order_item_id: 0,
      qty: ''
    }
  ],
  notify: 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}}/V1/invoice/:invoiceId/refund',
  headers: {'content-type': 'application/json'},
  data: {
    appendComment: false,
    arguments: {
      adjustment_negative: '',
      adjustment_positive: '',
      extension_attributes: {return_to_stock_items: []},
      shipping_amount: ''
    },
    comment: {comment: '', extension_attributes: {}, is_visible_on_front: 0},
    isOnline: false,
    items: [{extension_attributes: {}, order_item_id: 0, qty: ''}],
    notify: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/invoice/:invoiceId/refund';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"appendComment":false,"arguments":{"adjustment_negative":"","adjustment_positive":"","extension_attributes":{"return_to_stock_items":[]},"shipping_amount":""},"comment":{"comment":"","extension_attributes":{},"is_visible_on_front":0},"isOnline":false,"items":[{"extension_attributes":{},"order_item_id":0,"qty":""}],"notify":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"appendComment": @NO,
                              @"arguments": @{ @"adjustment_negative": @"", @"adjustment_positive": @"", @"extension_attributes": @{ @"return_to_stock_items": @[  ] }, @"shipping_amount": @"" },
                              @"comment": @{ @"comment": @"", @"extension_attributes": @{  }, @"is_visible_on_front": @0 },
                              @"isOnline": @NO,
                              @"items": @[ @{ @"extension_attributes": @{  }, @"order_item_id": @0, @"qty": @"" } ],
                              @"notify": @NO };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/invoice/:invoiceId/refund"]
                                                       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}}/V1/invoice/:invoiceId/refund" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"isOnline\": false,\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/invoice/:invoiceId/refund",
  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([
    'appendComment' => null,
    'arguments' => [
        'adjustment_negative' => '',
        'adjustment_positive' => '',
        'extension_attributes' => [
                'return_to_stock_items' => [
                                
                ]
        ],
        'shipping_amount' => ''
    ],
    'comment' => [
        'comment' => '',
        'extension_attributes' => [
                
        ],
        'is_visible_on_front' => 0
    ],
    'isOnline' => null,
    'items' => [
        [
                'extension_attributes' => [
                                
                ],
                'order_item_id' => 0,
                'qty' => ''
        ]
    ],
    'notify' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/invoice/:invoiceId/refund', [
  'body' => '{
  "appendComment": false,
  "arguments": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "extension_attributes": {
      "return_to_stock_items": []
    },
    "shipping_amount": ""
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "isOnline": false,
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/invoice/:invoiceId/refund');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'appendComment' => null,
  'arguments' => [
    'adjustment_negative' => '',
    'adjustment_positive' => '',
    'extension_attributes' => [
        'return_to_stock_items' => [
                
        ]
    ],
    'shipping_amount' => ''
  ],
  'comment' => [
    'comment' => '',
    'extension_attributes' => [
        
    ],
    'is_visible_on_front' => 0
  ],
  'isOnline' => null,
  'items' => [
    [
        'extension_attributes' => [
                
        ],
        'order_item_id' => 0,
        'qty' => ''
    ]
  ],
  'notify' => null
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'appendComment' => null,
  'arguments' => [
    'adjustment_negative' => '',
    'adjustment_positive' => '',
    'extension_attributes' => [
        'return_to_stock_items' => [
                
        ]
    ],
    'shipping_amount' => ''
  ],
  'comment' => [
    'comment' => '',
    'extension_attributes' => [
        
    ],
    'is_visible_on_front' => 0
  ],
  'isOnline' => null,
  'items' => [
    [
        'extension_attributes' => [
                
        ],
        'order_item_id' => 0,
        'qty' => ''
    ]
  ],
  'notify' => null
]));
$request->setRequestUrl('{{baseUrl}}/V1/invoice/:invoiceId/refund');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/invoice/:invoiceId/refund' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "appendComment": false,
  "arguments": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "extension_attributes": {
      "return_to_stock_items": []
    },
    "shipping_amount": ""
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "isOnline": false,
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/invoice/:invoiceId/refund' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "appendComment": false,
  "arguments": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "extension_attributes": {
      "return_to_stock_items": []
    },
    "shipping_amount": ""
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "isOnline": false,
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"isOnline\": false,\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/invoice/:invoiceId/refund", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/invoice/:invoiceId/refund"

payload = {
    "appendComment": False,
    "arguments": {
        "adjustment_negative": "",
        "adjustment_positive": "",
        "extension_attributes": { "return_to_stock_items": [] },
        "shipping_amount": ""
    },
    "comment": {
        "comment": "",
        "extension_attributes": {},
        "is_visible_on_front": 0
    },
    "isOnline": False,
    "items": [
        {
            "extension_attributes": {},
            "order_item_id": 0,
            "qty": ""
        }
    ],
    "notify": False
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/invoice/:invoiceId/refund"

payload <- "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"isOnline\": false,\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/invoice/:invoiceId/refund")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"isOnline\": false,\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": 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/V1/invoice/:invoiceId/refund') do |req|
  req.body = "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"isOnline\": false,\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/invoice/:invoiceId/refund";

    let payload = json!({
        "appendComment": false,
        "arguments": json!({
            "adjustment_negative": "",
            "adjustment_positive": "",
            "extension_attributes": json!({"return_to_stock_items": ()}),
            "shipping_amount": ""
        }),
        "comment": json!({
            "comment": "",
            "extension_attributes": json!({}),
            "is_visible_on_front": 0
        }),
        "isOnline": false,
        "items": (
            json!({
                "extension_attributes": json!({}),
                "order_item_id": 0,
                "qty": ""
            })
        ),
        "notify": false
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/invoice/:invoiceId/refund \
  --header 'content-type: application/json' \
  --data '{
  "appendComment": false,
  "arguments": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "extension_attributes": {
      "return_to_stock_items": []
    },
    "shipping_amount": ""
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "isOnline": false,
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}'
echo '{
  "appendComment": false,
  "arguments": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "extension_attributes": {
      "return_to_stock_items": []
    },
    "shipping_amount": ""
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "isOnline": false,
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}' |  \
  http POST {{baseUrl}}/V1/invoice/:invoiceId/refund \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "appendComment": false,\n  "arguments": {\n    "adjustment_negative": "",\n    "adjustment_positive": "",\n    "extension_attributes": {\n      "return_to_stock_items": []\n    },\n    "shipping_amount": ""\n  },\n  "comment": {\n    "comment": "",\n    "extension_attributes": {},\n    "is_visible_on_front": 0\n  },\n  "isOnline": false,\n  "items": [\n    {\n      "extension_attributes": {},\n      "order_item_id": 0,\n      "qty": ""\n    }\n  ],\n  "notify": false\n}' \
  --output-document \
  - {{baseUrl}}/V1/invoice/:invoiceId/refund
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "appendComment": false,
  "arguments": [
    "adjustment_negative": "",
    "adjustment_positive": "",
    "extension_attributes": ["return_to_stock_items": []],
    "shipping_amount": ""
  ],
  "comment": [
    "comment": "",
    "extension_attributes": [],
    "is_visible_on_front": 0
  ],
  "isOnline": false,
  "items": [
    [
      "extension_attributes": [],
      "order_item_id": 0,
      "qty": ""
    ]
  ],
  "notify": false
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/invoice/:invoiceId/refund")! 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 invoices
{{baseUrl}}/V1/invoices
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/invoices");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/invoices")
require "http/client"

url = "{{baseUrl}}/V1/invoices"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/invoices"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/invoices");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/invoices"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/invoices HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/invoices")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/invoices"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/invoices")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/invoices")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/invoices');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/invoices'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/invoices';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/invoices',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/invoices")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/invoices',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/invoices'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/invoices');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/invoices'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/invoices';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/invoices"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/invoices" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/invoices",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/invoices');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/invoices');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/invoices');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/invoices' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/invoices' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/invoices")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/invoices"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/invoices"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/invoices")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/invoices') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/invoices";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/invoices
http GET {{baseUrl}}/V1/invoices
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/invoices
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/invoices")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST invoices-
{{baseUrl}}/V1/invoices/
BODY json

{
  "entity": {
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_refunded": "",
    "billing_address_id": 0,
    "can_void_flag": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": "",
      "vertex_tax_calculation_billing_address": {
        "address_type": "",
        "city": "",
        "company": "",
        "country_id": "",
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "entity_id": 0,
        "extension_attributes": {
          "checkout_fields": [
            {
              "attribute_code": "",
              "value": ""
            }
          ]
        },
        "fax": "",
        "firstname": "",
        "lastname": "",
        "middlename": "",
        "parent_id": 0,
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": "",
        "vat_is_valid": 0,
        "vat_request_date": "",
        "vat_request_id": "",
        "vat_request_success": 0
      },
      "vertex_tax_calculation_order": {
        "adjustment_negative": "",
        "adjustment_positive": "",
        "applied_rule_ids": "",
        "base_adjustment_negative": "",
        "base_adjustment_positive": "",
        "base_currency_code": "",
        "base_discount_amount": "",
        "base_discount_canceled": "",
        "base_discount_invoiced": "",
        "base_discount_refunded": "",
        "base_discount_tax_compensation_amount": "",
        "base_discount_tax_compensation_invoiced": "",
        "base_discount_tax_compensation_refunded": "",
        "base_grand_total": "",
        "base_shipping_amount": "",
        "base_shipping_canceled": "",
        "base_shipping_discount_amount": "",
        "base_shipping_discount_tax_compensation_amnt": "",
        "base_shipping_incl_tax": "",
        "base_shipping_invoiced": "",
        "base_shipping_refunded": "",
        "base_shipping_tax_amount": "",
        "base_shipping_tax_refunded": "",
        "base_subtotal": "",
        "base_subtotal_canceled": "",
        "base_subtotal_incl_tax": "",
        "base_subtotal_invoiced": "",
        "base_subtotal_refunded": "",
        "base_tax_amount": "",
        "base_tax_canceled": "",
        "base_tax_invoiced": "",
        "base_tax_refunded": "",
        "base_to_global_rate": "",
        "base_to_order_rate": "",
        "base_total_canceled": "",
        "base_total_due": "",
        "base_total_invoiced": "",
        "base_total_invoiced_cost": "",
        "base_total_offline_refunded": "",
        "base_total_online_refunded": "",
        "base_total_paid": "",
        "base_total_qty_ordered": "",
        "base_total_refunded": "",
        "billing_address": {},
        "billing_address_id": 0,
        "can_ship_partially": 0,
        "can_ship_partially_item": 0,
        "coupon_code": "",
        "created_at": "",
        "customer_dob": "",
        "customer_email": "",
        "customer_firstname": "",
        "customer_gender": 0,
        "customer_group_id": 0,
        "customer_id": 0,
        "customer_is_guest": 0,
        "customer_lastname": "",
        "customer_middlename": "",
        "customer_note": "",
        "customer_note_notify": 0,
        "customer_prefix": "",
        "customer_suffix": "",
        "customer_taxvat": "",
        "discount_amount": "",
        "discount_canceled": "",
        "discount_description": "",
        "discount_invoiced": "",
        "discount_refunded": "",
        "discount_tax_compensation_amount": "",
        "discount_tax_compensation_invoiced": "",
        "discount_tax_compensation_refunded": "",
        "edit_increment": 0,
        "email_sent": 0,
        "entity_id": 0,
        "ext_customer_id": "",
        "ext_order_id": "",
        "extension_attributes": {
          "amazon_order_reference_id": "",
          "applied_taxes": [
            {
              "amount": "",
              "base_amount": "",
              "code": "",
              "extension_attributes": {
                "rates": [
                  {
                    "code": "",
                    "extension_attributes": {},
                    "percent": "",
                    "title": ""
                  }
                ]
              },
              "percent": "",
              "title": ""
            }
          ],
          "base_customer_balance_amount": "",
          "base_customer_balance_invoiced": "",
          "base_customer_balance_refunded": "",
          "base_customer_balance_total_refunded": "",
          "base_gift_cards_amount": "",
          "base_gift_cards_invoiced": "",
          "base_gift_cards_refunded": "",
          "base_reward_currency_amount": "",
          "company_order_attributes": {
            "company_id": 0,
            "company_name": "",
            "extension_attributes": {},
            "order_id": 0
          },
          "converting_from_quote": false,
          "customer_balance_amount": "",
          "customer_balance_invoiced": "",
          "customer_balance_refunded": "",
          "customer_balance_total_refunded": "",
          "gift_cards": [
            {
              "amount": "",
              "base_amount": "",
              "code": "",
              "id": 0
            }
          ],
          "gift_cards_amount": "",
          "gift_cards_invoiced": "",
          "gift_cards_refunded": "",
          "gift_message": {
            "customer_id": 0,
            "extension_attributes": {
              "entity_id": "",
              "entity_type": "",
              "wrapping_add_printed_card": false,
              "wrapping_allow_gift_receipt": false,
              "wrapping_id": 0
            },
            "gift_message_id": 0,
            "message": "",
            "recipient": "",
            "sender": ""
          },
          "gw_add_card": "",
          "gw_allow_gift_receipt": "",
          "gw_base_price": "",
          "gw_base_price_incl_tax": "",
          "gw_base_price_invoiced": "",
          "gw_base_price_refunded": "",
          "gw_base_tax_amount": "",
          "gw_base_tax_amount_invoiced": "",
          "gw_base_tax_amount_refunded": "",
          "gw_card_base_price": "",
          "gw_card_base_price_incl_tax": "",
          "gw_card_base_price_invoiced": "",
          "gw_card_base_price_refunded": "",
          "gw_card_base_tax_amount": "",
          "gw_card_base_tax_invoiced": "",
          "gw_card_base_tax_refunded": "",
          "gw_card_price": "",
          "gw_card_price_incl_tax": "",
          "gw_card_price_invoiced": "",
          "gw_card_price_refunded": "",
          "gw_card_tax_amount": "",
          "gw_card_tax_invoiced": "",
          "gw_card_tax_refunded": "",
          "gw_id": "",
          "gw_items_base_price": "",
          "gw_items_base_price_incl_tax": "",
          "gw_items_base_price_invoiced": "",
          "gw_items_base_price_refunded": "",
          "gw_items_base_tax_amount": "",
          "gw_items_base_tax_invoiced": "",
          "gw_items_base_tax_refunded": "",
          "gw_items_price": "",
          "gw_items_price_incl_tax": "",
          "gw_items_price_invoiced": "",
          "gw_items_price_refunded": "",
          "gw_items_tax_amount": "",
          "gw_items_tax_invoiced": "",
          "gw_items_tax_refunded": "",
          "gw_price": "",
          "gw_price_incl_tax": "",
          "gw_price_invoiced": "",
          "gw_price_refunded": "",
          "gw_tax_amount": "",
          "gw_tax_amount_invoiced": "",
          "gw_tax_amount_refunded": "",
          "item_applied_taxes": [
            {
              "applied_taxes": [
                {}
              ],
              "associated_item_id": 0,
              "extension_attributes": {},
              "item_id": 0,
              "type": ""
            }
          ],
          "payment_additional_info": [
            {
              "key": "",
              "value": ""
            }
          ],
          "reward_currency_amount": "",
          "reward_points_balance": 0,
          "shipping_assignments": [
            {
              "extension_attributes": {},
              "items": [
                {
                  "additional_data": "",
                  "amount_refunded": "",
                  "applied_rule_ids": "",
                  "base_amount_refunded": "",
                  "base_cost": "",
                  "base_discount_amount": "",
                  "base_discount_invoiced": "",
                  "base_discount_refunded": "",
                  "base_discount_tax_compensation_amount": "",
                  "base_discount_tax_compensation_invoiced": "",
                  "base_discount_tax_compensation_refunded": "",
                  "base_original_price": "",
                  "base_price": "",
                  "base_price_incl_tax": "",
                  "base_row_invoiced": "",
                  "base_row_total": "",
                  "base_row_total_incl_tax": "",
                  "base_tax_amount": "",
                  "base_tax_before_discount": "",
                  "base_tax_invoiced": "",
                  "base_tax_refunded": "",
                  "base_weee_tax_applied_amount": "",
                  "base_weee_tax_applied_row_amnt": "",
                  "base_weee_tax_disposition": "",
                  "base_weee_tax_row_disposition": "",
                  "created_at": "",
                  "description": "",
                  "discount_amount": "",
                  "discount_invoiced": "",
                  "discount_percent": "",
                  "discount_refunded": "",
                  "discount_tax_compensation_amount": "",
                  "discount_tax_compensation_canceled": "",
                  "discount_tax_compensation_invoiced": "",
                  "discount_tax_compensation_refunded": "",
                  "event_id": 0,
                  "ext_order_item_id": "",
                  "extension_attributes": {
                    "gift_message": {},
                    "gw_base_price": "",
                    "gw_base_price_invoiced": "",
                    "gw_base_price_refunded": "",
                    "gw_base_tax_amount": "",
                    "gw_base_tax_amount_invoiced": "",
                    "gw_base_tax_amount_refunded": "",
                    "gw_id": "",
                    "gw_price": "",
                    "gw_price_invoiced": "",
                    "gw_price_refunded": "",
                    "gw_tax_amount": "",
                    "gw_tax_amount_invoiced": "",
                    "gw_tax_amount_refunded": "",
                    "invoice_text_codes": [],
                    "tax_codes": [],
                    "vertex_tax_codes": []
                  },
                  "free_shipping": 0,
                  "gw_base_price": "",
                  "gw_base_price_invoiced": "",
                  "gw_base_price_refunded": "",
                  "gw_base_tax_amount": "",
                  "gw_base_tax_amount_invoiced": "",
                  "gw_base_tax_amount_refunded": "",
                  "gw_id": 0,
                  "gw_price": "",
                  "gw_price_invoiced": "",
                  "gw_price_refunded": "",
                  "gw_tax_amount": "",
                  "gw_tax_amount_invoiced": "",
                  "gw_tax_amount_refunded": "",
                  "is_qty_decimal": 0,
                  "is_virtual": 0,
                  "item_id": 0,
                  "locked_do_invoice": 0,
                  "locked_do_ship": 0,
                  "name": "",
                  "no_discount": 0,
                  "order_id": 0,
                  "original_price": "",
                  "parent_item": "",
                  "parent_item_id": 0,
                  "price": "",
                  "price_incl_tax": "",
                  "product_id": 0,
                  "product_option": {
                    "extension_attributes": {
                      "bundle_options": [
                        {
                          "extension_attributes": {},
                          "option_id": 0,
                          "option_qty": 0,
                          "option_selections": []
                        }
                      ],
                      "configurable_item_options": [
                        {
                          "extension_attributes": {},
                          "option_id": "",
                          "option_value": 0
                        }
                      ],
                      "custom_options": [
                        {
                          "extension_attributes": {
                            "file_info": {
                              "base64_encoded_data": "",
                              "name": "",
                              "type": ""
                            }
                          },
                          "option_id": "",
                          "option_value": ""
                        }
                      ],
                      "downloadable_option": {
                        "downloadable_links": []
                      },
                      "giftcard_item_option": {
                        "custom_giftcard_amount": "",
                        "extension_attributes": {},
                        "giftcard_amount": "",
                        "giftcard_message": "",
                        "giftcard_recipient_email": "",
                        "giftcard_recipient_name": "",
                        "giftcard_sender_email": "",
                        "giftcard_sender_name": ""
                      }
                    }
                  },
                  "product_type": "",
                  "qty_backordered": "",
                  "qty_canceled": "",
                  "qty_invoiced": "",
                  "qty_ordered": "",
                  "qty_refunded": "",
                  "qty_returned": "",
                  "qty_shipped": "",
                  "quote_item_id": 0,
                  "row_invoiced": "",
                  "row_total": "",
                  "row_total_incl_tax": "",
                  "row_weight": "",
                  "sku": "",
                  "store_id": 0,
                  "tax_amount": "",
                  "tax_before_discount": "",
                  "tax_canceled": "",
                  "tax_invoiced": "",
                  "tax_percent": "",
                  "tax_refunded": "",
                  "updated_at": "",
                  "weee_tax_applied": "",
                  "weee_tax_applied_amount": "",
                  "weee_tax_applied_row_amount": "",
                  "weee_tax_disposition": "",
                  "weee_tax_row_disposition": "",
                  "weight": ""
                }
              ],
              "shipping": {
                "address": {},
                "extension_attributes": {
                  "collection_point": {
                    "city": "",
                    "collection_point_id": "",
                    "country": "",
                    "name": "",
                    "postcode": "",
                    "recipient_address_id": 0,
                    "region": "",
                    "street": []
                  },
                  "ext_order_id": "",
                  "shipping_experience": {
                    "code": "",
                    "cost": "",
                    "label": ""
                  }
                },
                "method": "",
                "total": {
                  "base_shipping_amount": "",
                  "base_shipping_canceled": "",
                  "base_shipping_discount_amount": "",
                  "base_shipping_discount_tax_compensation_amnt": "",
                  "base_shipping_incl_tax": "",
                  "base_shipping_invoiced": "",
                  "base_shipping_refunded": "",
                  "base_shipping_tax_amount": "",
                  "base_shipping_tax_refunded": "",
                  "extension_attributes": {},
                  "shipping_amount": "",
                  "shipping_canceled": "",
                  "shipping_discount_amount": "",
                  "shipping_discount_tax_compensation_amount": "",
                  "shipping_incl_tax": "",
                  "shipping_invoiced": "",
                  "shipping_refunded": "",
                  "shipping_tax_amount": "",
                  "shipping_tax_refunded": ""
                }
              },
              "stock_id": 0
            }
          ]
        },
        "forced_shipment_with_invoice": 0,
        "global_currency_code": "",
        "grand_total": "",
        "hold_before_state": "",
        "hold_before_status": "",
        "increment_id": "",
        "is_virtual": 0,
        "items": [
          {}
        ],
        "order_currency_code": "",
        "original_increment_id": "",
        "payment": {
          "account_status": "",
          "additional_data": "",
          "additional_information": [],
          "address_status": "",
          "amount_authorized": "",
          "amount_canceled": "",
          "amount_ordered": "",
          "amount_paid": "",
          "amount_refunded": "",
          "anet_trans_method": "",
          "base_amount_authorized": "",
          "base_amount_canceled": "",
          "base_amount_ordered": "",
          "base_amount_paid": "",
          "base_amount_paid_online": "",
          "base_amount_refunded": "",
          "base_amount_refunded_online": "",
          "base_shipping_amount": "",
          "base_shipping_captured": "",
          "base_shipping_refunded": "",
          "cc_approval": "",
          "cc_avs_status": "",
          "cc_cid_status": "",
          "cc_debug_request_body": "",
          "cc_debug_response_body": "",
          "cc_debug_response_serialized": "",
          "cc_exp_month": "",
          "cc_exp_year": "",
          "cc_last4": "",
          "cc_number_enc": "",
          "cc_owner": "",
          "cc_secure_verify": "",
          "cc_ss_issue": "",
          "cc_ss_start_month": "",
          "cc_ss_start_year": "",
          "cc_status": "",
          "cc_status_description": "",
          "cc_trans_id": "",
          "cc_type": "",
          "echeck_account_name": "",
          "echeck_account_type": "",
          "echeck_bank_name": "",
          "echeck_routing_number": "",
          "echeck_type": "",
          "entity_id": 0,
          "extension_attributes": {
            "vault_payment_token": {
              "created_at": "",
              "customer_id": 0,
              "entity_id": 0,
              "expires_at": "",
              "gateway_token": "",
              "is_active": false,
              "is_visible": false,
              "payment_method_code": "",
              "public_hash": "",
              "token_details": "",
              "type": ""
            }
          },
          "last_trans_id": "",
          "method": "",
          "parent_id": 0,
          "po_number": "",
          "protection_eligibility": "",
          "quote_payment_id": 0,
          "shipping_amount": "",
          "shipping_captured": "",
          "shipping_refunded": ""
        },
        "payment_auth_expiration": 0,
        "payment_authorization_amount": "",
        "protect_code": "",
        "quote_address_id": 0,
        "quote_id": 0,
        "relation_child_id": "",
        "relation_child_real_id": "",
        "relation_parent_id": "",
        "relation_parent_real_id": "",
        "remote_ip": "",
        "shipping_amount": "",
        "shipping_canceled": "",
        "shipping_description": "",
        "shipping_discount_amount": "",
        "shipping_discount_tax_compensation_amount": "",
        "shipping_incl_tax": "",
        "shipping_invoiced": "",
        "shipping_refunded": "",
        "shipping_tax_amount": "",
        "shipping_tax_refunded": "",
        "state": "",
        "status": "",
        "status_histories": [
          {
            "comment": "",
            "created_at": "",
            "entity_id": 0,
            "entity_name": "",
            "extension_attributes": {},
            "is_customer_notified": 0,
            "is_visible_on_front": 0,
            "parent_id": 0,
            "status": ""
          }
        ],
        "store_currency_code": "",
        "store_id": 0,
        "store_name": "",
        "store_to_base_rate": "",
        "store_to_order_rate": "",
        "subtotal": "",
        "subtotal_canceled": "",
        "subtotal_incl_tax": "",
        "subtotal_invoiced": "",
        "subtotal_refunded": "",
        "tax_amount": "",
        "tax_canceled": "",
        "tax_invoiced": "",
        "tax_refunded": "",
        "total_canceled": "",
        "total_due": "",
        "total_invoiced": "",
        "total_item_count": 0,
        "total_offline_refunded": "",
        "total_online_refunded": "",
        "total_paid": "",
        "total_qty_ordered": "",
        "total_refunded": "",
        "updated_at": "",
        "weight": "",
        "x_forwarded_for": ""
      },
      "vertex_tax_calculation_shipping_address": {}
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "is_used_for_refund": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "total_qty": "",
    "transaction_id": "",
    "updated_at": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/invoices/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"entity\": {\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address_id\": 0,\n    \"can_void_flag\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"vertex_tax_calculation_billing_address\": {\n        \"address_type\": \"\",\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"customer_address_id\": 0,\n        \"customer_id\": 0,\n        \"email\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"checkout_fields\": [\n            {\n              \"attribute_code\": \"\",\n              \"value\": \"\"\n            }\n          ]\n        },\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"parent_id\": 0,\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": \"\",\n        \"region_code\": \"\",\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\",\n        \"vat_is_valid\": 0,\n        \"vat_request_date\": \"\",\n        \"vat_request_id\": \"\",\n        \"vat_request_success\": 0\n      },\n      \"vertex_tax_calculation_order\": {\n        \"adjustment_negative\": \"\",\n        \"adjustment_positive\": \"\",\n        \"applied_rule_ids\": \"\",\n        \"base_adjustment_negative\": \"\",\n        \"base_adjustment_positive\": \"\",\n        \"base_currency_code\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_canceled\": \"\",\n        \"base_discount_invoiced\": \"\",\n        \"base_discount_refunded\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_discount_tax_compensation_invoiced\": \"\",\n        \"base_discount_tax_compensation_refunded\": \"\",\n        \"base_grand_total\": \"\",\n        \"base_shipping_amount\": \"\",\n        \"base_shipping_canceled\": \"\",\n        \"base_shipping_discount_amount\": \"\",\n        \"base_shipping_discount_tax_compensation_amnt\": \"\",\n        \"base_shipping_incl_tax\": \"\",\n        \"base_shipping_invoiced\": \"\",\n        \"base_shipping_refunded\": \"\",\n        \"base_shipping_tax_amount\": \"\",\n        \"base_shipping_tax_refunded\": \"\",\n        \"base_subtotal\": \"\",\n        \"base_subtotal_canceled\": \"\",\n        \"base_subtotal_incl_tax\": \"\",\n        \"base_subtotal_invoiced\": \"\",\n        \"base_subtotal_refunded\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_tax_canceled\": \"\",\n        \"base_tax_invoiced\": \"\",\n        \"base_tax_refunded\": \"\",\n        \"base_to_global_rate\": \"\",\n        \"base_to_order_rate\": \"\",\n        \"base_total_canceled\": \"\",\n        \"base_total_due\": \"\",\n        \"base_total_invoiced\": \"\",\n        \"base_total_invoiced_cost\": \"\",\n        \"base_total_offline_refunded\": \"\",\n        \"base_total_online_refunded\": \"\",\n        \"base_total_paid\": \"\",\n        \"base_total_qty_ordered\": \"\",\n        \"base_total_refunded\": \"\",\n        \"billing_address\": {},\n        \"billing_address_id\": 0,\n        \"can_ship_partially\": 0,\n        \"can_ship_partially_item\": 0,\n        \"coupon_code\": \"\",\n        \"created_at\": \"\",\n        \"customer_dob\": \"\",\n        \"customer_email\": \"\",\n        \"customer_firstname\": \"\",\n        \"customer_gender\": 0,\n        \"customer_group_id\": 0,\n        \"customer_id\": 0,\n        \"customer_is_guest\": 0,\n        \"customer_lastname\": \"\",\n        \"customer_middlename\": \"\",\n        \"customer_note\": \"\",\n        \"customer_note_notify\": 0,\n        \"customer_prefix\": \"\",\n        \"customer_suffix\": \"\",\n        \"customer_taxvat\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_canceled\": \"\",\n        \"discount_description\": \"\",\n        \"discount_invoiced\": \"\",\n        \"discount_refunded\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"discount_tax_compensation_invoiced\": \"\",\n        \"discount_tax_compensation_refunded\": \"\",\n        \"edit_increment\": 0,\n        \"email_sent\": 0,\n        \"entity_id\": 0,\n        \"ext_customer_id\": \"\",\n        \"ext_order_id\": \"\",\n        \"extension_attributes\": {\n          \"amazon_order_reference_id\": \"\",\n          \"applied_taxes\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"extension_attributes\": {\n                \"rates\": [\n                  {\n                    \"code\": \"\",\n                    \"extension_attributes\": {},\n                    \"percent\": \"\",\n                    \"title\": \"\"\n                  }\n                ]\n              },\n              \"percent\": \"\",\n              \"title\": \"\"\n            }\n          ],\n          \"base_customer_balance_amount\": \"\",\n          \"base_customer_balance_invoiced\": \"\",\n          \"base_customer_balance_refunded\": \"\",\n          \"base_customer_balance_total_refunded\": \"\",\n          \"base_gift_cards_amount\": \"\",\n          \"base_gift_cards_invoiced\": \"\",\n          \"base_gift_cards_refunded\": \"\",\n          \"base_reward_currency_amount\": \"\",\n          \"company_order_attributes\": {\n            \"company_id\": 0,\n            \"company_name\": \"\",\n            \"extension_attributes\": {},\n            \"order_id\": 0\n          },\n          \"converting_from_quote\": false,\n          \"customer_balance_amount\": \"\",\n          \"customer_balance_invoiced\": \"\",\n          \"customer_balance_refunded\": \"\",\n          \"customer_balance_total_refunded\": \"\",\n          \"gift_cards\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"id\": 0\n            }\n          ],\n          \"gift_cards_amount\": \"\",\n          \"gift_cards_invoiced\": \"\",\n          \"gift_cards_refunded\": \"\",\n          \"gift_message\": {\n            \"customer_id\": 0,\n            \"extension_attributes\": {\n              \"entity_id\": \"\",\n              \"entity_type\": \"\",\n              \"wrapping_add_printed_card\": false,\n              \"wrapping_allow_gift_receipt\": false,\n              \"wrapping_id\": 0\n            },\n            \"gift_message_id\": 0,\n            \"message\": \"\",\n            \"recipient\": \"\",\n            \"sender\": \"\"\n          },\n          \"gw_add_card\": \"\",\n          \"gw_allow_gift_receipt\": \"\",\n          \"gw_base_price\": \"\",\n          \"gw_base_price_incl_tax\": \"\",\n          \"gw_base_price_invoiced\": \"\",\n          \"gw_base_price_refunded\": \"\",\n          \"gw_base_tax_amount\": \"\",\n          \"gw_base_tax_amount_invoiced\": \"\",\n          \"gw_base_tax_amount_refunded\": \"\",\n          \"gw_card_base_price\": \"\",\n          \"gw_card_base_price_incl_tax\": \"\",\n          \"gw_card_base_price_invoiced\": \"\",\n          \"gw_card_base_price_refunded\": \"\",\n          \"gw_card_base_tax_amount\": \"\",\n          \"gw_card_base_tax_invoiced\": \"\",\n          \"gw_card_base_tax_refunded\": \"\",\n          \"gw_card_price\": \"\",\n          \"gw_card_price_incl_tax\": \"\",\n          \"gw_card_price_invoiced\": \"\",\n          \"gw_card_price_refunded\": \"\",\n          \"gw_card_tax_amount\": \"\",\n          \"gw_card_tax_invoiced\": \"\",\n          \"gw_card_tax_refunded\": \"\",\n          \"gw_id\": \"\",\n          \"gw_items_base_price\": \"\",\n          \"gw_items_base_price_incl_tax\": \"\",\n          \"gw_items_base_price_invoiced\": \"\",\n          \"gw_items_base_price_refunded\": \"\",\n          \"gw_items_base_tax_amount\": \"\",\n          \"gw_items_base_tax_invoiced\": \"\",\n          \"gw_items_base_tax_refunded\": \"\",\n          \"gw_items_price\": \"\",\n          \"gw_items_price_incl_tax\": \"\",\n          \"gw_items_price_invoiced\": \"\",\n          \"gw_items_price_refunded\": \"\",\n          \"gw_items_tax_amount\": \"\",\n          \"gw_items_tax_invoiced\": \"\",\n          \"gw_items_tax_refunded\": \"\",\n          \"gw_price\": \"\",\n          \"gw_price_incl_tax\": \"\",\n          \"gw_price_invoiced\": \"\",\n          \"gw_price_refunded\": \"\",\n          \"gw_tax_amount\": \"\",\n          \"gw_tax_amount_invoiced\": \"\",\n          \"gw_tax_amount_refunded\": \"\",\n          \"item_applied_taxes\": [\n            {\n              \"applied_taxes\": [\n                {}\n              ],\n              \"associated_item_id\": 0,\n              \"extension_attributes\": {},\n              \"item_id\": 0,\n              \"type\": \"\"\n            }\n          ],\n          \"payment_additional_info\": [\n            {\n              \"key\": \"\",\n              \"value\": \"\"\n            }\n          ],\n          \"reward_currency_amount\": \"\",\n          \"reward_points_balance\": 0,\n          \"shipping_assignments\": [\n            {\n              \"extension_attributes\": {},\n              \"items\": [\n                {\n                  \"additional_data\": \"\",\n                  \"amount_refunded\": \"\",\n                  \"applied_rule_ids\": \"\",\n                  \"base_amount_refunded\": \"\",\n                  \"base_cost\": \"\",\n                  \"base_discount_amount\": \"\",\n                  \"base_discount_invoiced\": \"\",\n                  \"base_discount_refunded\": \"\",\n                  \"base_discount_tax_compensation_amount\": \"\",\n                  \"base_discount_tax_compensation_invoiced\": \"\",\n                  \"base_discount_tax_compensation_refunded\": \"\",\n                  \"base_original_price\": \"\",\n                  \"base_price\": \"\",\n                  \"base_price_incl_tax\": \"\",\n                  \"base_row_invoiced\": \"\",\n                  \"base_row_total\": \"\",\n                  \"base_row_total_incl_tax\": \"\",\n                  \"base_tax_amount\": \"\",\n                  \"base_tax_before_discount\": \"\",\n                  \"base_tax_invoiced\": \"\",\n                  \"base_tax_refunded\": \"\",\n                  \"base_weee_tax_applied_amount\": \"\",\n                  \"base_weee_tax_applied_row_amnt\": \"\",\n                  \"base_weee_tax_disposition\": \"\",\n                  \"base_weee_tax_row_disposition\": \"\",\n                  \"created_at\": \"\",\n                  \"description\": \"\",\n                  \"discount_amount\": \"\",\n                  \"discount_invoiced\": \"\",\n                  \"discount_percent\": \"\",\n                  \"discount_refunded\": \"\",\n                  \"discount_tax_compensation_amount\": \"\",\n                  \"discount_tax_compensation_canceled\": \"\",\n                  \"discount_tax_compensation_invoiced\": \"\",\n                  \"discount_tax_compensation_refunded\": \"\",\n                  \"event_id\": 0,\n                  \"ext_order_item_id\": \"\",\n                  \"extension_attributes\": {\n                    \"gift_message\": {},\n                    \"gw_base_price\": \"\",\n                    \"gw_base_price_invoiced\": \"\",\n                    \"gw_base_price_refunded\": \"\",\n                    \"gw_base_tax_amount\": \"\",\n                    \"gw_base_tax_amount_invoiced\": \"\",\n                    \"gw_base_tax_amount_refunded\": \"\",\n                    \"gw_id\": \"\",\n                    \"gw_price\": \"\",\n                    \"gw_price_invoiced\": \"\",\n                    \"gw_price_refunded\": \"\",\n                    \"gw_tax_amount\": \"\",\n                    \"gw_tax_amount_invoiced\": \"\",\n                    \"gw_tax_amount_refunded\": \"\",\n                    \"invoice_text_codes\": [],\n                    \"tax_codes\": [],\n                    \"vertex_tax_codes\": []\n                  },\n                  \"free_shipping\": 0,\n                  \"gw_base_price\": \"\",\n                  \"gw_base_price_invoiced\": \"\",\n                  \"gw_base_price_refunded\": \"\",\n                  \"gw_base_tax_amount\": \"\",\n                  \"gw_base_tax_amount_invoiced\": \"\",\n                  \"gw_base_tax_amount_refunded\": \"\",\n                  \"gw_id\": 0,\n                  \"gw_price\": \"\",\n                  \"gw_price_invoiced\": \"\",\n                  \"gw_price_refunded\": \"\",\n                  \"gw_tax_amount\": \"\",\n                  \"gw_tax_amount_invoiced\": \"\",\n                  \"gw_tax_amount_refunded\": \"\",\n                  \"is_qty_decimal\": 0,\n                  \"is_virtual\": 0,\n                  \"item_id\": 0,\n                  \"locked_do_invoice\": 0,\n                  \"locked_do_ship\": 0,\n                  \"name\": \"\",\n                  \"no_discount\": 0,\n                  \"order_id\": 0,\n                  \"original_price\": \"\",\n                  \"parent_item\": \"\",\n                  \"parent_item_id\": 0,\n                  \"price\": \"\",\n                  \"price_incl_tax\": \"\",\n                  \"product_id\": 0,\n                  \"product_option\": {\n                    \"extension_attributes\": {\n                      \"bundle_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": 0,\n                          \"option_qty\": 0,\n                          \"option_selections\": []\n                        }\n                      ],\n                      \"configurable_item_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": \"\",\n                          \"option_value\": 0\n                        }\n                      ],\n                      \"custom_options\": [\n                        {\n                          \"extension_attributes\": {\n                            \"file_info\": {\n                              \"base64_encoded_data\": \"\",\n                              \"name\": \"\",\n                              \"type\": \"\"\n                            }\n                          },\n                          \"option_id\": \"\",\n                          \"option_value\": \"\"\n                        }\n                      ],\n                      \"downloadable_option\": {\n                        \"downloadable_links\": []\n                      },\n                      \"giftcard_item_option\": {\n                        \"custom_giftcard_amount\": \"\",\n                        \"extension_attributes\": {},\n                        \"giftcard_amount\": \"\",\n                        \"giftcard_message\": \"\",\n                        \"giftcard_recipient_email\": \"\",\n                        \"giftcard_recipient_name\": \"\",\n                        \"giftcard_sender_email\": \"\",\n                        \"giftcard_sender_name\": \"\"\n                      }\n                    }\n                  },\n                  \"product_type\": \"\",\n                  \"qty_backordered\": \"\",\n                  \"qty_canceled\": \"\",\n                  \"qty_invoiced\": \"\",\n                  \"qty_ordered\": \"\",\n                  \"qty_refunded\": \"\",\n                  \"qty_returned\": \"\",\n                  \"qty_shipped\": \"\",\n                  \"quote_item_id\": 0,\n                  \"row_invoiced\": \"\",\n                  \"row_total\": \"\",\n                  \"row_total_incl_tax\": \"\",\n                  \"row_weight\": \"\",\n                  \"sku\": \"\",\n                  \"store_id\": 0,\n                  \"tax_amount\": \"\",\n                  \"tax_before_discount\": \"\",\n                  \"tax_canceled\": \"\",\n                  \"tax_invoiced\": \"\",\n                  \"tax_percent\": \"\",\n                  \"tax_refunded\": \"\",\n                  \"updated_at\": \"\",\n                  \"weee_tax_applied\": \"\",\n                  \"weee_tax_applied_amount\": \"\",\n                  \"weee_tax_applied_row_amount\": \"\",\n                  \"weee_tax_disposition\": \"\",\n                  \"weee_tax_row_disposition\": \"\",\n                  \"weight\": \"\"\n                }\n              ],\n              \"shipping\": {\n                \"address\": {},\n                \"extension_attributes\": {\n                  \"collection_point\": {\n                    \"city\": \"\",\n                    \"collection_point_id\": \"\",\n                    \"country\": \"\",\n                    \"name\": \"\",\n                    \"postcode\": \"\",\n                    \"recipient_address_id\": 0,\n                    \"region\": \"\",\n                    \"street\": []\n                  },\n                  \"ext_order_id\": \"\",\n                  \"shipping_experience\": {\n                    \"code\": \"\",\n                    \"cost\": \"\",\n                    \"label\": \"\"\n                  }\n                },\n                \"method\": \"\",\n                \"total\": {\n                  \"base_shipping_amount\": \"\",\n                  \"base_shipping_canceled\": \"\",\n                  \"base_shipping_discount_amount\": \"\",\n                  \"base_shipping_discount_tax_compensation_amnt\": \"\",\n                  \"base_shipping_incl_tax\": \"\",\n                  \"base_shipping_invoiced\": \"\",\n                  \"base_shipping_refunded\": \"\",\n                  \"base_shipping_tax_amount\": \"\",\n                  \"base_shipping_tax_refunded\": \"\",\n                  \"extension_attributes\": {},\n                  \"shipping_amount\": \"\",\n                  \"shipping_canceled\": \"\",\n                  \"shipping_discount_amount\": \"\",\n                  \"shipping_discount_tax_compensation_amount\": \"\",\n                  \"shipping_incl_tax\": \"\",\n                  \"shipping_invoiced\": \"\",\n                  \"shipping_refunded\": \"\",\n                  \"shipping_tax_amount\": \"\",\n                  \"shipping_tax_refunded\": \"\"\n                }\n              },\n              \"stock_id\": 0\n            }\n          ]\n        },\n        \"forced_shipment_with_invoice\": 0,\n        \"global_currency_code\": \"\",\n        \"grand_total\": \"\",\n        \"hold_before_state\": \"\",\n        \"hold_before_status\": \"\",\n        \"increment_id\": \"\",\n        \"is_virtual\": 0,\n        \"items\": [\n          {}\n        ],\n        \"order_currency_code\": \"\",\n        \"original_increment_id\": \"\",\n        \"payment\": {\n          \"account_status\": \"\",\n          \"additional_data\": \"\",\n          \"additional_information\": [],\n          \"address_status\": \"\",\n          \"amount_authorized\": \"\",\n          \"amount_canceled\": \"\",\n          \"amount_ordered\": \"\",\n          \"amount_paid\": \"\",\n          \"amount_refunded\": \"\",\n          \"anet_trans_method\": \"\",\n          \"base_amount_authorized\": \"\",\n          \"base_amount_canceled\": \"\",\n          \"base_amount_ordered\": \"\",\n          \"base_amount_paid\": \"\",\n          \"base_amount_paid_online\": \"\",\n          \"base_amount_refunded\": \"\",\n          \"base_amount_refunded_online\": \"\",\n          \"base_shipping_amount\": \"\",\n          \"base_shipping_captured\": \"\",\n          \"base_shipping_refunded\": \"\",\n          \"cc_approval\": \"\",\n          \"cc_avs_status\": \"\",\n          \"cc_cid_status\": \"\",\n          \"cc_debug_request_body\": \"\",\n          \"cc_debug_response_body\": \"\",\n          \"cc_debug_response_serialized\": \"\",\n          \"cc_exp_month\": \"\",\n          \"cc_exp_year\": \"\",\n          \"cc_last4\": \"\",\n          \"cc_number_enc\": \"\",\n          \"cc_owner\": \"\",\n          \"cc_secure_verify\": \"\",\n          \"cc_ss_issue\": \"\",\n          \"cc_ss_start_month\": \"\",\n          \"cc_ss_start_year\": \"\",\n          \"cc_status\": \"\",\n          \"cc_status_description\": \"\",\n          \"cc_trans_id\": \"\",\n          \"cc_type\": \"\",\n          \"echeck_account_name\": \"\",\n          \"echeck_account_type\": \"\",\n          \"echeck_bank_name\": \"\",\n          \"echeck_routing_number\": \"\",\n          \"echeck_type\": \"\",\n          \"entity_id\": 0,\n          \"extension_attributes\": {\n            \"vault_payment_token\": {\n              \"created_at\": \"\",\n              \"customer_id\": 0,\n              \"entity_id\": 0,\n              \"expires_at\": \"\",\n              \"gateway_token\": \"\",\n              \"is_active\": false,\n              \"is_visible\": false,\n              \"payment_method_code\": \"\",\n              \"public_hash\": \"\",\n              \"token_details\": \"\",\n              \"type\": \"\"\n            }\n          },\n          \"last_trans_id\": \"\",\n          \"method\": \"\",\n          \"parent_id\": 0,\n          \"po_number\": \"\",\n          \"protection_eligibility\": \"\",\n          \"quote_payment_id\": 0,\n          \"shipping_amount\": \"\",\n          \"shipping_captured\": \"\",\n          \"shipping_refunded\": \"\"\n        },\n        \"payment_auth_expiration\": 0,\n        \"payment_authorization_amount\": \"\",\n        \"protect_code\": \"\",\n        \"quote_address_id\": 0,\n        \"quote_id\": 0,\n        \"relation_child_id\": \"\",\n        \"relation_child_real_id\": \"\",\n        \"relation_parent_id\": \"\",\n        \"relation_parent_real_id\": \"\",\n        \"remote_ip\": \"\",\n        \"shipping_amount\": \"\",\n        \"shipping_canceled\": \"\",\n        \"shipping_description\": \"\",\n        \"shipping_discount_amount\": \"\",\n        \"shipping_discount_tax_compensation_amount\": \"\",\n        \"shipping_incl_tax\": \"\",\n        \"shipping_invoiced\": \"\",\n        \"shipping_refunded\": \"\",\n        \"shipping_tax_amount\": \"\",\n        \"shipping_tax_refunded\": \"\",\n        \"state\": \"\",\n        \"status\": \"\",\n        \"status_histories\": [\n          {\n            \"comment\": \"\",\n            \"created_at\": \"\",\n            \"entity_id\": 0,\n            \"entity_name\": \"\",\n            \"extension_attributes\": {},\n            \"is_customer_notified\": 0,\n            \"is_visible_on_front\": 0,\n            \"parent_id\": 0,\n            \"status\": \"\"\n          }\n        ],\n        \"store_currency_code\": \"\",\n        \"store_id\": 0,\n        \"store_name\": \"\",\n        \"store_to_base_rate\": \"\",\n        \"store_to_order_rate\": \"\",\n        \"subtotal\": \"\",\n        \"subtotal_canceled\": \"\",\n        \"subtotal_incl_tax\": \"\",\n        \"subtotal_invoiced\": \"\",\n        \"subtotal_refunded\": \"\",\n        \"tax_amount\": \"\",\n        \"tax_canceled\": \"\",\n        \"tax_invoiced\": \"\",\n        \"tax_refunded\": \"\",\n        \"total_canceled\": \"\",\n        \"total_due\": \"\",\n        \"total_invoiced\": \"\",\n        \"total_item_count\": 0,\n        \"total_offline_refunded\": \"\",\n        \"total_online_refunded\": \"\",\n        \"total_paid\": \"\",\n        \"total_qty_ordered\": \"\",\n        \"total_refunded\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\",\n        \"x_forwarded_for\": \"\"\n      },\n      \"vertex_tax_calculation_shipping_address\": {}\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"is_used_for_refund\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"total_qty\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/invoices/" {:content-type :json
                                                         :form-params {:entity {:base_currency_code ""
                                                                                :base_discount_amount ""
                                                                                :base_discount_tax_compensation_amount ""
                                                                                :base_grand_total ""
                                                                                :base_shipping_amount ""
                                                                                :base_shipping_discount_tax_compensation_amnt ""
                                                                                :base_shipping_incl_tax ""
                                                                                :base_shipping_tax_amount ""
                                                                                :base_subtotal ""
                                                                                :base_subtotal_incl_tax ""
                                                                                :base_tax_amount ""
                                                                                :base_to_global_rate ""
                                                                                :base_to_order_rate ""
                                                                                :base_total_refunded ""
                                                                                :billing_address_id 0
                                                                                :can_void_flag 0
                                                                                :comments [{:comment ""
                                                                                            :created_at ""
                                                                                            :entity_id 0
                                                                                            :extension_attributes {}
                                                                                            :is_customer_notified 0
                                                                                            :is_visible_on_front 0
                                                                                            :parent_id 0}]
                                                                                :created_at ""
                                                                                :discount_amount ""
                                                                                :discount_description ""
                                                                                :discount_tax_compensation_amount ""
                                                                                :email_sent 0
                                                                                :entity_id 0
                                                                                :extension_attributes {:base_customer_balance_amount ""
                                                                                                       :base_gift_cards_amount ""
                                                                                                       :customer_balance_amount ""
                                                                                                       :gift_cards_amount ""
                                                                                                       :gw_base_price ""
                                                                                                       :gw_base_tax_amount ""
                                                                                                       :gw_card_base_price ""
                                                                                                       :gw_card_base_tax_amount ""
                                                                                                       :gw_card_price ""
                                                                                                       :gw_card_tax_amount ""
                                                                                                       :gw_items_base_price ""
                                                                                                       :gw_items_base_tax_amount ""
                                                                                                       :gw_items_price ""
                                                                                                       :gw_items_tax_amount ""
                                                                                                       :gw_price ""
                                                                                                       :gw_tax_amount ""
                                                                                                       :vertex_tax_calculation_billing_address {:address_type ""
                                                                                                                                                :city ""
                                                                                                                                                :company ""
                                                                                                                                                :country_id ""
                                                                                                                                                :customer_address_id 0
                                                                                                                                                :customer_id 0
                                                                                                                                                :email ""
                                                                                                                                                :entity_id 0
                                                                                                                                                :extension_attributes {:checkout_fields [{:attribute_code ""
                                                                                                                                                                                          :value ""}]}
                                                                                                                                                :fax ""
                                                                                                                                                :firstname ""
                                                                                                                                                :lastname ""
                                                                                                                                                :middlename ""
                                                                                                                                                :parent_id 0
                                                                                                                                                :postcode ""
                                                                                                                                                :prefix ""
                                                                                                                                                :region ""
                                                                                                                                                :region_code ""
                                                                                                                                                :region_id 0
                                                                                                                                                :street []
                                                                                                                                                :suffix ""
                                                                                                                                                :telephone ""
                                                                                                                                                :vat_id ""
                                                                                                                                                :vat_is_valid 0
                                                                                                                                                :vat_request_date ""
                                                                                                                                                :vat_request_id ""
                                                                                                                                                :vat_request_success 0}
                                                                                                       :vertex_tax_calculation_order {:adjustment_negative ""
                                                                                                                                      :adjustment_positive ""
                                                                                                                                      :applied_rule_ids ""
                                                                                                                                      :base_adjustment_negative ""
                                                                                                                                      :base_adjustment_positive ""
                                                                                                                                      :base_currency_code ""
                                                                                                                                      :base_discount_amount ""
                                                                                                                                      :base_discount_canceled ""
                                                                                                                                      :base_discount_invoiced ""
                                                                                                                                      :base_discount_refunded ""
                                                                                                                                      :base_discount_tax_compensation_amount ""
                                                                                                                                      :base_discount_tax_compensation_invoiced ""
                                                                                                                                      :base_discount_tax_compensation_refunded ""
                                                                                                                                      :base_grand_total ""
                                                                                                                                      :base_shipping_amount ""
                                                                                                                                      :base_shipping_canceled ""
                                                                                                                                      :base_shipping_discount_amount ""
                                                                                                                                      :base_shipping_discount_tax_compensation_amnt ""
                                                                                                                                      :base_shipping_incl_tax ""
                                                                                                                                      :base_shipping_invoiced ""
                                                                                                                                      :base_shipping_refunded ""
                                                                                                                                      :base_shipping_tax_amount ""
                                                                                                                                      :base_shipping_tax_refunded ""
                                                                                                                                      :base_subtotal ""
                                                                                                                                      :base_subtotal_canceled ""
                                                                                                                                      :base_subtotal_incl_tax ""
                                                                                                                                      :base_subtotal_invoiced ""
                                                                                                                                      :base_subtotal_refunded ""
                                                                                                                                      :base_tax_amount ""
                                                                                                                                      :base_tax_canceled ""
                                                                                                                                      :base_tax_invoiced ""
                                                                                                                                      :base_tax_refunded ""
                                                                                                                                      :base_to_global_rate ""
                                                                                                                                      :base_to_order_rate ""
                                                                                                                                      :base_total_canceled ""
                                                                                                                                      :base_total_due ""
                                                                                                                                      :base_total_invoiced ""
                                                                                                                                      :base_total_invoiced_cost ""
                                                                                                                                      :base_total_offline_refunded ""
                                                                                                                                      :base_total_online_refunded ""
                                                                                                                                      :base_total_paid ""
                                                                                                                                      :base_total_qty_ordered ""
                                                                                                                                      :base_total_refunded ""
                                                                                                                                      :billing_address {}
                                                                                                                                      :billing_address_id 0
                                                                                                                                      :can_ship_partially 0
                                                                                                                                      :can_ship_partially_item 0
                                                                                                                                      :coupon_code ""
                                                                                                                                      :created_at ""
                                                                                                                                      :customer_dob ""
                                                                                                                                      :customer_email ""
                                                                                                                                      :customer_firstname ""
                                                                                                                                      :customer_gender 0
                                                                                                                                      :customer_group_id 0
                                                                                                                                      :customer_id 0
                                                                                                                                      :customer_is_guest 0
                                                                                                                                      :customer_lastname ""
                                                                                                                                      :customer_middlename ""
                                                                                                                                      :customer_note ""
                                                                                                                                      :customer_note_notify 0
                                                                                                                                      :customer_prefix ""
                                                                                                                                      :customer_suffix ""
                                                                                                                                      :customer_taxvat ""
                                                                                                                                      :discount_amount ""
                                                                                                                                      :discount_canceled ""
                                                                                                                                      :discount_description ""
                                                                                                                                      :discount_invoiced ""
                                                                                                                                      :discount_refunded ""
                                                                                                                                      :discount_tax_compensation_amount ""
                                                                                                                                      :discount_tax_compensation_invoiced ""
                                                                                                                                      :discount_tax_compensation_refunded ""
                                                                                                                                      :edit_increment 0
                                                                                                                                      :email_sent 0
                                                                                                                                      :entity_id 0
                                                                                                                                      :ext_customer_id ""
                                                                                                                                      :ext_order_id ""
                                                                                                                                      :extension_attributes {:amazon_order_reference_id ""
                                                                                                                                                             :applied_taxes [{:amount ""
                                                                                                                                                                              :base_amount ""
                                                                                                                                                                              :code ""
                                                                                                                                                                              :extension_attributes {:rates [{:code ""
                                                                                                                                                                                                              :extension_attributes {}
                                                                                                                                                                                                              :percent ""
                                                                                                                                                                                                              :title ""}]}
                                                                                                                                                                              :percent ""
                                                                                                                                                                              :title ""}]
                                                                                                                                                             :base_customer_balance_amount ""
                                                                                                                                                             :base_customer_balance_invoiced ""
                                                                                                                                                             :base_customer_balance_refunded ""
                                                                                                                                                             :base_customer_balance_total_refunded ""
                                                                                                                                                             :base_gift_cards_amount ""
                                                                                                                                                             :base_gift_cards_invoiced ""
                                                                                                                                                             :base_gift_cards_refunded ""
                                                                                                                                                             :base_reward_currency_amount ""
                                                                                                                                                             :company_order_attributes {:company_id 0
                                                                                                                                                                                        :company_name ""
                                                                                                                                                                                        :extension_attributes {}
                                                                                                                                                                                        :order_id 0}
                                                                                                                                                             :converting_from_quote false
                                                                                                                                                             :customer_balance_amount ""
                                                                                                                                                             :customer_balance_invoiced ""
                                                                                                                                                             :customer_balance_refunded ""
                                                                                                                                                             :customer_balance_total_refunded ""
                                                                                                                                                             :gift_cards [{:amount ""
                                                                                                                                                                           :base_amount ""
                                                                                                                                                                           :code ""
                                                                                                                                                                           :id 0}]
                                                                                                                                                             :gift_cards_amount ""
                                                                                                                                                             :gift_cards_invoiced ""
                                                                                                                                                             :gift_cards_refunded ""
                                                                                                                                                             :gift_message {:customer_id 0
                                                                                                                                                                            :extension_attributes {:entity_id ""
                                                                                                                                                                                                   :entity_type ""
                                                                                                                                                                                                   :wrapping_add_printed_card false
                                                                                                                                                                                                   :wrapping_allow_gift_receipt false
                                                                                                                                                                                                   :wrapping_id 0}
                                                                                                                                                                            :gift_message_id 0
                                                                                                                                                                            :message ""
                                                                                                                                                                            :recipient ""
                                                                                                                                                                            :sender ""}
                                                                                                                                                             :gw_add_card ""
                                                                                                                                                             :gw_allow_gift_receipt ""
                                                                                                                                                             :gw_base_price ""
                                                                                                                                                             :gw_base_price_incl_tax ""
                                                                                                                                                             :gw_base_price_invoiced ""
                                                                                                                                                             :gw_base_price_refunded ""
                                                                                                                                                             :gw_base_tax_amount ""
                                                                                                                                                             :gw_base_tax_amount_invoiced ""
                                                                                                                                                             :gw_base_tax_amount_refunded ""
                                                                                                                                                             :gw_card_base_price ""
                                                                                                                                                             :gw_card_base_price_incl_tax ""
                                                                                                                                                             :gw_card_base_price_invoiced ""
                                                                                                                                                             :gw_card_base_price_refunded ""
                                                                                                                                                             :gw_card_base_tax_amount ""
                                                                                                                                                             :gw_card_base_tax_invoiced ""
                                                                                                                                                             :gw_card_base_tax_refunded ""
                                                                                                                                                             :gw_card_price ""
                                                                                                                                                             :gw_card_price_incl_tax ""
                                                                                                                                                             :gw_card_price_invoiced ""
                                                                                                                                                             :gw_card_price_refunded ""
                                                                                                                                                             :gw_card_tax_amount ""
                                                                                                                                                             :gw_card_tax_invoiced ""
                                                                                                                                                             :gw_card_tax_refunded ""
                                                                                                                                                             :gw_id ""
                                                                                                                                                             :gw_items_base_price ""
                                                                                                                                                             :gw_items_base_price_incl_tax ""
                                                                                                                                                             :gw_items_base_price_invoiced ""
                                                                                                                                                             :gw_items_base_price_refunded ""
                                                                                                                                                             :gw_items_base_tax_amount ""
                                                                                                                                                             :gw_items_base_tax_invoiced ""
                                                                                                                                                             :gw_items_base_tax_refunded ""
                                                                                                                                                             :gw_items_price ""
                                                                                                                                                             :gw_items_price_incl_tax ""
                                                                                                                                                             :gw_items_price_invoiced ""
                                                                                                                                                             :gw_items_price_refunded ""
                                                                                                                                                             :gw_items_tax_amount ""
                                                                                                                                                             :gw_items_tax_invoiced ""
                                                                                                                                                             :gw_items_tax_refunded ""
                                                                                                                                                             :gw_price ""
                                                                                                                                                             :gw_price_incl_tax ""
                                                                                                                                                             :gw_price_invoiced ""
                                                                                                                                                             :gw_price_refunded ""
                                                                                                                                                             :gw_tax_amount ""
                                                                                                                                                             :gw_tax_amount_invoiced ""
                                                                                                                                                             :gw_tax_amount_refunded ""
                                                                                                                                                             :item_applied_taxes [{:applied_taxes [{}]
                                                                                                                                                                                   :associated_item_id 0
                                                                                                                                                                                   :extension_attributes {}
                                                                                                                                                                                   :item_id 0
                                                                                                                                                                                   :type ""}]
                                                                                                                                                             :payment_additional_info [{:key ""
                                                                                                                                                                                        :value ""}]
                                                                                                                                                             :reward_currency_amount ""
                                                                                                                                                             :reward_points_balance 0
                                                                                                                                                             :shipping_assignments [{:extension_attributes {}
                                                                                                                                                                                     :items [{:additional_data ""
                                                                                                                                                                                              :amount_refunded ""
                                                                                                                                                                                              :applied_rule_ids ""
                                                                                                                                                                                              :base_amount_refunded ""
                                                                                                                                                                                              :base_cost ""
                                                                                                                                                                                              :base_discount_amount ""
                                                                                                                                                                                              :base_discount_invoiced ""
                                                                                                                                                                                              :base_discount_refunded ""
                                                                                                                                                                                              :base_discount_tax_compensation_amount ""
                                                                                                                                                                                              :base_discount_tax_compensation_invoiced ""
                                                                                                                                                                                              :base_discount_tax_compensation_refunded ""
                                                                                                                                                                                              :base_original_price ""
                                                                                                                                                                                              :base_price ""
                                                                                                                                                                                              :base_price_incl_tax ""
                                                                                                                                                                                              :base_row_invoiced ""
                                                                                                                                                                                              :base_row_total ""
                                                                                                                                                                                              :base_row_total_incl_tax ""
                                                                                                                                                                                              :base_tax_amount ""
                                                                                                                                                                                              :base_tax_before_discount ""
                                                                                                                                                                                              :base_tax_invoiced ""
                                                                                                                                                                                              :base_tax_refunded ""
                                                                                                                                                                                              :base_weee_tax_applied_amount ""
                                                                                                                                                                                              :base_weee_tax_applied_row_amnt ""
                                                                                                                                                                                              :base_weee_tax_disposition ""
                                                                                                                                                                                              :base_weee_tax_row_disposition ""
                                                                                                                                                                                              :created_at ""
                                                                                                                                                                                              :description ""
                                                                                                                                                                                              :discount_amount ""
                                                                                                                                                                                              :discount_invoiced ""
                                                                                                                                                                                              :discount_percent ""
                                                                                                                                                                                              :discount_refunded ""
                                                                                                                                                                                              :discount_tax_compensation_amount ""
                                                                                                                                                                                              :discount_tax_compensation_canceled ""
                                                                                                                                                                                              :discount_tax_compensation_invoiced ""
                                                                                                                                                                                              :discount_tax_compensation_refunded ""
                                                                                                                                                                                              :event_id 0
                                                                                                                                                                                              :ext_order_item_id ""
                                                                                                                                                                                              :extension_attributes {:gift_message {}
                                                                                                                                                                                                                     :gw_base_price ""
                                                                                                                                                                                                                     :gw_base_price_invoiced ""
                                                                                                                                                                                                                     :gw_base_price_refunded ""
                                                                                                                                                                                                                     :gw_base_tax_amount ""
                                                                                                                                                                                                                     :gw_base_tax_amount_invoiced ""
                                                                                                                                                                                                                     :gw_base_tax_amount_refunded ""
                                                                                                                                                                                                                     :gw_id ""
                                                                                                                                                                                                                     :gw_price ""
                                                                                                                                                                                                                     :gw_price_invoiced ""
                                                                                                                                                                                                                     :gw_price_refunded ""
                                                                                                                                                                                                                     :gw_tax_amount ""
                                                                                                                                                                                                                     :gw_tax_amount_invoiced ""
                                                                                                                                                                                                                     :gw_tax_amount_refunded ""
                                                                                                                                                                                                                     :invoice_text_codes []
                                                                                                                                                                                                                     :tax_codes []
                                                                                                                                                                                                                     :vertex_tax_codes []}
                                                                                                                                                                                              :free_shipping 0
                                                                                                                                                                                              :gw_base_price ""
                                                                                                                                                                                              :gw_base_price_invoiced ""
                                                                                                                                                                                              :gw_base_price_refunded ""
                                                                                                                                                                                              :gw_base_tax_amount ""
                                                                                                                                                                                              :gw_base_tax_amount_invoiced ""
                                                                                                                                                                                              :gw_base_tax_amount_refunded ""
                                                                                                                                                                                              :gw_id 0
                                                                                                                                                                                              :gw_price ""
                                                                                                                                                                                              :gw_price_invoiced ""
                                                                                                                                                                                              :gw_price_refunded ""
                                                                                                                                                                                              :gw_tax_amount ""
                                                                                                                                                                                              :gw_tax_amount_invoiced ""
                                                                                                                                                                                              :gw_tax_amount_refunded ""
                                                                                                                                                                                              :is_qty_decimal 0
                                                                                                                                                                                              :is_virtual 0
                                                                                                                                                                                              :item_id 0
                                                                                                                                                                                              :locked_do_invoice 0
                                                                                                                                                                                              :locked_do_ship 0
                                                                                                                                                                                              :name ""
                                                                                                                                                                                              :no_discount 0
                                                                                                                                                                                              :order_id 0
                                                                                                                                                                                              :original_price ""
                                                                                                                                                                                              :parent_item ""
                                                                                                                                                                                              :parent_item_id 0
                                                                                                                                                                                              :price ""
                                                                                                                                                                                              :price_incl_tax ""
                                                                                                                                                                                              :product_id 0
                                                                                                                                                                                              :product_option {:extension_attributes {:bundle_options [{:extension_attributes {}
                                                                                                                                                                                                                                                        :option_id 0
                                                                                                                                                                                                                                                        :option_qty 0
                                                                                                                                                                                                                                                        :option_selections []}]
                                                                                                                                                                                                                                      :configurable_item_options [{:extension_attributes {}
                                                                                                                                                                                                                                                                   :option_id ""
                                                                                                                                                                                                                                                                   :option_value 0}]
                                                                                                                                                                                                                                      :custom_options [{:extension_attributes {:file_info {:base64_encoded_data ""
                                                                                                                                                                                                                                                                                           :name ""
                                                                                                                                                                                                                                                                                           :type ""}}
                                                                                                                                                                                                                                                        :option_id ""
                                                                                                                                                                                                                                                        :option_value ""}]
                                                                                                                                                                                                                                      :downloadable_option {:downloadable_links []}
                                                                                                                                                                                                                                      :giftcard_item_option {:custom_giftcard_amount ""
                                                                                                                                                                                                                                                             :extension_attributes {}
                                                                                                                                                                                                                                                             :giftcard_amount ""
                                                                                                                                                                                                                                                             :giftcard_message ""
                                                                                                                                                                                                                                                             :giftcard_recipient_email ""
                                                                                                                                                                                                                                                             :giftcard_recipient_name ""
                                                                                                                                                                                                                                                             :giftcard_sender_email ""
                                                                                                                                                                                                                                                             :giftcard_sender_name ""}}}
                                                                                                                                                                                              :product_type ""
                                                                                                                                                                                              :qty_backordered ""
                                                                                                                                                                                              :qty_canceled ""
                                                                                                                                                                                              :qty_invoiced ""
                                                                                                                                                                                              :qty_ordered ""
                                                                                                                                                                                              :qty_refunded ""
                                                                                                                                                                                              :qty_returned ""
                                                                                                                                                                                              :qty_shipped ""
                                                                                                                                                                                              :quote_item_id 0
                                                                                                                                                                                              :row_invoiced ""
                                                                                                                                                                                              :row_total ""
                                                                                                                                                                                              :row_total_incl_tax ""
                                                                                                                                                                                              :row_weight ""
                                                                                                                                                                                              :sku ""
                                                                                                                                                                                              :store_id 0
                                                                                                                                                                                              :tax_amount ""
                                                                                                                                                                                              :tax_before_discount ""
                                                                                                                                                                                              :tax_canceled ""
                                                                                                                                                                                              :tax_invoiced ""
                                                                                                                                                                                              :tax_percent ""
                                                                                                                                                                                              :tax_refunded ""
                                                                                                                                                                                              :updated_at ""
                                                                                                                                                                                              :weee_tax_applied ""
                                                                                                                                                                                              :weee_tax_applied_amount ""
                                                                                                                                                                                              :weee_tax_applied_row_amount ""
                                                                                                                                                                                              :weee_tax_disposition ""
                                                                                                                                                                                              :weee_tax_row_disposition ""
                                                                                                                                                                                              :weight ""}]
                                                                                                                                                                                     :shipping {:address {}
                                                                                                                                                                                                :extension_attributes {:collection_point {:city ""
                                                                                                                                                                                                                                          :collection_point_id ""
                                                                                                                                                                                                                                          :country ""
                                                                                                                                                                                                                                          :name ""
                                                                                                                                                                                                                                          :postcode ""
                                                                                                                                                                                                                                          :recipient_address_id 0
                                                                                                                                                                                                                                          :region ""
                                                                                                                                                                                                                                          :street []}
                                                                                                                                                                                                                       :ext_order_id ""
                                                                                                                                                                                                                       :shipping_experience {:code ""
                                                                                                                                                                                                                                             :cost ""
                                                                                                                                                                                                                                             :label ""}}
                                                                                                                                                                                                :method ""
                                                                                                                                                                                                :total {:base_shipping_amount ""
                                                                                                                                                                                                        :base_shipping_canceled ""
                                                                                                                                                                                                        :base_shipping_discount_amount ""
                                                                                                                                                                                                        :base_shipping_discount_tax_compensation_amnt ""
                                                                                                                                                                                                        :base_shipping_incl_tax ""
                                                                                                                                                                                                        :base_shipping_invoiced ""
                                                                                                                                                                                                        :base_shipping_refunded ""
                                                                                                                                                                                                        :base_shipping_tax_amount ""
                                                                                                                                                                                                        :base_shipping_tax_refunded ""
                                                                                                                                                                                                        :extension_attributes {}
                                                                                                                                                                                                        :shipping_amount ""
                                                                                                                                                                                                        :shipping_canceled ""
                                                                                                                                                                                                        :shipping_discount_amount ""
                                                                                                                                                                                                        :shipping_discount_tax_compensation_amount ""
                                                                                                                                                                                                        :shipping_incl_tax ""
                                                                                                                                                                                                        :shipping_invoiced ""
                                                                                                                                                                                                        :shipping_refunded ""
                                                                                                                                                                                                        :shipping_tax_amount ""
                                                                                                                                                                                                        :shipping_tax_refunded ""}}
                                                                                                                                                                                     :stock_id 0}]}
                                                                                                                                      :forced_shipment_with_invoice 0
                                                                                                                                      :global_currency_code ""
                                                                                                                                      :grand_total ""
                                                                                                                                      :hold_before_state ""
                                                                                                                                      :hold_before_status ""
                                                                                                                                      :increment_id ""
                                                                                                                                      :is_virtual 0
                                                                                                                                      :items [{}]
                                                                                                                                      :order_currency_code ""
                                                                                                                                      :original_increment_id ""
                                                                                                                                      :payment {:account_status ""
                                                                                                                                                :additional_data ""
                                                                                                                                                :additional_information []
                                                                                                                                                :address_status ""
                                                                                                                                                :amount_authorized ""
                                                                                                                                                :amount_canceled ""
                                                                                                                                                :amount_ordered ""
                                                                                                                                                :amount_paid ""
                                                                                                                                                :amount_refunded ""
                                                                                                                                                :anet_trans_method ""
                                                                                                                                                :base_amount_authorized ""
                                                                                                                                                :base_amount_canceled ""
                                                                                                                                                :base_amount_ordered ""
                                                                                                                                                :base_amount_paid ""
                                                                                                                                                :base_amount_paid_online ""
                                                                                                                                                :base_amount_refunded ""
                                                                                                                                                :base_amount_refunded_online ""
                                                                                                                                                :base_shipping_amount ""
                                                                                                                                                :base_shipping_captured ""
                                                                                                                                                :base_shipping_refunded ""
                                                                                                                                                :cc_approval ""
                                                                                                                                                :cc_avs_status ""
                                                                                                                                                :cc_cid_status ""
                                                                                                                                                :cc_debug_request_body ""
                                                                                                                                                :cc_debug_response_body ""
                                                                                                                                                :cc_debug_response_serialized ""
                                                                                                                                                :cc_exp_month ""
                                                                                                                                                :cc_exp_year ""
                                                                                                                                                :cc_last4 ""
                                                                                                                                                :cc_number_enc ""
                                                                                                                                                :cc_owner ""
                                                                                                                                                :cc_secure_verify ""
                                                                                                                                                :cc_ss_issue ""
                                                                                                                                                :cc_ss_start_month ""
                                                                                                                                                :cc_ss_start_year ""
                                                                                                                                                :cc_status ""
                                                                                                                                                :cc_status_description ""
                                                                                                                                                :cc_trans_id ""
                                                                                                                                                :cc_type ""
                                                                                                                                                :echeck_account_name ""
                                                                                                                                                :echeck_account_type ""
                                                                                                                                                :echeck_bank_name ""
                                                                                                                                                :echeck_routing_number ""
                                                                                                                                                :echeck_type ""
                                                                                                                                                :entity_id 0
                                                                                                                                                :extension_attributes {:vault_payment_token {:created_at ""
                                                                                                                                                                                             :customer_id 0
                                                                                                                                                                                             :entity_id 0
                                                                                                                                                                                             :expires_at ""
                                                                                                                                                                                             :gateway_token ""
                                                                                                                                                                                             :is_active false
                                                                                                                                                                                             :is_visible false
                                                                                                                                                                                             :payment_method_code ""
                                                                                                                                                                                             :public_hash ""
                                                                                                                                                                                             :token_details ""
                                                                                                                                                                                             :type ""}}
                                                                                                                                                :last_trans_id ""
                                                                                                                                                :method ""
                                                                                                                                                :parent_id 0
                                                                                                                                                :po_number ""
                                                                                                                                                :protection_eligibility ""
                                                                                                                                                :quote_payment_id 0
                                                                                                                                                :shipping_amount ""
                                                                                                                                                :shipping_captured ""
                                                                                                                                                :shipping_refunded ""}
                                                                                                                                      :payment_auth_expiration 0
                                                                                                                                      :payment_authorization_amount ""
                                                                                                                                      :protect_code ""
                                                                                                                                      :quote_address_id 0
                                                                                                                                      :quote_id 0
                                                                                                                                      :relation_child_id ""
                                                                                                                                      :relation_child_real_id ""
                                                                                                                                      :relation_parent_id ""
                                                                                                                                      :relation_parent_real_id ""
                                                                                                                                      :remote_ip ""
                                                                                                                                      :shipping_amount ""
                                                                                                                                      :shipping_canceled ""
                                                                                                                                      :shipping_description ""
                                                                                                                                      :shipping_discount_amount ""
                                                                                                                                      :shipping_discount_tax_compensation_amount ""
                                                                                                                                      :shipping_incl_tax ""
                                                                                                                                      :shipping_invoiced ""
                                                                                                                                      :shipping_refunded ""
                                                                                                                                      :shipping_tax_amount ""
                                                                                                                                      :shipping_tax_refunded ""
                                                                                                                                      :state ""
                                                                                                                                      :status ""
                                                                                                                                      :status_histories [{:comment ""
                                                                                                                                                          :created_at ""
                                                                                                                                                          :entity_id 0
                                                                                                                                                          :entity_name ""
                                                                                                                                                          :extension_attributes {}
                                                                                                                                                          :is_customer_notified 0
                                                                                                                                                          :is_visible_on_front 0
                                                                                                                                                          :parent_id 0
                                                                                                                                                          :status ""}]
                                                                                                                                      :store_currency_code ""
                                                                                                                                      :store_id 0
                                                                                                                                      :store_name ""
                                                                                                                                      :store_to_base_rate ""
                                                                                                                                      :store_to_order_rate ""
                                                                                                                                      :subtotal ""
                                                                                                                                      :subtotal_canceled ""
                                                                                                                                      :subtotal_incl_tax ""
                                                                                                                                      :subtotal_invoiced ""
                                                                                                                                      :subtotal_refunded ""
                                                                                                                                      :tax_amount ""
                                                                                                                                      :tax_canceled ""
                                                                                                                                      :tax_invoiced ""
                                                                                                                                      :tax_refunded ""
                                                                                                                                      :total_canceled ""
                                                                                                                                      :total_due ""
                                                                                                                                      :total_invoiced ""
                                                                                                                                      :total_item_count 0
                                                                                                                                      :total_offline_refunded ""
                                                                                                                                      :total_online_refunded ""
                                                                                                                                      :total_paid ""
                                                                                                                                      :total_qty_ordered ""
                                                                                                                                      :total_refunded ""
                                                                                                                                      :updated_at ""
                                                                                                                                      :weight ""
                                                                                                                                      :x_forwarded_for ""}
                                                                                                       :vertex_tax_calculation_shipping_address {}}
                                                                                :global_currency_code ""
                                                                                :grand_total ""
                                                                                :increment_id ""
                                                                                :is_used_for_refund 0
                                                                                :items [{:additional_data ""
                                                                                         :base_cost ""
                                                                                         :base_discount_amount ""
                                                                                         :base_discount_tax_compensation_amount ""
                                                                                         :base_price ""
                                                                                         :base_price_incl_tax ""
                                                                                         :base_row_total ""
                                                                                         :base_row_total_incl_tax ""
                                                                                         :base_tax_amount ""
                                                                                         :description ""
                                                                                         :discount_amount ""
                                                                                         :discount_tax_compensation_amount ""
                                                                                         :entity_id 0
                                                                                         :extension_attributes {:invoice_text_codes []
                                                                                                                :tax_codes []
                                                                                                                :vertex_tax_codes []}
                                                                                         :name ""
                                                                                         :order_item_id 0
                                                                                         :parent_id 0
                                                                                         :price ""
                                                                                         :price_incl_tax ""
                                                                                         :product_id 0
                                                                                         :qty ""
                                                                                         :row_total ""
                                                                                         :row_total_incl_tax ""
                                                                                         :sku ""
                                                                                         :tax_amount ""}]
                                                                                :order_currency_code ""
                                                                                :order_id 0
                                                                                :shipping_address_id 0
                                                                                :shipping_amount ""
                                                                                :shipping_discount_tax_compensation_amount ""
                                                                                :shipping_incl_tax ""
                                                                                :shipping_tax_amount ""
                                                                                :state 0
                                                                                :store_currency_code ""
                                                                                :store_id 0
                                                                                :store_to_base_rate ""
                                                                                :store_to_order_rate ""
                                                                                :subtotal ""
                                                                                :subtotal_incl_tax ""
                                                                                :tax_amount ""
                                                                                :total_qty ""
                                                                                :transaction_id ""
                                                                                :updated_at ""}}})
require "http/client"

url = "{{baseUrl}}/V1/invoices/"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"entity\": {\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address_id\": 0,\n    \"can_void_flag\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"vertex_tax_calculation_billing_address\": {\n        \"address_type\": \"\",\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"customer_address_id\": 0,\n        \"customer_id\": 0,\n        \"email\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"checkout_fields\": [\n            {\n              \"attribute_code\": \"\",\n              \"value\": \"\"\n            }\n          ]\n        },\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"parent_id\": 0,\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": \"\",\n        \"region_code\": \"\",\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\",\n        \"vat_is_valid\": 0,\n        \"vat_request_date\": \"\",\n        \"vat_request_id\": \"\",\n        \"vat_request_success\": 0\n      },\n      \"vertex_tax_calculation_order\": {\n        \"adjustment_negative\": \"\",\n        \"adjustment_positive\": \"\",\n        \"applied_rule_ids\": \"\",\n        \"base_adjustment_negative\": \"\",\n        \"base_adjustment_positive\": \"\",\n        \"base_currency_code\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_canceled\": \"\",\n        \"base_discount_invoiced\": \"\",\n        \"base_discount_refunded\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_discount_tax_compensation_invoiced\": \"\",\n        \"base_discount_tax_compensation_refunded\": \"\",\n        \"base_grand_total\": \"\",\n        \"base_shipping_amount\": \"\",\n        \"base_shipping_canceled\": \"\",\n        \"base_shipping_discount_amount\": \"\",\n        \"base_shipping_discount_tax_compensation_amnt\": \"\",\n        \"base_shipping_incl_tax\": \"\",\n        \"base_shipping_invoiced\": \"\",\n        \"base_shipping_refunded\": \"\",\n        \"base_shipping_tax_amount\": \"\",\n        \"base_shipping_tax_refunded\": \"\",\n        \"base_subtotal\": \"\",\n        \"base_subtotal_canceled\": \"\",\n        \"base_subtotal_incl_tax\": \"\",\n        \"base_subtotal_invoiced\": \"\",\n        \"base_subtotal_refunded\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_tax_canceled\": \"\",\n        \"base_tax_invoiced\": \"\",\n        \"base_tax_refunded\": \"\",\n        \"base_to_global_rate\": \"\",\n        \"base_to_order_rate\": \"\",\n        \"base_total_canceled\": \"\",\n        \"base_total_due\": \"\",\n        \"base_total_invoiced\": \"\",\n        \"base_total_invoiced_cost\": \"\",\n        \"base_total_offline_refunded\": \"\",\n        \"base_total_online_refunded\": \"\",\n        \"base_total_paid\": \"\",\n        \"base_total_qty_ordered\": \"\",\n        \"base_total_refunded\": \"\",\n        \"billing_address\": {},\n        \"billing_address_id\": 0,\n        \"can_ship_partially\": 0,\n        \"can_ship_partially_item\": 0,\n        \"coupon_code\": \"\",\n        \"created_at\": \"\",\n        \"customer_dob\": \"\",\n        \"customer_email\": \"\",\n        \"customer_firstname\": \"\",\n        \"customer_gender\": 0,\n        \"customer_group_id\": 0,\n        \"customer_id\": 0,\n        \"customer_is_guest\": 0,\n        \"customer_lastname\": \"\",\n        \"customer_middlename\": \"\",\n        \"customer_note\": \"\",\n        \"customer_note_notify\": 0,\n        \"customer_prefix\": \"\",\n        \"customer_suffix\": \"\",\n        \"customer_taxvat\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_canceled\": \"\",\n        \"discount_description\": \"\",\n        \"discount_invoiced\": \"\",\n        \"discount_refunded\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"discount_tax_compensation_invoiced\": \"\",\n        \"discount_tax_compensation_refunded\": \"\",\n        \"edit_increment\": 0,\n        \"email_sent\": 0,\n        \"entity_id\": 0,\n        \"ext_customer_id\": \"\",\n        \"ext_order_id\": \"\",\n        \"extension_attributes\": {\n          \"amazon_order_reference_id\": \"\",\n          \"applied_taxes\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"extension_attributes\": {\n                \"rates\": [\n                  {\n                    \"code\": \"\",\n                    \"extension_attributes\": {},\n                    \"percent\": \"\",\n                    \"title\": \"\"\n                  }\n                ]\n              },\n              \"percent\": \"\",\n              \"title\": \"\"\n            }\n          ],\n          \"base_customer_balance_amount\": \"\",\n          \"base_customer_balance_invoiced\": \"\",\n          \"base_customer_balance_refunded\": \"\",\n          \"base_customer_balance_total_refunded\": \"\",\n          \"base_gift_cards_amount\": \"\",\n          \"base_gift_cards_invoiced\": \"\",\n          \"base_gift_cards_refunded\": \"\",\n          \"base_reward_currency_amount\": \"\",\n          \"company_order_attributes\": {\n            \"company_id\": 0,\n            \"company_name\": \"\",\n            \"extension_attributes\": {},\n            \"order_id\": 0\n          },\n          \"converting_from_quote\": false,\n          \"customer_balance_amount\": \"\",\n          \"customer_balance_invoiced\": \"\",\n          \"customer_balance_refunded\": \"\",\n          \"customer_balance_total_refunded\": \"\",\n          \"gift_cards\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"id\": 0\n            }\n          ],\n          \"gift_cards_amount\": \"\",\n          \"gift_cards_invoiced\": \"\",\n          \"gift_cards_refunded\": \"\",\n          \"gift_message\": {\n            \"customer_id\": 0,\n            \"extension_attributes\": {\n              \"entity_id\": \"\",\n              \"entity_type\": \"\",\n              \"wrapping_add_printed_card\": false,\n              \"wrapping_allow_gift_receipt\": false,\n              \"wrapping_id\": 0\n            },\n            \"gift_message_id\": 0,\n            \"message\": \"\",\n            \"recipient\": \"\",\n            \"sender\": \"\"\n          },\n          \"gw_add_card\": \"\",\n          \"gw_allow_gift_receipt\": \"\",\n          \"gw_base_price\": \"\",\n          \"gw_base_price_incl_tax\": \"\",\n          \"gw_base_price_invoiced\": \"\",\n          \"gw_base_price_refunded\": \"\",\n          \"gw_base_tax_amount\": \"\",\n          \"gw_base_tax_amount_invoiced\": \"\",\n          \"gw_base_tax_amount_refunded\": \"\",\n          \"gw_card_base_price\": \"\",\n          \"gw_card_base_price_incl_tax\": \"\",\n          \"gw_card_base_price_invoiced\": \"\",\n          \"gw_card_base_price_refunded\": \"\",\n          \"gw_card_base_tax_amount\": \"\",\n          \"gw_card_base_tax_invoiced\": \"\",\n          \"gw_card_base_tax_refunded\": \"\",\n          \"gw_card_price\": \"\",\n          \"gw_card_price_incl_tax\": \"\",\n          \"gw_card_price_invoiced\": \"\",\n          \"gw_card_price_refunded\": \"\",\n          \"gw_card_tax_amount\": \"\",\n          \"gw_card_tax_invoiced\": \"\",\n          \"gw_card_tax_refunded\": \"\",\n          \"gw_id\": \"\",\n          \"gw_items_base_price\": \"\",\n          \"gw_items_base_price_incl_tax\": \"\",\n          \"gw_items_base_price_invoiced\": \"\",\n          \"gw_items_base_price_refunded\": \"\",\n          \"gw_items_base_tax_amount\": \"\",\n          \"gw_items_base_tax_invoiced\": \"\",\n          \"gw_items_base_tax_refunded\": \"\",\n          \"gw_items_price\": \"\",\n          \"gw_items_price_incl_tax\": \"\",\n          \"gw_items_price_invoiced\": \"\",\n          \"gw_items_price_refunded\": \"\",\n          \"gw_items_tax_amount\": \"\",\n          \"gw_items_tax_invoiced\": \"\",\n          \"gw_items_tax_refunded\": \"\",\n          \"gw_price\": \"\",\n          \"gw_price_incl_tax\": \"\",\n          \"gw_price_invoiced\": \"\",\n          \"gw_price_refunded\": \"\",\n          \"gw_tax_amount\": \"\",\n          \"gw_tax_amount_invoiced\": \"\",\n          \"gw_tax_amount_refunded\": \"\",\n          \"item_applied_taxes\": [\n            {\n              \"applied_taxes\": [\n                {}\n              ],\n              \"associated_item_id\": 0,\n              \"extension_attributes\": {},\n              \"item_id\": 0,\n              \"type\": \"\"\n            }\n          ],\n          \"payment_additional_info\": [\n            {\n              \"key\": \"\",\n              \"value\": \"\"\n            }\n          ],\n          \"reward_currency_amount\": \"\",\n          \"reward_points_balance\": 0,\n          \"shipping_assignments\": [\n            {\n              \"extension_attributes\": {},\n              \"items\": [\n                {\n                  \"additional_data\": \"\",\n                  \"amount_refunded\": \"\",\n                  \"applied_rule_ids\": \"\",\n                  \"base_amount_refunded\": \"\",\n                  \"base_cost\": \"\",\n                  \"base_discount_amount\": \"\",\n                  \"base_discount_invoiced\": \"\",\n                  \"base_discount_refunded\": \"\",\n                  \"base_discount_tax_compensation_amount\": \"\",\n                  \"base_discount_tax_compensation_invoiced\": \"\",\n                  \"base_discount_tax_compensation_refunded\": \"\",\n                  \"base_original_price\": \"\",\n                  \"base_price\": \"\",\n                  \"base_price_incl_tax\": \"\",\n                  \"base_row_invoiced\": \"\",\n                  \"base_row_total\": \"\",\n                  \"base_row_total_incl_tax\": \"\",\n                  \"base_tax_amount\": \"\",\n                  \"base_tax_before_discount\": \"\",\n                  \"base_tax_invoiced\": \"\",\n                  \"base_tax_refunded\": \"\",\n                  \"base_weee_tax_applied_amount\": \"\",\n                  \"base_weee_tax_applied_row_amnt\": \"\",\n                  \"base_weee_tax_disposition\": \"\",\n                  \"base_weee_tax_row_disposition\": \"\",\n                  \"created_at\": \"\",\n                  \"description\": \"\",\n                  \"discount_amount\": \"\",\n                  \"discount_invoiced\": \"\",\n                  \"discount_percent\": \"\",\n                  \"discount_refunded\": \"\",\n                  \"discount_tax_compensation_amount\": \"\",\n                  \"discount_tax_compensation_canceled\": \"\",\n                  \"discount_tax_compensation_invoiced\": \"\",\n                  \"discount_tax_compensation_refunded\": \"\",\n                  \"event_id\": 0,\n                  \"ext_order_item_id\": \"\",\n                  \"extension_attributes\": {\n                    \"gift_message\": {},\n                    \"gw_base_price\": \"\",\n                    \"gw_base_price_invoiced\": \"\",\n                    \"gw_base_price_refunded\": \"\",\n                    \"gw_base_tax_amount\": \"\",\n                    \"gw_base_tax_amount_invoiced\": \"\",\n                    \"gw_base_tax_amount_refunded\": \"\",\n                    \"gw_id\": \"\",\n                    \"gw_price\": \"\",\n                    \"gw_price_invoiced\": \"\",\n                    \"gw_price_refunded\": \"\",\n                    \"gw_tax_amount\": \"\",\n                    \"gw_tax_amount_invoiced\": \"\",\n                    \"gw_tax_amount_refunded\": \"\",\n                    \"invoice_text_codes\": [],\n                    \"tax_codes\": [],\n                    \"vertex_tax_codes\": []\n                  },\n                  \"free_shipping\": 0,\n                  \"gw_base_price\": \"\",\n                  \"gw_base_price_invoiced\": \"\",\n                  \"gw_base_price_refunded\": \"\",\n                  \"gw_base_tax_amount\": \"\",\n                  \"gw_base_tax_amount_invoiced\": \"\",\n                  \"gw_base_tax_amount_refunded\": \"\",\n                  \"gw_id\": 0,\n                  \"gw_price\": \"\",\n                  \"gw_price_invoiced\": \"\",\n                  \"gw_price_refunded\": \"\",\n                  \"gw_tax_amount\": \"\",\n                  \"gw_tax_amount_invoiced\": \"\",\n                  \"gw_tax_amount_refunded\": \"\",\n                  \"is_qty_decimal\": 0,\n                  \"is_virtual\": 0,\n                  \"item_id\": 0,\n                  \"locked_do_invoice\": 0,\n                  \"locked_do_ship\": 0,\n                  \"name\": \"\",\n                  \"no_discount\": 0,\n                  \"order_id\": 0,\n                  \"original_price\": \"\",\n                  \"parent_item\": \"\",\n                  \"parent_item_id\": 0,\n                  \"price\": \"\",\n                  \"price_incl_tax\": \"\",\n                  \"product_id\": 0,\n                  \"product_option\": {\n                    \"extension_attributes\": {\n                      \"bundle_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": 0,\n                          \"option_qty\": 0,\n                          \"option_selections\": []\n                        }\n                      ],\n                      \"configurable_item_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": \"\",\n                          \"option_value\": 0\n                        }\n                      ],\n                      \"custom_options\": [\n                        {\n                          \"extension_attributes\": {\n                            \"file_info\": {\n                              \"base64_encoded_data\": \"\",\n                              \"name\": \"\",\n                              \"type\": \"\"\n                            }\n                          },\n                          \"option_id\": \"\",\n                          \"option_value\": \"\"\n                        }\n                      ],\n                      \"downloadable_option\": {\n                        \"downloadable_links\": []\n                      },\n                      \"giftcard_item_option\": {\n                        \"custom_giftcard_amount\": \"\",\n                        \"extension_attributes\": {},\n                        \"giftcard_amount\": \"\",\n                        \"giftcard_message\": \"\",\n                        \"giftcard_recipient_email\": \"\",\n                        \"giftcard_recipient_name\": \"\",\n                        \"giftcard_sender_email\": \"\",\n                        \"giftcard_sender_name\": \"\"\n                      }\n                    }\n                  },\n                  \"product_type\": \"\",\n                  \"qty_backordered\": \"\",\n                  \"qty_canceled\": \"\",\n                  \"qty_invoiced\": \"\",\n                  \"qty_ordered\": \"\",\n                  \"qty_refunded\": \"\",\n                  \"qty_returned\": \"\",\n                  \"qty_shipped\": \"\",\n                  \"quote_item_id\": 0,\n                  \"row_invoiced\": \"\",\n                  \"row_total\": \"\",\n                  \"row_total_incl_tax\": \"\",\n                  \"row_weight\": \"\",\n                  \"sku\": \"\",\n                  \"store_id\": 0,\n                  \"tax_amount\": \"\",\n                  \"tax_before_discount\": \"\",\n                  \"tax_canceled\": \"\",\n                  \"tax_invoiced\": \"\",\n                  \"tax_percent\": \"\",\n                  \"tax_refunded\": \"\",\n                  \"updated_at\": \"\",\n                  \"weee_tax_applied\": \"\",\n                  \"weee_tax_applied_amount\": \"\",\n                  \"weee_tax_applied_row_amount\": \"\",\n                  \"weee_tax_disposition\": \"\",\n                  \"weee_tax_row_disposition\": \"\",\n                  \"weight\": \"\"\n                }\n              ],\n              \"shipping\": {\n                \"address\": {},\n                \"extension_attributes\": {\n                  \"collection_point\": {\n                    \"city\": \"\",\n                    \"collection_point_id\": \"\",\n                    \"country\": \"\",\n                    \"name\": \"\",\n                    \"postcode\": \"\",\n                    \"recipient_address_id\": 0,\n                    \"region\": \"\",\n                    \"street\": []\n                  },\n                  \"ext_order_id\": \"\",\n                  \"shipping_experience\": {\n                    \"code\": \"\",\n                    \"cost\": \"\",\n                    \"label\": \"\"\n                  }\n                },\n                \"method\": \"\",\n                \"total\": {\n                  \"base_shipping_amount\": \"\",\n                  \"base_shipping_canceled\": \"\",\n                  \"base_shipping_discount_amount\": \"\",\n                  \"base_shipping_discount_tax_compensation_amnt\": \"\",\n                  \"base_shipping_incl_tax\": \"\",\n                  \"base_shipping_invoiced\": \"\",\n                  \"base_shipping_refunded\": \"\",\n                  \"base_shipping_tax_amount\": \"\",\n                  \"base_shipping_tax_refunded\": \"\",\n                  \"extension_attributes\": {},\n                  \"shipping_amount\": \"\",\n                  \"shipping_canceled\": \"\",\n                  \"shipping_discount_amount\": \"\",\n                  \"shipping_discount_tax_compensation_amount\": \"\",\n                  \"shipping_incl_tax\": \"\",\n                  \"shipping_invoiced\": \"\",\n                  \"shipping_refunded\": \"\",\n                  \"shipping_tax_amount\": \"\",\n                  \"shipping_tax_refunded\": \"\"\n                }\n              },\n              \"stock_id\": 0\n            }\n          ]\n        },\n        \"forced_shipment_with_invoice\": 0,\n        \"global_currency_code\": \"\",\n        \"grand_total\": \"\",\n        \"hold_before_state\": \"\",\n        \"hold_before_status\": \"\",\n        \"increment_id\": \"\",\n        \"is_virtual\": 0,\n        \"items\": [\n          {}\n        ],\n        \"order_currency_code\": \"\",\n        \"original_increment_id\": \"\",\n        \"payment\": {\n          \"account_status\": \"\",\n          \"additional_data\": \"\",\n          \"additional_information\": [],\n          \"address_status\": \"\",\n          \"amount_authorized\": \"\",\n          \"amount_canceled\": \"\",\n          \"amount_ordered\": \"\",\n          \"amount_paid\": \"\",\n          \"amount_refunded\": \"\",\n          \"anet_trans_method\": \"\",\n          \"base_amount_authorized\": \"\",\n          \"base_amount_canceled\": \"\",\n          \"base_amount_ordered\": \"\",\n          \"base_amount_paid\": \"\",\n          \"base_amount_paid_online\": \"\",\n          \"base_amount_refunded\": \"\",\n          \"base_amount_refunded_online\": \"\",\n          \"base_shipping_amount\": \"\",\n          \"base_shipping_captured\": \"\",\n          \"base_shipping_refunded\": \"\",\n          \"cc_approval\": \"\",\n          \"cc_avs_status\": \"\",\n          \"cc_cid_status\": \"\",\n          \"cc_debug_request_body\": \"\",\n          \"cc_debug_response_body\": \"\",\n          \"cc_debug_response_serialized\": \"\",\n          \"cc_exp_month\": \"\",\n          \"cc_exp_year\": \"\",\n          \"cc_last4\": \"\",\n          \"cc_number_enc\": \"\",\n          \"cc_owner\": \"\",\n          \"cc_secure_verify\": \"\",\n          \"cc_ss_issue\": \"\",\n          \"cc_ss_start_month\": \"\",\n          \"cc_ss_start_year\": \"\",\n          \"cc_status\": \"\",\n          \"cc_status_description\": \"\",\n          \"cc_trans_id\": \"\",\n          \"cc_type\": \"\",\n          \"echeck_account_name\": \"\",\n          \"echeck_account_type\": \"\",\n          \"echeck_bank_name\": \"\",\n          \"echeck_routing_number\": \"\",\n          \"echeck_type\": \"\",\n          \"entity_id\": 0,\n          \"extension_attributes\": {\n            \"vault_payment_token\": {\n              \"created_at\": \"\",\n              \"customer_id\": 0,\n              \"entity_id\": 0,\n              \"expires_at\": \"\",\n              \"gateway_token\": \"\",\n              \"is_active\": false,\n              \"is_visible\": false,\n              \"payment_method_code\": \"\",\n              \"public_hash\": \"\",\n              \"token_details\": \"\",\n              \"type\": \"\"\n            }\n          },\n          \"last_trans_id\": \"\",\n          \"method\": \"\",\n          \"parent_id\": 0,\n          \"po_number\": \"\",\n          \"protection_eligibility\": \"\",\n          \"quote_payment_id\": 0,\n          \"shipping_amount\": \"\",\n          \"shipping_captured\": \"\",\n          \"shipping_refunded\": \"\"\n        },\n        \"payment_auth_expiration\": 0,\n        \"payment_authorization_amount\": \"\",\n        \"protect_code\": \"\",\n        \"quote_address_id\": 0,\n        \"quote_id\": 0,\n        \"relation_child_id\": \"\",\n        \"relation_child_real_id\": \"\",\n        \"relation_parent_id\": \"\",\n        \"relation_parent_real_id\": \"\",\n        \"remote_ip\": \"\",\n        \"shipping_amount\": \"\",\n        \"shipping_canceled\": \"\",\n        \"shipping_description\": \"\",\n        \"shipping_discount_amount\": \"\",\n        \"shipping_discount_tax_compensation_amount\": \"\",\n        \"shipping_incl_tax\": \"\",\n        \"shipping_invoiced\": \"\",\n        \"shipping_refunded\": \"\",\n        \"shipping_tax_amount\": \"\",\n        \"shipping_tax_refunded\": \"\",\n        \"state\": \"\",\n        \"status\": \"\",\n        \"status_histories\": [\n          {\n            \"comment\": \"\",\n            \"created_at\": \"\",\n            \"entity_id\": 0,\n            \"entity_name\": \"\",\n            \"extension_attributes\": {},\n            \"is_customer_notified\": 0,\n            \"is_visible_on_front\": 0,\n            \"parent_id\": 0,\n            \"status\": \"\"\n          }\n        ],\n        \"store_currency_code\": \"\",\n        \"store_id\": 0,\n        \"store_name\": \"\",\n        \"store_to_base_rate\": \"\",\n        \"store_to_order_rate\": \"\",\n        \"subtotal\": \"\",\n        \"subtotal_canceled\": \"\",\n        \"subtotal_incl_tax\": \"\",\n        \"subtotal_invoiced\": \"\",\n        \"subtotal_refunded\": \"\",\n        \"tax_amount\": \"\",\n        \"tax_canceled\": \"\",\n        \"tax_invoiced\": \"\",\n        \"tax_refunded\": \"\",\n        \"total_canceled\": \"\",\n        \"total_due\": \"\",\n        \"total_invoiced\": \"\",\n        \"total_item_count\": 0,\n        \"total_offline_refunded\": \"\",\n        \"total_online_refunded\": \"\",\n        \"total_paid\": \"\",\n        \"total_qty_ordered\": \"\",\n        \"total_refunded\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\",\n        \"x_forwarded_for\": \"\"\n      },\n      \"vertex_tax_calculation_shipping_address\": {}\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"is_used_for_refund\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"total_qty\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\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}}/V1/invoices/"),
    Content = new StringContent("{\n  \"entity\": {\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address_id\": 0,\n    \"can_void_flag\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"vertex_tax_calculation_billing_address\": {\n        \"address_type\": \"\",\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"customer_address_id\": 0,\n        \"customer_id\": 0,\n        \"email\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"checkout_fields\": [\n            {\n              \"attribute_code\": \"\",\n              \"value\": \"\"\n            }\n          ]\n        },\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"parent_id\": 0,\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": \"\",\n        \"region_code\": \"\",\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\",\n        \"vat_is_valid\": 0,\n        \"vat_request_date\": \"\",\n        \"vat_request_id\": \"\",\n        \"vat_request_success\": 0\n      },\n      \"vertex_tax_calculation_order\": {\n        \"adjustment_negative\": \"\",\n        \"adjustment_positive\": \"\",\n        \"applied_rule_ids\": \"\",\n        \"base_adjustment_negative\": \"\",\n        \"base_adjustment_positive\": \"\",\n        \"base_currency_code\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_canceled\": \"\",\n        \"base_discount_invoiced\": \"\",\n        \"base_discount_refunded\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_discount_tax_compensation_invoiced\": \"\",\n        \"base_discount_tax_compensation_refunded\": \"\",\n        \"base_grand_total\": \"\",\n        \"base_shipping_amount\": \"\",\n        \"base_shipping_canceled\": \"\",\n        \"base_shipping_discount_amount\": \"\",\n        \"base_shipping_discount_tax_compensation_amnt\": \"\",\n        \"base_shipping_incl_tax\": \"\",\n        \"base_shipping_invoiced\": \"\",\n        \"base_shipping_refunded\": \"\",\n        \"base_shipping_tax_amount\": \"\",\n        \"base_shipping_tax_refunded\": \"\",\n        \"base_subtotal\": \"\",\n        \"base_subtotal_canceled\": \"\",\n        \"base_subtotal_incl_tax\": \"\",\n        \"base_subtotal_invoiced\": \"\",\n        \"base_subtotal_refunded\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_tax_canceled\": \"\",\n        \"base_tax_invoiced\": \"\",\n        \"base_tax_refunded\": \"\",\n        \"base_to_global_rate\": \"\",\n        \"base_to_order_rate\": \"\",\n        \"base_total_canceled\": \"\",\n        \"base_total_due\": \"\",\n        \"base_total_invoiced\": \"\",\n        \"base_total_invoiced_cost\": \"\",\n        \"base_total_offline_refunded\": \"\",\n        \"base_total_online_refunded\": \"\",\n        \"base_total_paid\": \"\",\n        \"base_total_qty_ordered\": \"\",\n        \"base_total_refunded\": \"\",\n        \"billing_address\": {},\n        \"billing_address_id\": 0,\n        \"can_ship_partially\": 0,\n        \"can_ship_partially_item\": 0,\n        \"coupon_code\": \"\",\n        \"created_at\": \"\",\n        \"customer_dob\": \"\",\n        \"customer_email\": \"\",\n        \"customer_firstname\": \"\",\n        \"customer_gender\": 0,\n        \"customer_group_id\": 0,\n        \"customer_id\": 0,\n        \"customer_is_guest\": 0,\n        \"customer_lastname\": \"\",\n        \"customer_middlename\": \"\",\n        \"customer_note\": \"\",\n        \"customer_note_notify\": 0,\n        \"customer_prefix\": \"\",\n        \"customer_suffix\": \"\",\n        \"customer_taxvat\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_canceled\": \"\",\n        \"discount_description\": \"\",\n        \"discount_invoiced\": \"\",\n        \"discount_refunded\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"discount_tax_compensation_invoiced\": \"\",\n        \"discount_tax_compensation_refunded\": \"\",\n        \"edit_increment\": 0,\n        \"email_sent\": 0,\n        \"entity_id\": 0,\n        \"ext_customer_id\": \"\",\n        \"ext_order_id\": \"\",\n        \"extension_attributes\": {\n          \"amazon_order_reference_id\": \"\",\n          \"applied_taxes\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"extension_attributes\": {\n                \"rates\": [\n                  {\n                    \"code\": \"\",\n                    \"extension_attributes\": {},\n                    \"percent\": \"\",\n                    \"title\": \"\"\n                  }\n                ]\n              },\n              \"percent\": \"\",\n              \"title\": \"\"\n            }\n          ],\n          \"base_customer_balance_amount\": \"\",\n          \"base_customer_balance_invoiced\": \"\",\n          \"base_customer_balance_refunded\": \"\",\n          \"base_customer_balance_total_refunded\": \"\",\n          \"base_gift_cards_amount\": \"\",\n          \"base_gift_cards_invoiced\": \"\",\n          \"base_gift_cards_refunded\": \"\",\n          \"base_reward_currency_amount\": \"\",\n          \"company_order_attributes\": {\n            \"company_id\": 0,\n            \"company_name\": \"\",\n            \"extension_attributes\": {},\n            \"order_id\": 0\n          },\n          \"converting_from_quote\": false,\n          \"customer_balance_amount\": \"\",\n          \"customer_balance_invoiced\": \"\",\n          \"customer_balance_refunded\": \"\",\n          \"customer_balance_total_refunded\": \"\",\n          \"gift_cards\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"id\": 0\n            }\n          ],\n          \"gift_cards_amount\": \"\",\n          \"gift_cards_invoiced\": \"\",\n          \"gift_cards_refunded\": \"\",\n          \"gift_message\": {\n            \"customer_id\": 0,\n            \"extension_attributes\": {\n              \"entity_id\": \"\",\n              \"entity_type\": \"\",\n              \"wrapping_add_printed_card\": false,\n              \"wrapping_allow_gift_receipt\": false,\n              \"wrapping_id\": 0\n            },\n            \"gift_message_id\": 0,\n            \"message\": \"\",\n            \"recipient\": \"\",\n            \"sender\": \"\"\n          },\n          \"gw_add_card\": \"\",\n          \"gw_allow_gift_receipt\": \"\",\n          \"gw_base_price\": \"\",\n          \"gw_base_price_incl_tax\": \"\",\n          \"gw_base_price_invoiced\": \"\",\n          \"gw_base_price_refunded\": \"\",\n          \"gw_base_tax_amount\": \"\",\n          \"gw_base_tax_amount_invoiced\": \"\",\n          \"gw_base_tax_amount_refunded\": \"\",\n          \"gw_card_base_price\": \"\",\n          \"gw_card_base_price_incl_tax\": \"\",\n          \"gw_card_base_price_invoiced\": \"\",\n          \"gw_card_base_price_refunded\": \"\",\n          \"gw_card_base_tax_amount\": \"\",\n          \"gw_card_base_tax_invoiced\": \"\",\n          \"gw_card_base_tax_refunded\": \"\",\n          \"gw_card_price\": \"\",\n          \"gw_card_price_incl_tax\": \"\",\n          \"gw_card_price_invoiced\": \"\",\n          \"gw_card_price_refunded\": \"\",\n          \"gw_card_tax_amount\": \"\",\n          \"gw_card_tax_invoiced\": \"\",\n          \"gw_card_tax_refunded\": \"\",\n          \"gw_id\": \"\",\n          \"gw_items_base_price\": \"\",\n          \"gw_items_base_price_incl_tax\": \"\",\n          \"gw_items_base_price_invoiced\": \"\",\n          \"gw_items_base_price_refunded\": \"\",\n          \"gw_items_base_tax_amount\": \"\",\n          \"gw_items_base_tax_invoiced\": \"\",\n          \"gw_items_base_tax_refunded\": \"\",\n          \"gw_items_price\": \"\",\n          \"gw_items_price_incl_tax\": \"\",\n          \"gw_items_price_invoiced\": \"\",\n          \"gw_items_price_refunded\": \"\",\n          \"gw_items_tax_amount\": \"\",\n          \"gw_items_tax_invoiced\": \"\",\n          \"gw_items_tax_refunded\": \"\",\n          \"gw_price\": \"\",\n          \"gw_price_incl_tax\": \"\",\n          \"gw_price_invoiced\": \"\",\n          \"gw_price_refunded\": \"\",\n          \"gw_tax_amount\": \"\",\n          \"gw_tax_amount_invoiced\": \"\",\n          \"gw_tax_amount_refunded\": \"\",\n          \"item_applied_taxes\": [\n            {\n              \"applied_taxes\": [\n                {}\n              ],\n              \"associated_item_id\": 0,\n              \"extension_attributes\": {},\n              \"item_id\": 0,\n              \"type\": \"\"\n            }\n          ],\n          \"payment_additional_info\": [\n            {\n              \"key\": \"\",\n              \"value\": \"\"\n            }\n          ],\n          \"reward_currency_amount\": \"\",\n          \"reward_points_balance\": 0,\n          \"shipping_assignments\": [\n            {\n              \"extension_attributes\": {},\n              \"items\": [\n                {\n                  \"additional_data\": \"\",\n                  \"amount_refunded\": \"\",\n                  \"applied_rule_ids\": \"\",\n                  \"base_amount_refunded\": \"\",\n                  \"base_cost\": \"\",\n                  \"base_discount_amount\": \"\",\n                  \"base_discount_invoiced\": \"\",\n                  \"base_discount_refunded\": \"\",\n                  \"base_discount_tax_compensation_amount\": \"\",\n                  \"base_discount_tax_compensation_invoiced\": \"\",\n                  \"base_discount_tax_compensation_refunded\": \"\",\n                  \"base_original_price\": \"\",\n                  \"base_price\": \"\",\n                  \"base_price_incl_tax\": \"\",\n                  \"base_row_invoiced\": \"\",\n                  \"base_row_total\": \"\",\n                  \"base_row_total_incl_tax\": \"\",\n                  \"base_tax_amount\": \"\",\n                  \"base_tax_before_discount\": \"\",\n                  \"base_tax_invoiced\": \"\",\n                  \"base_tax_refunded\": \"\",\n                  \"base_weee_tax_applied_amount\": \"\",\n                  \"base_weee_tax_applied_row_amnt\": \"\",\n                  \"base_weee_tax_disposition\": \"\",\n                  \"base_weee_tax_row_disposition\": \"\",\n                  \"created_at\": \"\",\n                  \"description\": \"\",\n                  \"discount_amount\": \"\",\n                  \"discount_invoiced\": \"\",\n                  \"discount_percent\": \"\",\n                  \"discount_refunded\": \"\",\n                  \"discount_tax_compensation_amount\": \"\",\n                  \"discount_tax_compensation_canceled\": \"\",\n                  \"discount_tax_compensation_invoiced\": \"\",\n                  \"discount_tax_compensation_refunded\": \"\",\n                  \"event_id\": 0,\n                  \"ext_order_item_id\": \"\",\n                  \"extension_attributes\": {\n                    \"gift_message\": {},\n                    \"gw_base_price\": \"\",\n                    \"gw_base_price_invoiced\": \"\",\n                    \"gw_base_price_refunded\": \"\",\n                    \"gw_base_tax_amount\": \"\",\n                    \"gw_base_tax_amount_invoiced\": \"\",\n                    \"gw_base_tax_amount_refunded\": \"\",\n                    \"gw_id\": \"\",\n                    \"gw_price\": \"\",\n                    \"gw_price_invoiced\": \"\",\n                    \"gw_price_refunded\": \"\",\n                    \"gw_tax_amount\": \"\",\n                    \"gw_tax_amount_invoiced\": \"\",\n                    \"gw_tax_amount_refunded\": \"\",\n                    \"invoice_text_codes\": [],\n                    \"tax_codes\": [],\n                    \"vertex_tax_codes\": []\n                  },\n                  \"free_shipping\": 0,\n                  \"gw_base_price\": \"\",\n                  \"gw_base_price_invoiced\": \"\",\n                  \"gw_base_price_refunded\": \"\",\n                  \"gw_base_tax_amount\": \"\",\n                  \"gw_base_tax_amount_invoiced\": \"\",\n                  \"gw_base_tax_amount_refunded\": \"\",\n                  \"gw_id\": 0,\n                  \"gw_price\": \"\",\n                  \"gw_price_invoiced\": \"\",\n                  \"gw_price_refunded\": \"\",\n                  \"gw_tax_amount\": \"\",\n                  \"gw_tax_amount_invoiced\": \"\",\n                  \"gw_tax_amount_refunded\": \"\",\n                  \"is_qty_decimal\": 0,\n                  \"is_virtual\": 0,\n                  \"item_id\": 0,\n                  \"locked_do_invoice\": 0,\n                  \"locked_do_ship\": 0,\n                  \"name\": \"\",\n                  \"no_discount\": 0,\n                  \"order_id\": 0,\n                  \"original_price\": \"\",\n                  \"parent_item\": \"\",\n                  \"parent_item_id\": 0,\n                  \"price\": \"\",\n                  \"price_incl_tax\": \"\",\n                  \"product_id\": 0,\n                  \"product_option\": {\n                    \"extension_attributes\": {\n                      \"bundle_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": 0,\n                          \"option_qty\": 0,\n                          \"option_selections\": []\n                        }\n                      ],\n                      \"configurable_item_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": \"\",\n                          \"option_value\": 0\n                        }\n                      ],\n                      \"custom_options\": [\n                        {\n                          \"extension_attributes\": {\n                            \"file_info\": {\n                              \"base64_encoded_data\": \"\",\n                              \"name\": \"\",\n                              \"type\": \"\"\n                            }\n                          },\n                          \"option_id\": \"\",\n                          \"option_value\": \"\"\n                        }\n                      ],\n                      \"downloadable_option\": {\n                        \"downloadable_links\": []\n                      },\n                      \"giftcard_item_option\": {\n                        \"custom_giftcard_amount\": \"\",\n                        \"extension_attributes\": {},\n                        \"giftcard_amount\": \"\",\n                        \"giftcard_message\": \"\",\n                        \"giftcard_recipient_email\": \"\",\n                        \"giftcard_recipient_name\": \"\",\n                        \"giftcard_sender_email\": \"\",\n                        \"giftcard_sender_name\": \"\"\n                      }\n                    }\n                  },\n                  \"product_type\": \"\",\n                  \"qty_backordered\": \"\",\n                  \"qty_canceled\": \"\",\n                  \"qty_invoiced\": \"\",\n                  \"qty_ordered\": \"\",\n                  \"qty_refunded\": \"\",\n                  \"qty_returned\": \"\",\n                  \"qty_shipped\": \"\",\n                  \"quote_item_id\": 0,\n                  \"row_invoiced\": \"\",\n                  \"row_total\": \"\",\n                  \"row_total_incl_tax\": \"\",\n                  \"row_weight\": \"\",\n                  \"sku\": \"\",\n                  \"store_id\": 0,\n                  \"tax_amount\": \"\",\n                  \"tax_before_discount\": \"\",\n                  \"tax_canceled\": \"\",\n                  \"tax_invoiced\": \"\",\n                  \"tax_percent\": \"\",\n                  \"tax_refunded\": \"\",\n                  \"updated_at\": \"\",\n                  \"weee_tax_applied\": \"\",\n                  \"weee_tax_applied_amount\": \"\",\n                  \"weee_tax_applied_row_amount\": \"\",\n                  \"weee_tax_disposition\": \"\",\n                  \"weee_tax_row_disposition\": \"\",\n                  \"weight\": \"\"\n                }\n              ],\n              \"shipping\": {\n                \"address\": {},\n                \"extension_attributes\": {\n                  \"collection_point\": {\n                    \"city\": \"\",\n                    \"collection_point_id\": \"\",\n                    \"country\": \"\",\n                    \"name\": \"\",\n                    \"postcode\": \"\",\n                    \"recipient_address_id\": 0,\n                    \"region\": \"\",\n                    \"street\": []\n                  },\n                  \"ext_order_id\": \"\",\n                  \"shipping_experience\": {\n                    \"code\": \"\",\n                    \"cost\": \"\",\n                    \"label\": \"\"\n                  }\n                },\n                \"method\": \"\",\n                \"total\": {\n                  \"base_shipping_amount\": \"\",\n                  \"base_shipping_canceled\": \"\",\n                  \"base_shipping_discount_amount\": \"\",\n                  \"base_shipping_discount_tax_compensation_amnt\": \"\",\n                  \"base_shipping_incl_tax\": \"\",\n                  \"base_shipping_invoiced\": \"\",\n                  \"base_shipping_refunded\": \"\",\n                  \"base_shipping_tax_amount\": \"\",\n                  \"base_shipping_tax_refunded\": \"\",\n                  \"extension_attributes\": {},\n                  \"shipping_amount\": \"\",\n                  \"shipping_canceled\": \"\",\n                  \"shipping_discount_amount\": \"\",\n                  \"shipping_discount_tax_compensation_amount\": \"\",\n                  \"shipping_incl_tax\": \"\",\n                  \"shipping_invoiced\": \"\",\n                  \"shipping_refunded\": \"\",\n                  \"shipping_tax_amount\": \"\",\n                  \"shipping_tax_refunded\": \"\"\n                }\n              },\n              \"stock_id\": 0\n            }\n          ]\n        },\n        \"forced_shipment_with_invoice\": 0,\n        \"global_currency_code\": \"\",\n        \"grand_total\": \"\",\n        \"hold_before_state\": \"\",\n        \"hold_before_status\": \"\",\n        \"increment_id\": \"\",\n        \"is_virtual\": 0,\n        \"items\": [\n          {}\n        ],\n        \"order_currency_code\": \"\",\n        \"original_increment_id\": \"\",\n        \"payment\": {\n          \"account_status\": \"\",\n          \"additional_data\": \"\",\n          \"additional_information\": [],\n          \"address_status\": \"\",\n          \"amount_authorized\": \"\",\n          \"amount_canceled\": \"\",\n          \"amount_ordered\": \"\",\n          \"amount_paid\": \"\",\n          \"amount_refunded\": \"\",\n          \"anet_trans_method\": \"\",\n          \"base_amount_authorized\": \"\",\n          \"base_amount_canceled\": \"\",\n          \"base_amount_ordered\": \"\",\n          \"base_amount_paid\": \"\",\n          \"base_amount_paid_online\": \"\",\n          \"base_amount_refunded\": \"\",\n          \"base_amount_refunded_online\": \"\",\n          \"base_shipping_amount\": \"\",\n          \"base_shipping_captured\": \"\",\n          \"base_shipping_refunded\": \"\",\n          \"cc_approval\": \"\",\n          \"cc_avs_status\": \"\",\n          \"cc_cid_status\": \"\",\n          \"cc_debug_request_body\": \"\",\n          \"cc_debug_response_body\": \"\",\n          \"cc_debug_response_serialized\": \"\",\n          \"cc_exp_month\": \"\",\n          \"cc_exp_year\": \"\",\n          \"cc_last4\": \"\",\n          \"cc_number_enc\": \"\",\n          \"cc_owner\": \"\",\n          \"cc_secure_verify\": \"\",\n          \"cc_ss_issue\": \"\",\n          \"cc_ss_start_month\": \"\",\n          \"cc_ss_start_year\": \"\",\n          \"cc_status\": \"\",\n          \"cc_status_description\": \"\",\n          \"cc_trans_id\": \"\",\n          \"cc_type\": \"\",\n          \"echeck_account_name\": \"\",\n          \"echeck_account_type\": \"\",\n          \"echeck_bank_name\": \"\",\n          \"echeck_routing_number\": \"\",\n          \"echeck_type\": \"\",\n          \"entity_id\": 0,\n          \"extension_attributes\": {\n            \"vault_payment_token\": {\n              \"created_at\": \"\",\n              \"customer_id\": 0,\n              \"entity_id\": 0,\n              \"expires_at\": \"\",\n              \"gateway_token\": \"\",\n              \"is_active\": false,\n              \"is_visible\": false,\n              \"payment_method_code\": \"\",\n              \"public_hash\": \"\",\n              \"token_details\": \"\",\n              \"type\": \"\"\n            }\n          },\n          \"last_trans_id\": \"\",\n          \"method\": \"\",\n          \"parent_id\": 0,\n          \"po_number\": \"\",\n          \"protection_eligibility\": \"\",\n          \"quote_payment_id\": 0,\n          \"shipping_amount\": \"\",\n          \"shipping_captured\": \"\",\n          \"shipping_refunded\": \"\"\n        },\n        \"payment_auth_expiration\": 0,\n        \"payment_authorization_amount\": \"\",\n        \"protect_code\": \"\",\n        \"quote_address_id\": 0,\n        \"quote_id\": 0,\n        \"relation_child_id\": \"\",\n        \"relation_child_real_id\": \"\",\n        \"relation_parent_id\": \"\",\n        \"relation_parent_real_id\": \"\",\n        \"remote_ip\": \"\",\n        \"shipping_amount\": \"\",\n        \"shipping_canceled\": \"\",\n        \"shipping_description\": \"\",\n        \"shipping_discount_amount\": \"\",\n        \"shipping_discount_tax_compensation_amount\": \"\",\n        \"shipping_incl_tax\": \"\",\n        \"shipping_invoiced\": \"\",\n        \"shipping_refunded\": \"\",\n        \"shipping_tax_amount\": \"\",\n        \"shipping_tax_refunded\": \"\",\n        \"state\": \"\",\n        \"status\": \"\",\n        \"status_histories\": [\n          {\n            \"comment\": \"\",\n            \"created_at\": \"\",\n            \"entity_id\": 0,\n            \"entity_name\": \"\",\n            \"extension_attributes\": {},\n            \"is_customer_notified\": 0,\n            \"is_visible_on_front\": 0,\n            \"parent_id\": 0,\n            \"status\": \"\"\n          }\n        ],\n        \"store_currency_code\": \"\",\n        \"store_id\": 0,\n        \"store_name\": \"\",\n        \"store_to_base_rate\": \"\",\n        \"store_to_order_rate\": \"\",\n        \"subtotal\": \"\",\n        \"subtotal_canceled\": \"\",\n        \"subtotal_incl_tax\": \"\",\n        \"subtotal_invoiced\": \"\",\n        \"subtotal_refunded\": \"\",\n        \"tax_amount\": \"\",\n        \"tax_canceled\": \"\",\n        \"tax_invoiced\": \"\",\n        \"tax_refunded\": \"\",\n        \"total_canceled\": \"\",\n        \"total_due\": \"\",\n        \"total_invoiced\": \"\",\n        \"total_item_count\": 0,\n        \"total_offline_refunded\": \"\",\n        \"total_online_refunded\": \"\",\n        \"total_paid\": \"\",\n        \"total_qty_ordered\": \"\",\n        \"total_refunded\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\",\n        \"x_forwarded_for\": \"\"\n      },\n      \"vertex_tax_calculation_shipping_address\": {}\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"is_used_for_refund\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"total_qty\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\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}}/V1/invoices/");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"entity\": {\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address_id\": 0,\n    \"can_void_flag\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"vertex_tax_calculation_billing_address\": {\n        \"address_type\": \"\",\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"customer_address_id\": 0,\n        \"customer_id\": 0,\n        \"email\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"checkout_fields\": [\n            {\n              \"attribute_code\": \"\",\n              \"value\": \"\"\n            }\n          ]\n        },\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"parent_id\": 0,\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": \"\",\n        \"region_code\": \"\",\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\",\n        \"vat_is_valid\": 0,\n        \"vat_request_date\": \"\",\n        \"vat_request_id\": \"\",\n        \"vat_request_success\": 0\n      },\n      \"vertex_tax_calculation_order\": {\n        \"adjustment_negative\": \"\",\n        \"adjustment_positive\": \"\",\n        \"applied_rule_ids\": \"\",\n        \"base_adjustment_negative\": \"\",\n        \"base_adjustment_positive\": \"\",\n        \"base_currency_code\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_canceled\": \"\",\n        \"base_discount_invoiced\": \"\",\n        \"base_discount_refunded\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_discount_tax_compensation_invoiced\": \"\",\n        \"base_discount_tax_compensation_refunded\": \"\",\n        \"base_grand_total\": \"\",\n        \"base_shipping_amount\": \"\",\n        \"base_shipping_canceled\": \"\",\n        \"base_shipping_discount_amount\": \"\",\n        \"base_shipping_discount_tax_compensation_amnt\": \"\",\n        \"base_shipping_incl_tax\": \"\",\n        \"base_shipping_invoiced\": \"\",\n        \"base_shipping_refunded\": \"\",\n        \"base_shipping_tax_amount\": \"\",\n        \"base_shipping_tax_refunded\": \"\",\n        \"base_subtotal\": \"\",\n        \"base_subtotal_canceled\": \"\",\n        \"base_subtotal_incl_tax\": \"\",\n        \"base_subtotal_invoiced\": \"\",\n        \"base_subtotal_refunded\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_tax_canceled\": \"\",\n        \"base_tax_invoiced\": \"\",\n        \"base_tax_refunded\": \"\",\n        \"base_to_global_rate\": \"\",\n        \"base_to_order_rate\": \"\",\n        \"base_total_canceled\": \"\",\n        \"base_total_due\": \"\",\n        \"base_total_invoiced\": \"\",\n        \"base_total_invoiced_cost\": \"\",\n        \"base_total_offline_refunded\": \"\",\n        \"base_total_online_refunded\": \"\",\n        \"base_total_paid\": \"\",\n        \"base_total_qty_ordered\": \"\",\n        \"base_total_refunded\": \"\",\n        \"billing_address\": {},\n        \"billing_address_id\": 0,\n        \"can_ship_partially\": 0,\n        \"can_ship_partially_item\": 0,\n        \"coupon_code\": \"\",\n        \"created_at\": \"\",\n        \"customer_dob\": \"\",\n        \"customer_email\": \"\",\n        \"customer_firstname\": \"\",\n        \"customer_gender\": 0,\n        \"customer_group_id\": 0,\n        \"customer_id\": 0,\n        \"customer_is_guest\": 0,\n        \"customer_lastname\": \"\",\n        \"customer_middlename\": \"\",\n        \"customer_note\": \"\",\n        \"customer_note_notify\": 0,\n        \"customer_prefix\": \"\",\n        \"customer_suffix\": \"\",\n        \"customer_taxvat\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_canceled\": \"\",\n        \"discount_description\": \"\",\n        \"discount_invoiced\": \"\",\n        \"discount_refunded\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"discount_tax_compensation_invoiced\": \"\",\n        \"discount_tax_compensation_refunded\": \"\",\n        \"edit_increment\": 0,\n        \"email_sent\": 0,\n        \"entity_id\": 0,\n        \"ext_customer_id\": \"\",\n        \"ext_order_id\": \"\",\n        \"extension_attributes\": {\n          \"amazon_order_reference_id\": \"\",\n          \"applied_taxes\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"extension_attributes\": {\n                \"rates\": [\n                  {\n                    \"code\": \"\",\n                    \"extension_attributes\": {},\n                    \"percent\": \"\",\n                    \"title\": \"\"\n                  }\n                ]\n              },\n              \"percent\": \"\",\n              \"title\": \"\"\n            }\n          ],\n          \"base_customer_balance_amount\": \"\",\n          \"base_customer_balance_invoiced\": \"\",\n          \"base_customer_balance_refunded\": \"\",\n          \"base_customer_balance_total_refunded\": \"\",\n          \"base_gift_cards_amount\": \"\",\n          \"base_gift_cards_invoiced\": \"\",\n          \"base_gift_cards_refunded\": \"\",\n          \"base_reward_currency_amount\": \"\",\n          \"company_order_attributes\": {\n            \"company_id\": 0,\n            \"company_name\": \"\",\n            \"extension_attributes\": {},\n            \"order_id\": 0\n          },\n          \"converting_from_quote\": false,\n          \"customer_balance_amount\": \"\",\n          \"customer_balance_invoiced\": \"\",\n          \"customer_balance_refunded\": \"\",\n          \"customer_balance_total_refunded\": \"\",\n          \"gift_cards\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"id\": 0\n            }\n          ],\n          \"gift_cards_amount\": \"\",\n          \"gift_cards_invoiced\": \"\",\n          \"gift_cards_refunded\": \"\",\n          \"gift_message\": {\n            \"customer_id\": 0,\n            \"extension_attributes\": {\n              \"entity_id\": \"\",\n              \"entity_type\": \"\",\n              \"wrapping_add_printed_card\": false,\n              \"wrapping_allow_gift_receipt\": false,\n              \"wrapping_id\": 0\n            },\n            \"gift_message_id\": 0,\n            \"message\": \"\",\n            \"recipient\": \"\",\n            \"sender\": \"\"\n          },\n          \"gw_add_card\": \"\",\n          \"gw_allow_gift_receipt\": \"\",\n          \"gw_base_price\": \"\",\n          \"gw_base_price_incl_tax\": \"\",\n          \"gw_base_price_invoiced\": \"\",\n          \"gw_base_price_refunded\": \"\",\n          \"gw_base_tax_amount\": \"\",\n          \"gw_base_tax_amount_invoiced\": \"\",\n          \"gw_base_tax_amount_refunded\": \"\",\n          \"gw_card_base_price\": \"\",\n          \"gw_card_base_price_incl_tax\": \"\",\n          \"gw_card_base_price_invoiced\": \"\",\n          \"gw_card_base_price_refunded\": \"\",\n          \"gw_card_base_tax_amount\": \"\",\n          \"gw_card_base_tax_invoiced\": \"\",\n          \"gw_card_base_tax_refunded\": \"\",\n          \"gw_card_price\": \"\",\n          \"gw_card_price_incl_tax\": \"\",\n          \"gw_card_price_invoiced\": \"\",\n          \"gw_card_price_refunded\": \"\",\n          \"gw_card_tax_amount\": \"\",\n          \"gw_card_tax_invoiced\": \"\",\n          \"gw_card_tax_refunded\": \"\",\n          \"gw_id\": \"\",\n          \"gw_items_base_price\": \"\",\n          \"gw_items_base_price_incl_tax\": \"\",\n          \"gw_items_base_price_invoiced\": \"\",\n          \"gw_items_base_price_refunded\": \"\",\n          \"gw_items_base_tax_amount\": \"\",\n          \"gw_items_base_tax_invoiced\": \"\",\n          \"gw_items_base_tax_refunded\": \"\",\n          \"gw_items_price\": \"\",\n          \"gw_items_price_incl_tax\": \"\",\n          \"gw_items_price_invoiced\": \"\",\n          \"gw_items_price_refunded\": \"\",\n          \"gw_items_tax_amount\": \"\",\n          \"gw_items_tax_invoiced\": \"\",\n          \"gw_items_tax_refunded\": \"\",\n          \"gw_price\": \"\",\n          \"gw_price_incl_tax\": \"\",\n          \"gw_price_invoiced\": \"\",\n          \"gw_price_refunded\": \"\",\n          \"gw_tax_amount\": \"\",\n          \"gw_tax_amount_invoiced\": \"\",\n          \"gw_tax_amount_refunded\": \"\",\n          \"item_applied_taxes\": [\n            {\n              \"applied_taxes\": [\n                {}\n              ],\n              \"associated_item_id\": 0,\n              \"extension_attributes\": {},\n              \"item_id\": 0,\n              \"type\": \"\"\n            }\n          ],\n          \"payment_additional_info\": [\n            {\n              \"key\": \"\",\n              \"value\": \"\"\n            }\n          ],\n          \"reward_currency_amount\": \"\",\n          \"reward_points_balance\": 0,\n          \"shipping_assignments\": [\n            {\n              \"extension_attributes\": {},\n              \"items\": [\n                {\n                  \"additional_data\": \"\",\n                  \"amount_refunded\": \"\",\n                  \"applied_rule_ids\": \"\",\n                  \"base_amount_refunded\": \"\",\n                  \"base_cost\": \"\",\n                  \"base_discount_amount\": \"\",\n                  \"base_discount_invoiced\": \"\",\n                  \"base_discount_refunded\": \"\",\n                  \"base_discount_tax_compensation_amount\": \"\",\n                  \"base_discount_tax_compensation_invoiced\": \"\",\n                  \"base_discount_tax_compensation_refunded\": \"\",\n                  \"base_original_price\": \"\",\n                  \"base_price\": \"\",\n                  \"base_price_incl_tax\": \"\",\n                  \"base_row_invoiced\": \"\",\n                  \"base_row_total\": \"\",\n                  \"base_row_total_incl_tax\": \"\",\n                  \"base_tax_amount\": \"\",\n                  \"base_tax_before_discount\": \"\",\n                  \"base_tax_invoiced\": \"\",\n                  \"base_tax_refunded\": \"\",\n                  \"base_weee_tax_applied_amount\": \"\",\n                  \"base_weee_tax_applied_row_amnt\": \"\",\n                  \"base_weee_tax_disposition\": \"\",\n                  \"base_weee_tax_row_disposition\": \"\",\n                  \"created_at\": \"\",\n                  \"description\": \"\",\n                  \"discount_amount\": \"\",\n                  \"discount_invoiced\": \"\",\n                  \"discount_percent\": \"\",\n                  \"discount_refunded\": \"\",\n                  \"discount_tax_compensation_amount\": \"\",\n                  \"discount_tax_compensation_canceled\": \"\",\n                  \"discount_tax_compensation_invoiced\": \"\",\n                  \"discount_tax_compensation_refunded\": \"\",\n                  \"event_id\": 0,\n                  \"ext_order_item_id\": \"\",\n                  \"extension_attributes\": {\n                    \"gift_message\": {},\n                    \"gw_base_price\": \"\",\n                    \"gw_base_price_invoiced\": \"\",\n                    \"gw_base_price_refunded\": \"\",\n                    \"gw_base_tax_amount\": \"\",\n                    \"gw_base_tax_amount_invoiced\": \"\",\n                    \"gw_base_tax_amount_refunded\": \"\",\n                    \"gw_id\": \"\",\n                    \"gw_price\": \"\",\n                    \"gw_price_invoiced\": \"\",\n                    \"gw_price_refunded\": \"\",\n                    \"gw_tax_amount\": \"\",\n                    \"gw_tax_amount_invoiced\": \"\",\n                    \"gw_tax_amount_refunded\": \"\",\n                    \"invoice_text_codes\": [],\n                    \"tax_codes\": [],\n                    \"vertex_tax_codes\": []\n                  },\n                  \"free_shipping\": 0,\n                  \"gw_base_price\": \"\",\n                  \"gw_base_price_invoiced\": \"\",\n                  \"gw_base_price_refunded\": \"\",\n                  \"gw_base_tax_amount\": \"\",\n                  \"gw_base_tax_amount_invoiced\": \"\",\n                  \"gw_base_tax_amount_refunded\": \"\",\n                  \"gw_id\": 0,\n                  \"gw_price\": \"\",\n                  \"gw_price_invoiced\": \"\",\n                  \"gw_price_refunded\": \"\",\n                  \"gw_tax_amount\": \"\",\n                  \"gw_tax_amount_invoiced\": \"\",\n                  \"gw_tax_amount_refunded\": \"\",\n                  \"is_qty_decimal\": 0,\n                  \"is_virtual\": 0,\n                  \"item_id\": 0,\n                  \"locked_do_invoice\": 0,\n                  \"locked_do_ship\": 0,\n                  \"name\": \"\",\n                  \"no_discount\": 0,\n                  \"order_id\": 0,\n                  \"original_price\": \"\",\n                  \"parent_item\": \"\",\n                  \"parent_item_id\": 0,\n                  \"price\": \"\",\n                  \"price_incl_tax\": \"\",\n                  \"product_id\": 0,\n                  \"product_option\": {\n                    \"extension_attributes\": {\n                      \"bundle_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": 0,\n                          \"option_qty\": 0,\n                          \"option_selections\": []\n                        }\n                      ],\n                      \"configurable_item_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": \"\",\n                          \"option_value\": 0\n                        }\n                      ],\n                      \"custom_options\": [\n                        {\n                          \"extension_attributes\": {\n                            \"file_info\": {\n                              \"base64_encoded_data\": \"\",\n                              \"name\": \"\",\n                              \"type\": \"\"\n                            }\n                          },\n                          \"option_id\": \"\",\n                          \"option_value\": \"\"\n                        }\n                      ],\n                      \"downloadable_option\": {\n                        \"downloadable_links\": []\n                      },\n                      \"giftcard_item_option\": {\n                        \"custom_giftcard_amount\": \"\",\n                        \"extension_attributes\": {},\n                        \"giftcard_amount\": \"\",\n                        \"giftcard_message\": \"\",\n                        \"giftcard_recipient_email\": \"\",\n                        \"giftcard_recipient_name\": \"\",\n                        \"giftcard_sender_email\": \"\",\n                        \"giftcard_sender_name\": \"\"\n                      }\n                    }\n                  },\n                  \"product_type\": \"\",\n                  \"qty_backordered\": \"\",\n                  \"qty_canceled\": \"\",\n                  \"qty_invoiced\": \"\",\n                  \"qty_ordered\": \"\",\n                  \"qty_refunded\": \"\",\n                  \"qty_returned\": \"\",\n                  \"qty_shipped\": \"\",\n                  \"quote_item_id\": 0,\n                  \"row_invoiced\": \"\",\n                  \"row_total\": \"\",\n                  \"row_total_incl_tax\": \"\",\n                  \"row_weight\": \"\",\n                  \"sku\": \"\",\n                  \"store_id\": 0,\n                  \"tax_amount\": \"\",\n                  \"tax_before_discount\": \"\",\n                  \"tax_canceled\": \"\",\n                  \"tax_invoiced\": \"\",\n                  \"tax_percent\": \"\",\n                  \"tax_refunded\": \"\",\n                  \"updated_at\": \"\",\n                  \"weee_tax_applied\": \"\",\n                  \"weee_tax_applied_amount\": \"\",\n                  \"weee_tax_applied_row_amount\": \"\",\n                  \"weee_tax_disposition\": \"\",\n                  \"weee_tax_row_disposition\": \"\",\n                  \"weight\": \"\"\n                }\n              ],\n              \"shipping\": {\n                \"address\": {},\n                \"extension_attributes\": {\n                  \"collection_point\": {\n                    \"city\": \"\",\n                    \"collection_point_id\": \"\",\n                    \"country\": \"\",\n                    \"name\": \"\",\n                    \"postcode\": \"\",\n                    \"recipient_address_id\": 0,\n                    \"region\": \"\",\n                    \"street\": []\n                  },\n                  \"ext_order_id\": \"\",\n                  \"shipping_experience\": {\n                    \"code\": \"\",\n                    \"cost\": \"\",\n                    \"label\": \"\"\n                  }\n                },\n                \"method\": \"\",\n                \"total\": {\n                  \"base_shipping_amount\": \"\",\n                  \"base_shipping_canceled\": \"\",\n                  \"base_shipping_discount_amount\": \"\",\n                  \"base_shipping_discount_tax_compensation_amnt\": \"\",\n                  \"base_shipping_incl_tax\": \"\",\n                  \"base_shipping_invoiced\": \"\",\n                  \"base_shipping_refunded\": \"\",\n                  \"base_shipping_tax_amount\": \"\",\n                  \"base_shipping_tax_refunded\": \"\",\n                  \"extension_attributes\": {},\n                  \"shipping_amount\": \"\",\n                  \"shipping_canceled\": \"\",\n                  \"shipping_discount_amount\": \"\",\n                  \"shipping_discount_tax_compensation_amount\": \"\",\n                  \"shipping_incl_tax\": \"\",\n                  \"shipping_invoiced\": \"\",\n                  \"shipping_refunded\": \"\",\n                  \"shipping_tax_amount\": \"\",\n                  \"shipping_tax_refunded\": \"\"\n                }\n              },\n              \"stock_id\": 0\n            }\n          ]\n        },\n        \"forced_shipment_with_invoice\": 0,\n        \"global_currency_code\": \"\",\n        \"grand_total\": \"\",\n        \"hold_before_state\": \"\",\n        \"hold_before_status\": \"\",\n        \"increment_id\": \"\",\n        \"is_virtual\": 0,\n        \"items\": [\n          {}\n        ],\n        \"order_currency_code\": \"\",\n        \"original_increment_id\": \"\",\n        \"payment\": {\n          \"account_status\": \"\",\n          \"additional_data\": \"\",\n          \"additional_information\": [],\n          \"address_status\": \"\",\n          \"amount_authorized\": \"\",\n          \"amount_canceled\": \"\",\n          \"amount_ordered\": \"\",\n          \"amount_paid\": \"\",\n          \"amount_refunded\": \"\",\n          \"anet_trans_method\": \"\",\n          \"base_amount_authorized\": \"\",\n          \"base_amount_canceled\": \"\",\n          \"base_amount_ordered\": \"\",\n          \"base_amount_paid\": \"\",\n          \"base_amount_paid_online\": \"\",\n          \"base_amount_refunded\": \"\",\n          \"base_amount_refunded_online\": \"\",\n          \"base_shipping_amount\": \"\",\n          \"base_shipping_captured\": \"\",\n          \"base_shipping_refunded\": \"\",\n          \"cc_approval\": \"\",\n          \"cc_avs_status\": \"\",\n          \"cc_cid_status\": \"\",\n          \"cc_debug_request_body\": \"\",\n          \"cc_debug_response_body\": \"\",\n          \"cc_debug_response_serialized\": \"\",\n          \"cc_exp_month\": \"\",\n          \"cc_exp_year\": \"\",\n          \"cc_last4\": \"\",\n          \"cc_number_enc\": \"\",\n          \"cc_owner\": \"\",\n          \"cc_secure_verify\": \"\",\n          \"cc_ss_issue\": \"\",\n          \"cc_ss_start_month\": \"\",\n          \"cc_ss_start_year\": \"\",\n          \"cc_status\": \"\",\n          \"cc_status_description\": \"\",\n          \"cc_trans_id\": \"\",\n          \"cc_type\": \"\",\n          \"echeck_account_name\": \"\",\n          \"echeck_account_type\": \"\",\n          \"echeck_bank_name\": \"\",\n          \"echeck_routing_number\": \"\",\n          \"echeck_type\": \"\",\n          \"entity_id\": 0,\n          \"extension_attributes\": {\n            \"vault_payment_token\": {\n              \"created_at\": \"\",\n              \"customer_id\": 0,\n              \"entity_id\": 0,\n              \"expires_at\": \"\",\n              \"gateway_token\": \"\",\n              \"is_active\": false,\n              \"is_visible\": false,\n              \"payment_method_code\": \"\",\n              \"public_hash\": \"\",\n              \"token_details\": \"\",\n              \"type\": \"\"\n            }\n          },\n          \"last_trans_id\": \"\",\n          \"method\": \"\",\n          \"parent_id\": 0,\n          \"po_number\": \"\",\n          \"protection_eligibility\": \"\",\n          \"quote_payment_id\": 0,\n          \"shipping_amount\": \"\",\n          \"shipping_captured\": \"\",\n          \"shipping_refunded\": \"\"\n        },\n        \"payment_auth_expiration\": 0,\n        \"payment_authorization_amount\": \"\",\n        \"protect_code\": \"\",\n        \"quote_address_id\": 0,\n        \"quote_id\": 0,\n        \"relation_child_id\": \"\",\n        \"relation_child_real_id\": \"\",\n        \"relation_parent_id\": \"\",\n        \"relation_parent_real_id\": \"\",\n        \"remote_ip\": \"\",\n        \"shipping_amount\": \"\",\n        \"shipping_canceled\": \"\",\n        \"shipping_description\": \"\",\n        \"shipping_discount_amount\": \"\",\n        \"shipping_discount_tax_compensation_amount\": \"\",\n        \"shipping_incl_tax\": \"\",\n        \"shipping_invoiced\": \"\",\n        \"shipping_refunded\": \"\",\n        \"shipping_tax_amount\": \"\",\n        \"shipping_tax_refunded\": \"\",\n        \"state\": \"\",\n        \"status\": \"\",\n        \"status_histories\": [\n          {\n            \"comment\": \"\",\n            \"created_at\": \"\",\n            \"entity_id\": 0,\n            \"entity_name\": \"\",\n            \"extension_attributes\": {},\n            \"is_customer_notified\": 0,\n            \"is_visible_on_front\": 0,\n            \"parent_id\": 0,\n            \"status\": \"\"\n          }\n        ],\n        \"store_currency_code\": \"\",\n        \"store_id\": 0,\n        \"store_name\": \"\",\n        \"store_to_base_rate\": \"\",\n        \"store_to_order_rate\": \"\",\n        \"subtotal\": \"\",\n        \"subtotal_canceled\": \"\",\n        \"subtotal_incl_tax\": \"\",\n        \"subtotal_invoiced\": \"\",\n        \"subtotal_refunded\": \"\",\n        \"tax_amount\": \"\",\n        \"tax_canceled\": \"\",\n        \"tax_invoiced\": \"\",\n        \"tax_refunded\": \"\",\n        \"total_canceled\": \"\",\n        \"total_due\": \"\",\n        \"total_invoiced\": \"\",\n        \"total_item_count\": 0,\n        \"total_offline_refunded\": \"\",\n        \"total_online_refunded\": \"\",\n        \"total_paid\": \"\",\n        \"total_qty_ordered\": \"\",\n        \"total_refunded\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\",\n        \"x_forwarded_for\": \"\"\n      },\n      \"vertex_tax_calculation_shipping_address\": {}\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"is_used_for_refund\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"total_qty\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/invoices/"

	payload := strings.NewReader("{\n  \"entity\": {\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address_id\": 0,\n    \"can_void_flag\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"vertex_tax_calculation_billing_address\": {\n        \"address_type\": \"\",\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"customer_address_id\": 0,\n        \"customer_id\": 0,\n        \"email\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"checkout_fields\": [\n            {\n              \"attribute_code\": \"\",\n              \"value\": \"\"\n            }\n          ]\n        },\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"parent_id\": 0,\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": \"\",\n        \"region_code\": \"\",\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\",\n        \"vat_is_valid\": 0,\n        \"vat_request_date\": \"\",\n        \"vat_request_id\": \"\",\n        \"vat_request_success\": 0\n      },\n      \"vertex_tax_calculation_order\": {\n        \"adjustment_negative\": \"\",\n        \"adjustment_positive\": \"\",\n        \"applied_rule_ids\": \"\",\n        \"base_adjustment_negative\": \"\",\n        \"base_adjustment_positive\": \"\",\n        \"base_currency_code\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_canceled\": \"\",\n        \"base_discount_invoiced\": \"\",\n        \"base_discount_refunded\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_discount_tax_compensation_invoiced\": \"\",\n        \"base_discount_tax_compensation_refunded\": \"\",\n        \"base_grand_total\": \"\",\n        \"base_shipping_amount\": \"\",\n        \"base_shipping_canceled\": \"\",\n        \"base_shipping_discount_amount\": \"\",\n        \"base_shipping_discount_tax_compensation_amnt\": \"\",\n        \"base_shipping_incl_tax\": \"\",\n        \"base_shipping_invoiced\": \"\",\n        \"base_shipping_refunded\": \"\",\n        \"base_shipping_tax_amount\": \"\",\n        \"base_shipping_tax_refunded\": \"\",\n        \"base_subtotal\": \"\",\n        \"base_subtotal_canceled\": \"\",\n        \"base_subtotal_incl_tax\": \"\",\n        \"base_subtotal_invoiced\": \"\",\n        \"base_subtotal_refunded\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_tax_canceled\": \"\",\n        \"base_tax_invoiced\": \"\",\n        \"base_tax_refunded\": \"\",\n        \"base_to_global_rate\": \"\",\n        \"base_to_order_rate\": \"\",\n        \"base_total_canceled\": \"\",\n        \"base_total_due\": \"\",\n        \"base_total_invoiced\": \"\",\n        \"base_total_invoiced_cost\": \"\",\n        \"base_total_offline_refunded\": \"\",\n        \"base_total_online_refunded\": \"\",\n        \"base_total_paid\": \"\",\n        \"base_total_qty_ordered\": \"\",\n        \"base_total_refunded\": \"\",\n        \"billing_address\": {},\n        \"billing_address_id\": 0,\n        \"can_ship_partially\": 0,\n        \"can_ship_partially_item\": 0,\n        \"coupon_code\": \"\",\n        \"created_at\": \"\",\n        \"customer_dob\": \"\",\n        \"customer_email\": \"\",\n        \"customer_firstname\": \"\",\n        \"customer_gender\": 0,\n        \"customer_group_id\": 0,\n        \"customer_id\": 0,\n        \"customer_is_guest\": 0,\n        \"customer_lastname\": \"\",\n        \"customer_middlename\": \"\",\n        \"customer_note\": \"\",\n        \"customer_note_notify\": 0,\n        \"customer_prefix\": \"\",\n        \"customer_suffix\": \"\",\n        \"customer_taxvat\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_canceled\": \"\",\n        \"discount_description\": \"\",\n        \"discount_invoiced\": \"\",\n        \"discount_refunded\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"discount_tax_compensation_invoiced\": \"\",\n        \"discount_tax_compensation_refunded\": \"\",\n        \"edit_increment\": 0,\n        \"email_sent\": 0,\n        \"entity_id\": 0,\n        \"ext_customer_id\": \"\",\n        \"ext_order_id\": \"\",\n        \"extension_attributes\": {\n          \"amazon_order_reference_id\": \"\",\n          \"applied_taxes\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"extension_attributes\": {\n                \"rates\": [\n                  {\n                    \"code\": \"\",\n                    \"extension_attributes\": {},\n                    \"percent\": \"\",\n                    \"title\": \"\"\n                  }\n                ]\n              },\n              \"percent\": \"\",\n              \"title\": \"\"\n            }\n          ],\n          \"base_customer_balance_amount\": \"\",\n          \"base_customer_balance_invoiced\": \"\",\n          \"base_customer_balance_refunded\": \"\",\n          \"base_customer_balance_total_refunded\": \"\",\n          \"base_gift_cards_amount\": \"\",\n          \"base_gift_cards_invoiced\": \"\",\n          \"base_gift_cards_refunded\": \"\",\n          \"base_reward_currency_amount\": \"\",\n          \"company_order_attributes\": {\n            \"company_id\": 0,\n            \"company_name\": \"\",\n            \"extension_attributes\": {},\n            \"order_id\": 0\n          },\n          \"converting_from_quote\": false,\n          \"customer_balance_amount\": \"\",\n          \"customer_balance_invoiced\": \"\",\n          \"customer_balance_refunded\": \"\",\n          \"customer_balance_total_refunded\": \"\",\n          \"gift_cards\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"id\": 0\n            }\n          ],\n          \"gift_cards_amount\": \"\",\n          \"gift_cards_invoiced\": \"\",\n          \"gift_cards_refunded\": \"\",\n          \"gift_message\": {\n            \"customer_id\": 0,\n            \"extension_attributes\": {\n              \"entity_id\": \"\",\n              \"entity_type\": \"\",\n              \"wrapping_add_printed_card\": false,\n              \"wrapping_allow_gift_receipt\": false,\n              \"wrapping_id\": 0\n            },\n            \"gift_message_id\": 0,\n            \"message\": \"\",\n            \"recipient\": \"\",\n            \"sender\": \"\"\n          },\n          \"gw_add_card\": \"\",\n          \"gw_allow_gift_receipt\": \"\",\n          \"gw_base_price\": \"\",\n          \"gw_base_price_incl_tax\": \"\",\n          \"gw_base_price_invoiced\": \"\",\n          \"gw_base_price_refunded\": \"\",\n          \"gw_base_tax_amount\": \"\",\n          \"gw_base_tax_amount_invoiced\": \"\",\n          \"gw_base_tax_amount_refunded\": \"\",\n          \"gw_card_base_price\": \"\",\n          \"gw_card_base_price_incl_tax\": \"\",\n          \"gw_card_base_price_invoiced\": \"\",\n          \"gw_card_base_price_refunded\": \"\",\n          \"gw_card_base_tax_amount\": \"\",\n          \"gw_card_base_tax_invoiced\": \"\",\n          \"gw_card_base_tax_refunded\": \"\",\n          \"gw_card_price\": \"\",\n          \"gw_card_price_incl_tax\": \"\",\n          \"gw_card_price_invoiced\": \"\",\n          \"gw_card_price_refunded\": \"\",\n          \"gw_card_tax_amount\": \"\",\n          \"gw_card_tax_invoiced\": \"\",\n          \"gw_card_tax_refunded\": \"\",\n          \"gw_id\": \"\",\n          \"gw_items_base_price\": \"\",\n          \"gw_items_base_price_incl_tax\": \"\",\n          \"gw_items_base_price_invoiced\": \"\",\n          \"gw_items_base_price_refunded\": \"\",\n          \"gw_items_base_tax_amount\": \"\",\n          \"gw_items_base_tax_invoiced\": \"\",\n          \"gw_items_base_tax_refunded\": \"\",\n          \"gw_items_price\": \"\",\n          \"gw_items_price_incl_tax\": \"\",\n          \"gw_items_price_invoiced\": \"\",\n          \"gw_items_price_refunded\": \"\",\n          \"gw_items_tax_amount\": \"\",\n          \"gw_items_tax_invoiced\": \"\",\n          \"gw_items_tax_refunded\": \"\",\n          \"gw_price\": \"\",\n          \"gw_price_incl_tax\": \"\",\n          \"gw_price_invoiced\": \"\",\n          \"gw_price_refunded\": \"\",\n          \"gw_tax_amount\": \"\",\n          \"gw_tax_amount_invoiced\": \"\",\n          \"gw_tax_amount_refunded\": \"\",\n          \"item_applied_taxes\": [\n            {\n              \"applied_taxes\": [\n                {}\n              ],\n              \"associated_item_id\": 0,\n              \"extension_attributes\": {},\n              \"item_id\": 0,\n              \"type\": \"\"\n            }\n          ],\n          \"payment_additional_info\": [\n            {\n              \"key\": \"\",\n              \"value\": \"\"\n            }\n          ],\n          \"reward_currency_amount\": \"\",\n          \"reward_points_balance\": 0,\n          \"shipping_assignments\": [\n            {\n              \"extension_attributes\": {},\n              \"items\": [\n                {\n                  \"additional_data\": \"\",\n                  \"amount_refunded\": \"\",\n                  \"applied_rule_ids\": \"\",\n                  \"base_amount_refunded\": \"\",\n                  \"base_cost\": \"\",\n                  \"base_discount_amount\": \"\",\n                  \"base_discount_invoiced\": \"\",\n                  \"base_discount_refunded\": \"\",\n                  \"base_discount_tax_compensation_amount\": \"\",\n                  \"base_discount_tax_compensation_invoiced\": \"\",\n                  \"base_discount_tax_compensation_refunded\": \"\",\n                  \"base_original_price\": \"\",\n                  \"base_price\": \"\",\n                  \"base_price_incl_tax\": \"\",\n                  \"base_row_invoiced\": \"\",\n                  \"base_row_total\": \"\",\n                  \"base_row_total_incl_tax\": \"\",\n                  \"base_tax_amount\": \"\",\n                  \"base_tax_before_discount\": \"\",\n                  \"base_tax_invoiced\": \"\",\n                  \"base_tax_refunded\": \"\",\n                  \"base_weee_tax_applied_amount\": \"\",\n                  \"base_weee_tax_applied_row_amnt\": \"\",\n                  \"base_weee_tax_disposition\": \"\",\n                  \"base_weee_tax_row_disposition\": \"\",\n                  \"created_at\": \"\",\n                  \"description\": \"\",\n                  \"discount_amount\": \"\",\n                  \"discount_invoiced\": \"\",\n                  \"discount_percent\": \"\",\n                  \"discount_refunded\": \"\",\n                  \"discount_tax_compensation_amount\": \"\",\n                  \"discount_tax_compensation_canceled\": \"\",\n                  \"discount_tax_compensation_invoiced\": \"\",\n                  \"discount_tax_compensation_refunded\": \"\",\n                  \"event_id\": 0,\n                  \"ext_order_item_id\": \"\",\n                  \"extension_attributes\": {\n                    \"gift_message\": {},\n                    \"gw_base_price\": \"\",\n                    \"gw_base_price_invoiced\": \"\",\n                    \"gw_base_price_refunded\": \"\",\n                    \"gw_base_tax_amount\": \"\",\n                    \"gw_base_tax_amount_invoiced\": \"\",\n                    \"gw_base_tax_amount_refunded\": \"\",\n                    \"gw_id\": \"\",\n                    \"gw_price\": \"\",\n                    \"gw_price_invoiced\": \"\",\n                    \"gw_price_refunded\": \"\",\n                    \"gw_tax_amount\": \"\",\n                    \"gw_tax_amount_invoiced\": \"\",\n                    \"gw_tax_amount_refunded\": \"\",\n                    \"invoice_text_codes\": [],\n                    \"tax_codes\": [],\n                    \"vertex_tax_codes\": []\n                  },\n                  \"free_shipping\": 0,\n                  \"gw_base_price\": \"\",\n                  \"gw_base_price_invoiced\": \"\",\n                  \"gw_base_price_refunded\": \"\",\n                  \"gw_base_tax_amount\": \"\",\n                  \"gw_base_tax_amount_invoiced\": \"\",\n                  \"gw_base_tax_amount_refunded\": \"\",\n                  \"gw_id\": 0,\n                  \"gw_price\": \"\",\n                  \"gw_price_invoiced\": \"\",\n                  \"gw_price_refunded\": \"\",\n                  \"gw_tax_amount\": \"\",\n                  \"gw_tax_amount_invoiced\": \"\",\n                  \"gw_tax_amount_refunded\": \"\",\n                  \"is_qty_decimal\": 0,\n                  \"is_virtual\": 0,\n                  \"item_id\": 0,\n                  \"locked_do_invoice\": 0,\n                  \"locked_do_ship\": 0,\n                  \"name\": \"\",\n                  \"no_discount\": 0,\n                  \"order_id\": 0,\n                  \"original_price\": \"\",\n                  \"parent_item\": \"\",\n                  \"parent_item_id\": 0,\n                  \"price\": \"\",\n                  \"price_incl_tax\": \"\",\n                  \"product_id\": 0,\n                  \"product_option\": {\n                    \"extension_attributes\": {\n                      \"bundle_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": 0,\n                          \"option_qty\": 0,\n                          \"option_selections\": []\n                        }\n                      ],\n                      \"configurable_item_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": \"\",\n                          \"option_value\": 0\n                        }\n                      ],\n                      \"custom_options\": [\n                        {\n                          \"extension_attributes\": {\n                            \"file_info\": {\n                              \"base64_encoded_data\": \"\",\n                              \"name\": \"\",\n                              \"type\": \"\"\n                            }\n                          },\n                          \"option_id\": \"\",\n                          \"option_value\": \"\"\n                        }\n                      ],\n                      \"downloadable_option\": {\n                        \"downloadable_links\": []\n                      },\n                      \"giftcard_item_option\": {\n                        \"custom_giftcard_amount\": \"\",\n                        \"extension_attributes\": {},\n                        \"giftcard_amount\": \"\",\n                        \"giftcard_message\": \"\",\n                        \"giftcard_recipient_email\": \"\",\n                        \"giftcard_recipient_name\": \"\",\n                        \"giftcard_sender_email\": \"\",\n                        \"giftcard_sender_name\": \"\"\n                      }\n                    }\n                  },\n                  \"product_type\": \"\",\n                  \"qty_backordered\": \"\",\n                  \"qty_canceled\": \"\",\n                  \"qty_invoiced\": \"\",\n                  \"qty_ordered\": \"\",\n                  \"qty_refunded\": \"\",\n                  \"qty_returned\": \"\",\n                  \"qty_shipped\": \"\",\n                  \"quote_item_id\": 0,\n                  \"row_invoiced\": \"\",\n                  \"row_total\": \"\",\n                  \"row_total_incl_tax\": \"\",\n                  \"row_weight\": \"\",\n                  \"sku\": \"\",\n                  \"store_id\": 0,\n                  \"tax_amount\": \"\",\n                  \"tax_before_discount\": \"\",\n                  \"tax_canceled\": \"\",\n                  \"tax_invoiced\": \"\",\n                  \"tax_percent\": \"\",\n                  \"tax_refunded\": \"\",\n                  \"updated_at\": \"\",\n                  \"weee_tax_applied\": \"\",\n                  \"weee_tax_applied_amount\": \"\",\n                  \"weee_tax_applied_row_amount\": \"\",\n                  \"weee_tax_disposition\": \"\",\n                  \"weee_tax_row_disposition\": \"\",\n                  \"weight\": \"\"\n                }\n              ],\n              \"shipping\": {\n                \"address\": {},\n                \"extension_attributes\": {\n                  \"collection_point\": {\n                    \"city\": \"\",\n                    \"collection_point_id\": \"\",\n                    \"country\": \"\",\n                    \"name\": \"\",\n                    \"postcode\": \"\",\n                    \"recipient_address_id\": 0,\n                    \"region\": \"\",\n                    \"street\": []\n                  },\n                  \"ext_order_id\": \"\",\n                  \"shipping_experience\": {\n                    \"code\": \"\",\n                    \"cost\": \"\",\n                    \"label\": \"\"\n                  }\n                },\n                \"method\": \"\",\n                \"total\": {\n                  \"base_shipping_amount\": \"\",\n                  \"base_shipping_canceled\": \"\",\n                  \"base_shipping_discount_amount\": \"\",\n                  \"base_shipping_discount_tax_compensation_amnt\": \"\",\n                  \"base_shipping_incl_tax\": \"\",\n                  \"base_shipping_invoiced\": \"\",\n                  \"base_shipping_refunded\": \"\",\n                  \"base_shipping_tax_amount\": \"\",\n                  \"base_shipping_tax_refunded\": \"\",\n                  \"extension_attributes\": {},\n                  \"shipping_amount\": \"\",\n                  \"shipping_canceled\": \"\",\n                  \"shipping_discount_amount\": \"\",\n                  \"shipping_discount_tax_compensation_amount\": \"\",\n                  \"shipping_incl_tax\": \"\",\n                  \"shipping_invoiced\": \"\",\n                  \"shipping_refunded\": \"\",\n                  \"shipping_tax_amount\": \"\",\n                  \"shipping_tax_refunded\": \"\"\n                }\n              },\n              \"stock_id\": 0\n            }\n          ]\n        },\n        \"forced_shipment_with_invoice\": 0,\n        \"global_currency_code\": \"\",\n        \"grand_total\": \"\",\n        \"hold_before_state\": \"\",\n        \"hold_before_status\": \"\",\n        \"increment_id\": \"\",\n        \"is_virtual\": 0,\n        \"items\": [\n          {}\n        ],\n        \"order_currency_code\": \"\",\n        \"original_increment_id\": \"\",\n        \"payment\": {\n          \"account_status\": \"\",\n          \"additional_data\": \"\",\n          \"additional_information\": [],\n          \"address_status\": \"\",\n          \"amount_authorized\": \"\",\n          \"amount_canceled\": \"\",\n          \"amount_ordered\": \"\",\n          \"amount_paid\": \"\",\n          \"amount_refunded\": \"\",\n          \"anet_trans_method\": \"\",\n          \"base_amount_authorized\": \"\",\n          \"base_amount_canceled\": \"\",\n          \"base_amount_ordered\": \"\",\n          \"base_amount_paid\": \"\",\n          \"base_amount_paid_online\": \"\",\n          \"base_amount_refunded\": \"\",\n          \"base_amount_refunded_online\": \"\",\n          \"base_shipping_amount\": \"\",\n          \"base_shipping_captured\": \"\",\n          \"base_shipping_refunded\": \"\",\n          \"cc_approval\": \"\",\n          \"cc_avs_status\": \"\",\n          \"cc_cid_status\": \"\",\n          \"cc_debug_request_body\": \"\",\n          \"cc_debug_response_body\": \"\",\n          \"cc_debug_response_serialized\": \"\",\n          \"cc_exp_month\": \"\",\n          \"cc_exp_year\": \"\",\n          \"cc_last4\": \"\",\n          \"cc_number_enc\": \"\",\n          \"cc_owner\": \"\",\n          \"cc_secure_verify\": \"\",\n          \"cc_ss_issue\": \"\",\n          \"cc_ss_start_month\": \"\",\n          \"cc_ss_start_year\": \"\",\n          \"cc_status\": \"\",\n          \"cc_status_description\": \"\",\n          \"cc_trans_id\": \"\",\n          \"cc_type\": \"\",\n          \"echeck_account_name\": \"\",\n          \"echeck_account_type\": \"\",\n          \"echeck_bank_name\": \"\",\n          \"echeck_routing_number\": \"\",\n          \"echeck_type\": \"\",\n          \"entity_id\": 0,\n          \"extension_attributes\": {\n            \"vault_payment_token\": {\n              \"created_at\": \"\",\n              \"customer_id\": 0,\n              \"entity_id\": 0,\n              \"expires_at\": \"\",\n              \"gateway_token\": \"\",\n              \"is_active\": false,\n              \"is_visible\": false,\n              \"payment_method_code\": \"\",\n              \"public_hash\": \"\",\n              \"token_details\": \"\",\n              \"type\": \"\"\n            }\n          },\n          \"last_trans_id\": \"\",\n          \"method\": \"\",\n          \"parent_id\": 0,\n          \"po_number\": \"\",\n          \"protection_eligibility\": \"\",\n          \"quote_payment_id\": 0,\n          \"shipping_amount\": \"\",\n          \"shipping_captured\": \"\",\n          \"shipping_refunded\": \"\"\n        },\n        \"payment_auth_expiration\": 0,\n        \"payment_authorization_amount\": \"\",\n        \"protect_code\": \"\",\n        \"quote_address_id\": 0,\n        \"quote_id\": 0,\n        \"relation_child_id\": \"\",\n        \"relation_child_real_id\": \"\",\n        \"relation_parent_id\": \"\",\n        \"relation_parent_real_id\": \"\",\n        \"remote_ip\": \"\",\n        \"shipping_amount\": \"\",\n        \"shipping_canceled\": \"\",\n        \"shipping_description\": \"\",\n        \"shipping_discount_amount\": \"\",\n        \"shipping_discount_tax_compensation_amount\": \"\",\n        \"shipping_incl_tax\": \"\",\n        \"shipping_invoiced\": \"\",\n        \"shipping_refunded\": \"\",\n        \"shipping_tax_amount\": \"\",\n        \"shipping_tax_refunded\": \"\",\n        \"state\": \"\",\n        \"status\": \"\",\n        \"status_histories\": [\n          {\n            \"comment\": \"\",\n            \"created_at\": \"\",\n            \"entity_id\": 0,\n            \"entity_name\": \"\",\n            \"extension_attributes\": {},\n            \"is_customer_notified\": 0,\n            \"is_visible_on_front\": 0,\n            \"parent_id\": 0,\n            \"status\": \"\"\n          }\n        ],\n        \"store_currency_code\": \"\",\n        \"store_id\": 0,\n        \"store_name\": \"\",\n        \"store_to_base_rate\": \"\",\n        \"store_to_order_rate\": \"\",\n        \"subtotal\": \"\",\n        \"subtotal_canceled\": \"\",\n        \"subtotal_incl_tax\": \"\",\n        \"subtotal_invoiced\": \"\",\n        \"subtotal_refunded\": \"\",\n        \"tax_amount\": \"\",\n        \"tax_canceled\": \"\",\n        \"tax_invoiced\": \"\",\n        \"tax_refunded\": \"\",\n        \"total_canceled\": \"\",\n        \"total_due\": \"\",\n        \"total_invoiced\": \"\",\n        \"total_item_count\": 0,\n        \"total_offline_refunded\": \"\",\n        \"total_online_refunded\": \"\",\n        \"total_paid\": \"\",\n        \"total_qty_ordered\": \"\",\n        \"total_refunded\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\",\n        \"x_forwarded_for\": \"\"\n      },\n      \"vertex_tax_calculation_shipping_address\": {}\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"is_used_for_refund\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"total_qty\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/invoices/ HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 24059

{
  "entity": {
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_refunded": "",
    "billing_address_id": 0,
    "can_void_flag": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": "",
      "vertex_tax_calculation_billing_address": {
        "address_type": "",
        "city": "",
        "company": "",
        "country_id": "",
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "entity_id": 0,
        "extension_attributes": {
          "checkout_fields": [
            {
              "attribute_code": "",
              "value": ""
            }
          ]
        },
        "fax": "",
        "firstname": "",
        "lastname": "",
        "middlename": "",
        "parent_id": 0,
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": "",
        "vat_is_valid": 0,
        "vat_request_date": "",
        "vat_request_id": "",
        "vat_request_success": 0
      },
      "vertex_tax_calculation_order": {
        "adjustment_negative": "",
        "adjustment_positive": "",
        "applied_rule_ids": "",
        "base_adjustment_negative": "",
        "base_adjustment_positive": "",
        "base_currency_code": "",
        "base_discount_amount": "",
        "base_discount_canceled": "",
        "base_discount_invoiced": "",
        "base_discount_refunded": "",
        "base_discount_tax_compensation_amount": "",
        "base_discount_tax_compensation_invoiced": "",
        "base_discount_tax_compensation_refunded": "",
        "base_grand_total": "",
        "base_shipping_amount": "",
        "base_shipping_canceled": "",
        "base_shipping_discount_amount": "",
        "base_shipping_discount_tax_compensation_amnt": "",
        "base_shipping_incl_tax": "",
        "base_shipping_invoiced": "",
        "base_shipping_refunded": "",
        "base_shipping_tax_amount": "",
        "base_shipping_tax_refunded": "",
        "base_subtotal": "",
        "base_subtotal_canceled": "",
        "base_subtotal_incl_tax": "",
        "base_subtotal_invoiced": "",
        "base_subtotal_refunded": "",
        "base_tax_amount": "",
        "base_tax_canceled": "",
        "base_tax_invoiced": "",
        "base_tax_refunded": "",
        "base_to_global_rate": "",
        "base_to_order_rate": "",
        "base_total_canceled": "",
        "base_total_due": "",
        "base_total_invoiced": "",
        "base_total_invoiced_cost": "",
        "base_total_offline_refunded": "",
        "base_total_online_refunded": "",
        "base_total_paid": "",
        "base_total_qty_ordered": "",
        "base_total_refunded": "",
        "billing_address": {},
        "billing_address_id": 0,
        "can_ship_partially": 0,
        "can_ship_partially_item": 0,
        "coupon_code": "",
        "created_at": "",
        "customer_dob": "",
        "customer_email": "",
        "customer_firstname": "",
        "customer_gender": 0,
        "customer_group_id": 0,
        "customer_id": 0,
        "customer_is_guest": 0,
        "customer_lastname": "",
        "customer_middlename": "",
        "customer_note": "",
        "customer_note_notify": 0,
        "customer_prefix": "",
        "customer_suffix": "",
        "customer_taxvat": "",
        "discount_amount": "",
        "discount_canceled": "",
        "discount_description": "",
        "discount_invoiced": "",
        "discount_refunded": "",
        "discount_tax_compensation_amount": "",
        "discount_tax_compensation_invoiced": "",
        "discount_tax_compensation_refunded": "",
        "edit_increment": 0,
        "email_sent": 0,
        "entity_id": 0,
        "ext_customer_id": "",
        "ext_order_id": "",
        "extension_attributes": {
          "amazon_order_reference_id": "",
          "applied_taxes": [
            {
              "amount": "",
              "base_amount": "",
              "code": "",
              "extension_attributes": {
                "rates": [
                  {
                    "code": "",
                    "extension_attributes": {},
                    "percent": "",
                    "title": ""
                  }
                ]
              },
              "percent": "",
              "title": ""
            }
          ],
          "base_customer_balance_amount": "",
          "base_customer_balance_invoiced": "",
          "base_customer_balance_refunded": "",
          "base_customer_balance_total_refunded": "",
          "base_gift_cards_amount": "",
          "base_gift_cards_invoiced": "",
          "base_gift_cards_refunded": "",
          "base_reward_currency_amount": "",
          "company_order_attributes": {
            "company_id": 0,
            "company_name": "",
            "extension_attributes": {},
            "order_id": 0
          },
          "converting_from_quote": false,
          "customer_balance_amount": "",
          "customer_balance_invoiced": "",
          "customer_balance_refunded": "",
          "customer_balance_total_refunded": "",
          "gift_cards": [
            {
              "amount": "",
              "base_amount": "",
              "code": "",
              "id": 0
            }
          ],
          "gift_cards_amount": "",
          "gift_cards_invoiced": "",
          "gift_cards_refunded": "",
          "gift_message": {
            "customer_id": 0,
            "extension_attributes": {
              "entity_id": "",
              "entity_type": "",
              "wrapping_add_printed_card": false,
              "wrapping_allow_gift_receipt": false,
              "wrapping_id": 0
            },
            "gift_message_id": 0,
            "message": "",
            "recipient": "",
            "sender": ""
          },
          "gw_add_card": "",
          "gw_allow_gift_receipt": "",
          "gw_base_price": "",
          "gw_base_price_incl_tax": "",
          "gw_base_price_invoiced": "",
          "gw_base_price_refunded": "",
          "gw_base_tax_amount": "",
          "gw_base_tax_amount_invoiced": "",
          "gw_base_tax_amount_refunded": "",
          "gw_card_base_price": "",
          "gw_card_base_price_incl_tax": "",
          "gw_card_base_price_invoiced": "",
          "gw_card_base_price_refunded": "",
          "gw_card_base_tax_amount": "",
          "gw_card_base_tax_invoiced": "",
          "gw_card_base_tax_refunded": "",
          "gw_card_price": "",
          "gw_card_price_incl_tax": "",
          "gw_card_price_invoiced": "",
          "gw_card_price_refunded": "",
          "gw_card_tax_amount": "",
          "gw_card_tax_invoiced": "",
          "gw_card_tax_refunded": "",
          "gw_id": "",
          "gw_items_base_price": "",
          "gw_items_base_price_incl_tax": "",
          "gw_items_base_price_invoiced": "",
          "gw_items_base_price_refunded": "",
          "gw_items_base_tax_amount": "",
          "gw_items_base_tax_invoiced": "",
          "gw_items_base_tax_refunded": "",
          "gw_items_price": "",
          "gw_items_price_incl_tax": "",
          "gw_items_price_invoiced": "",
          "gw_items_price_refunded": "",
          "gw_items_tax_amount": "",
          "gw_items_tax_invoiced": "",
          "gw_items_tax_refunded": "",
          "gw_price": "",
          "gw_price_incl_tax": "",
          "gw_price_invoiced": "",
          "gw_price_refunded": "",
          "gw_tax_amount": "",
          "gw_tax_amount_invoiced": "",
          "gw_tax_amount_refunded": "",
          "item_applied_taxes": [
            {
              "applied_taxes": [
                {}
              ],
              "associated_item_id": 0,
              "extension_attributes": {},
              "item_id": 0,
              "type": ""
            }
          ],
          "payment_additional_info": [
            {
              "key": "",
              "value": ""
            }
          ],
          "reward_currency_amount": "",
          "reward_points_balance": 0,
          "shipping_assignments": [
            {
              "extension_attributes": {},
              "items": [
                {
                  "additional_data": "",
                  "amount_refunded": "",
                  "applied_rule_ids": "",
                  "base_amount_refunded": "",
                  "base_cost": "",
                  "base_discount_amount": "",
                  "base_discount_invoiced": "",
                  "base_discount_refunded": "",
                  "base_discount_tax_compensation_amount": "",
                  "base_discount_tax_compensation_invoiced": "",
                  "base_discount_tax_compensation_refunded": "",
                  "base_original_price": "",
                  "base_price": "",
                  "base_price_incl_tax": "",
                  "base_row_invoiced": "",
                  "base_row_total": "",
                  "base_row_total_incl_tax": "",
                  "base_tax_amount": "",
                  "base_tax_before_discount": "",
                  "base_tax_invoiced": "",
                  "base_tax_refunded": "",
                  "base_weee_tax_applied_amount": "",
                  "base_weee_tax_applied_row_amnt": "",
                  "base_weee_tax_disposition": "",
                  "base_weee_tax_row_disposition": "",
                  "created_at": "",
                  "description": "",
                  "discount_amount": "",
                  "discount_invoiced": "",
                  "discount_percent": "",
                  "discount_refunded": "",
                  "discount_tax_compensation_amount": "",
                  "discount_tax_compensation_canceled": "",
                  "discount_tax_compensation_invoiced": "",
                  "discount_tax_compensation_refunded": "",
                  "event_id": 0,
                  "ext_order_item_id": "",
                  "extension_attributes": {
                    "gift_message": {},
                    "gw_base_price": "",
                    "gw_base_price_invoiced": "",
                    "gw_base_price_refunded": "",
                    "gw_base_tax_amount": "",
                    "gw_base_tax_amount_invoiced": "",
                    "gw_base_tax_amount_refunded": "",
                    "gw_id": "",
                    "gw_price": "",
                    "gw_price_invoiced": "",
                    "gw_price_refunded": "",
                    "gw_tax_amount": "",
                    "gw_tax_amount_invoiced": "",
                    "gw_tax_amount_refunded": "",
                    "invoice_text_codes": [],
                    "tax_codes": [],
                    "vertex_tax_codes": []
                  },
                  "free_shipping": 0,
                  "gw_base_price": "",
                  "gw_base_price_invoiced": "",
                  "gw_base_price_refunded": "",
                  "gw_base_tax_amount": "",
                  "gw_base_tax_amount_invoiced": "",
                  "gw_base_tax_amount_refunded": "",
                  "gw_id": 0,
                  "gw_price": "",
                  "gw_price_invoiced": "",
                  "gw_price_refunded": "",
                  "gw_tax_amount": "",
                  "gw_tax_amount_invoiced": "",
                  "gw_tax_amount_refunded": "",
                  "is_qty_decimal": 0,
                  "is_virtual": 0,
                  "item_id": 0,
                  "locked_do_invoice": 0,
                  "locked_do_ship": 0,
                  "name": "",
                  "no_discount": 0,
                  "order_id": 0,
                  "original_price": "",
                  "parent_item": "",
                  "parent_item_id": 0,
                  "price": "",
                  "price_incl_tax": "",
                  "product_id": 0,
                  "product_option": {
                    "extension_attributes": {
                      "bundle_options": [
                        {
                          "extension_attributes": {},
                          "option_id": 0,
                          "option_qty": 0,
                          "option_selections": []
                        }
                      ],
                      "configurable_item_options": [
                        {
                          "extension_attributes": {},
                          "option_id": "",
                          "option_value": 0
                        }
                      ],
                      "custom_options": [
                        {
                          "extension_attributes": {
                            "file_info": {
                              "base64_encoded_data": "",
                              "name": "",
                              "type": ""
                            }
                          },
                          "option_id": "",
                          "option_value": ""
                        }
                      ],
                      "downloadable_option": {
                        "downloadable_links": []
                      },
                      "giftcard_item_option": {
                        "custom_giftcard_amount": "",
                        "extension_attributes": {},
                        "giftcard_amount": "",
                        "giftcard_message": "",
                        "giftcard_recipient_email": "",
                        "giftcard_recipient_name": "",
                        "giftcard_sender_email": "",
                        "giftcard_sender_name": ""
                      }
                    }
                  },
                  "product_type": "",
                  "qty_backordered": "",
                  "qty_canceled": "",
                  "qty_invoiced": "",
                  "qty_ordered": "",
                  "qty_refunded": "",
                  "qty_returned": "",
                  "qty_shipped": "",
                  "quote_item_id": 0,
                  "row_invoiced": "",
                  "row_total": "",
                  "row_total_incl_tax": "",
                  "row_weight": "",
                  "sku": "",
                  "store_id": 0,
                  "tax_amount": "",
                  "tax_before_discount": "",
                  "tax_canceled": "",
                  "tax_invoiced": "",
                  "tax_percent": "",
                  "tax_refunded": "",
                  "updated_at": "",
                  "weee_tax_applied": "",
                  "weee_tax_applied_amount": "",
                  "weee_tax_applied_row_amount": "",
                  "weee_tax_disposition": "",
                  "weee_tax_row_disposition": "",
                  "weight": ""
                }
              ],
              "shipping": {
                "address": {},
                "extension_attributes": {
                  "collection_point": {
                    "city": "",
                    "collection_point_id": "",
                    "country": "",
                    "name": "",
                    "postcode": "",
                    "recipient_address_id": 0,
                    "region": "",
                    "street": []
                  },
                  "ext_order_id": "",
                  "shipping_experience": {
                    "code": "",
                    "cost": "",
                    "label": ""
                  }
                },
                "method": "",
                "total": {
                  "base_shipping_amount": "",
                  "base_shipping_canceled": "",
                  "base_shipping_discount_amount": "",
                  "base_shipping_discount_tax_compensation_amnt": "",
                  "base_shipping_incl_tax": "",
                  "base_shipping_invoiced": "",
                  "base_shipping_refunded": "",
                  "base_shipping_tax_amount": "",
                  "base_shipping_tax_refunded": "",
                  "extension_attributes": {},
                  "shipping_amount": "",
                  "shipping_canceled": "",
                  "shipping_discount_amount": "",
                  "shipping_discount_tax_compensation_amount": "",
                  "shipping_incl_tax": "",
                  "shipping_invoiced": "",
                  "shipping_refunded": "",
                  "shipping_tax_amount": "",
                  "shipping_tax_refunded": ""
                }
              },
              "stock_id": 0
            }
          ]
        },
        "forced_shipment_with_invoice": 0,
        "global_currency_code": "",
        "grand_total": "",
        "hold_before_state": "",
        "hold_before_status": "",
        "increment_id": "",
        "is_virtual": 0,
        "items": [
          {}
        ],
        "order_currency_code": "",
        "original_increment_id": "",
        "payment": {
          "account_status": "",
          "additional_data": "",
          "additional_information": [],
          "address_status": "",
          "amount_authorized": "",
          "amount_canceled": "",
          "amount_ordered": "",
          "amount_paid": "",
          "amount_refunded": "",
          "anet_trans_method": "",
          "base_amount_authorized": "",
          "base_amount_canceled": "",
          "base_amount_ordered": "",
          "base_amount_paid": "",
          "base_amount_paid_online": "",
          "base_amount_refunded": "",
          "base_amount_refunded_online": "",
          "base_shipping_amount": "",
          "base_shipping_captured": "",
          "base_shipping_refunded": "",
          "cc_approval": "",
          "cc_avs_status": "",
          "cc_cid_status": "",
          "cc_debug_request_body": "",
          "cc_debug_response_body": "",
          "cc_debug_response_serialized": "",
          "cc_exp_month": "",
          "cc_exp_year": "",
          "cc_last4": "",
          "cc_number_enc": "",
          "cc_owner": "",
          "cc_secure_verify": "",
          "cc_ss_issue": "",
          "cc_ss_start_month": "",
          "cc_ss_start_year": "",
          "cc_status": "",
          "cc_status_description": "",
          "cc_trans_id": "",
          "cc_type": "",
          "echeck_account_name": "",
          "echeck_account_type": "",
          "echeck_bank_name": "",
          "echeck_routing_number": "",
          "echeck_type": "",
          "entity_id": 0,
          "extension_attributes": {
            "vault_payment_token": {
              "created_at": "",
              "customer_id": 0,
              "entity_id": 0,
              "expires_at": "",
              "gateway_token": "",
              "is_active": false,
              "is_visible": false,
              "payment_method_code": "",
              "public_hash": "",
              "token_details": "",
              "type": ""
            }
          },
          "last_trans_id": "",
          "method": "",
          "parent_id": 0,
          "po_number": "",
          "protection_eligibility": "",
          "quote_payment_id": 0,
          "shipping_amount": "",
          "shipping_captured": "",
          "shipping_refunded": ""
        },
        "payment_auth_expiration": 0,
        "payment_authorization_amount": "",
        "protect_code": "",
        "quote_address_id": 0,
        "quote_id": 0,
        "relation_child_id": "",
        "relation_child_real_id": "",
        "relation_parent_id": "",
        "relation_parent_real_id": "",
        "remote_ip": "",
        "shipping_amount": "",
        "shipping_canceled": "",
        "shipping_description": "",
        "shipping_discount_amount": "",
        "shipping_discount_tax_compensation_amount": "",
        "shipping_incl_tax": "",
        "shipping_invoiced": "",
        "shipping_refunded": "",
        "shipping_tax_amount": "",
        "shipping_tax_refunded": "",
        "state": "",
        "status": "",
        "status_histories": [
          {
            "comment": "",
            "created_at": "",
            "entity_id": 0,
            "entity_name": "",
            "extension_attributes": {},
            "is_customer_notified": 0,
            "is_visible_on_front": 0,
            "parent_id": 0,
            "status": ""
          }
        ],
        "store_currency_code": "",
        "store_id": 0,
        "store_name": "",
        "store_to_base_rate": "",
        "store_to_order_rate": "",
        "subtotal": "",
        "subtotal_canceled": "",
        "subtotal_incl_tax": "",
        "subtotal_invoiced": "",
        "subtotal_refunded": "",
        "tax_amount": "",
        "tax_canceled": "",
        "tax_invoiced": "",
        "tax_refunded": "",
        "total_canceled": "",
        "total_due": "",
        "total_invoiced": "",
        "total_item_count": 0,
        "total_offline_refunded": "",
        "total_online_refunded": "",
        "total_paid": "",
        "total_qty_ordered": "",
        "total_refunded": "",
        "updated_at": "",
        "weight": "",
        "x_forwarded_for": ""
      },
      "vertex_tax_calculation_shipping_address": {}
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "is_used_for_refund": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "total_qty": "",
    "transaction_id": "",
    "updated_at": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/invoices/")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"entity\": {\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address_id\": 0,\n    \"can_void_flag\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"vertex_tax_calculation_billing_address\": {\n        \"address_type\": \"\",\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"customer_address_id\": 0,\n        \"customer_id\": 0,\n        \"email\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"checkout_fields\": [\n            {\n              \"attribute_code\": \"\",\n              \"value\": \"\"\n            }\n          ]\n        },\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"parent_id\": 0,\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": \"\",\n        \"region_code\": \"\",\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\",\n        \"vat_is_valid\": 0,\n        \"vat_request_date\": \"\",\n        \"vat_request_id\": \"\",\n        \"vat_request_success\": 0\n      },\n      \"vertex_tax_calculation_order\": {\n        \"adjustment_negative\": \"\",\n        \"adjustment_positive\": \"\",\n        \"applied_rule_ids\": \"\",\n        \"base_adjustment_negative\": \"\",\n        \"base_adjustment_positive\": \"\",\n        \"base_currency_code\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_canceled\": \"\",\n        \"base_discount_invoiced\": \"\",\n        \"base_discount_refunded\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_discount_tax_compensation_invoiced\": \"\",\n        \"base_discount_tax_compensation_refunded\": \"\",\n        \"base_grand_total\": \"\",\n        \"base_shipping_amount\": \"\",\n        \"base_shipping_canceled\": \"\",\n        \"base_shipping_discount_amount\": \"\",\n        \"base_shipping_discount_tax_compensation_amnt\": \"\",\n        \"base_shipping_incl_tax\": \"\",\n        \"base_shipping_invoiced\": \"\",\n        \"base_shipping_refunded\": \"\",\n        \"base_shipping_tax_amount\": \"\",\n        \"base_shipping_tax_refunded\": \"\",\n        \"base_subtotal\": \"\",\n        \"base_subtotal_canceled\": \"\",\n        \"base_subtotal_incl_tax\": \"\",\n        \"base_subtotal_invoiced\": \"\",\n        \"base_subtotal_refunded\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_tax_canceled\": \"\",\n        \"base_tax_invoiced\": \"\",\n        \"base_tax_refunded\": \"\",\n        \"base_to_global_rate\": \"\",\n        \"base_to_order_rate\": \"\",\n        \"base_total_canceled\": \"\",\n        \"base_total_due\": \"\",\n        \"base_total_invoiced\": \"\",\n        \"base_total_invoiced_cost\": \"\",\n        \"base_total_offline_refunded\": \"\",\n        \"base_total_online_refunded\": \"\",\n        \"base_total_paid\": \"\",\n        \"base_total_qty_ordered\": \"\",\n        \"base_total_refunded\": \"\",\n        \"billing_address\": {},\n        \"billing_address_id\": 0,\n        \"can_ship_partially\": 0,\n        \"can_ship_partially_item\": 0,\n        \"coupon_code\": \"\",\n        \"created_at\": \"\",\n        \"customer_dob\": \"\",\n        \"customer_email\": \"\",\n        \"customer_firstname\": \"\",\n        \"customer_gender\": 0,\n        \"customer_group_id\": 0,\n        \"customer_id\": 0,\n        \"customer_is_guest\": 0,\n        \"customer_lastname\": \"\",\n        \"customer_middlename\": \"\",\n        \"customer_note\": \"\",\n        \"customer_note_notify\": 0,\n        \"customer_prefix\": \"\",\n        \"customer_suffix\": \"\",\n        \"customer_taxvat\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_canceled\": \"\",\n        \"discount_description\": \"\",\n        \"discount_invoiced\": \"\",\n        \"discount_refunded\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"discount_tax_compensation_invoiced\": \"\",\n        \"discount_tax_compensation_refunded\": \"\",\n        \"edit_increment\": 0,\n        \"email_sent\": 0,\n        \"entity_id\": 0,\n        \"ext_customer_id\": \"\",\n        \"ext_order_id\": \"\",\n        \"extension_attributes\": {\n          \"amazon_order_reference_id\": \"\",\n          \"applied_taxes\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"extension_attributes\": {\n                \"rates\": [\n                  {\n                    \"code\": \"\",\n                    \"extension_attributes\": {},\n                    \"percent\": \"\",\n                    \"title\": \"\"\n                  }\n                ]\n              },\n              \"percent\": \"\",\n              \"title\": \"\"\n            }\n          ],\n          \"base_customer_balance_amount\": \"\",\n          \"base_customer_balance_invoiced\": \"\",\n          \"base_customer_balance_refunded\": \"\",\n          \"base_customer_balance_total_refunded\": \"\",\n          \"base_gift_cards_amount\": \"\",\n          \"base_gift_cards_invoiced\": \"\",\n          \"base_gift_cards_refunded\": \"\",\n          \"base_reward_currency_amount\": \"\",\n          \"company_order_attributes\": {\n            \"company_id\": 0,\n            \"company_name\": \"\",\n            \"extension_attributes\": {},\n            \"order_id\": 0\n          },\n          \"converting_from_quote\": false,\n          \"customer_balance_amount\": \"\",\n          \"customer_balance_invoiced\": \"\",\n          \"customer_balance_refunded\": \"\",\n          \"customer_balance_total_refunded\": \"\",\n          \"gift_cards\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"id\": 0\n            }\n          ],\n          \"gift_cards_amount\": \"\",\n          \"gift_cards_invoiced\": \"\",\n          \"gift_cards_refunded\": \"\",\n          \"gift_message\": {\n            \"customer_id\": 0,\n            \"extension_attributes\": {\n              \"entity_id\": \"\",\n              \"entity_type\": \"\",\n              \"wrapping_add_printed_card\": false,\n              \"wrapping_allow_gift_receipt\": false,\n              \"wrapping_id\": 0\n            },\n            \"gift_message_id\": 0,\n            \"message\": \"\",\n            \"recipient\": \"\",\n            \"sender\": \"\"\n          },\n          \"gw_add_card\": \"\",\n          \"gw_allow_gift_receipt\": \"\",\n          \"gw_base_price\": \"\",\n          \"gw_base_price_incl_tax\": \"\",\n          \"gw_base_price_invoiced\": \"\",\n          \"gw_base_price_refunded\": \"\",\n          \"gw_base_tax_amount\": \"\",\n          \"gw_base_tax_amount_invoiced\": \"\",\n          \"gw_base_tax_amount_refunded\": \"\",\n          \"gw_card_base_price\": \"\",\n          \"gw_card_base_price_incl_tax\": \"\",\n          \"gw_card_base_price_invoiced\": \"\",\n          \"gw_card_base_price_refunded\": \"\",\n          \"gw_card_base_tax_amount\": \"\",\n          \"gw_card_base_tax_invoiced\": \"\",\n          \"gw_card_base_tax_refunded\": \"\",\n          \"gw_card_price\": \"\",\n          \"gw_card_price_incl_tax\": \"\",\n          \"gw_card_price_invoiced\": \"\",\n          \"gw_card_price_refunded\": \"\",\n          \"gw_card_tax_amount\": \"\",\n          \"gw_card_tax_invoiced\": \"\",\n          \"gw_card_tax_refunded\": \"\",\n          \"gw_id\": \"\",\n          \"gw_items_base_price\": \"\",\n          \"gw_items_base_price_incl_tax\": \"\",\n          \"gw_items_base_price_invoiced\": \"\",\n          \"gw_items_base_price_refunded\": \"\",\n          \"gw_items_base_tax_amount\": \"\",\n          \"gw_items_base_tax_invoiced\": \"\",\n          \"gw_items_base_tax_refunded\": \"\",\n          \"gw_items_price\": \"\",\n          \"gw_items_price_incl_tax\": \"\",\n          \"gw_items_price_invoiced\": \"\",\n          \"gw_items_price_refunded\": \"\",\n          \"gw_items_tax_amount\": \"\",\n          \"gw_items_tax_invoiced\": \"\",\n          \"gw_items_tax_refunded\": \"\",\n          \"gw_price\": \"\",\n          \"gw_price_incl_tax\": \"\",\n          \"gw_price_invoiced\": \"\",\n          \"gw_price_refunded\": \"\",\n          \"gw_tax_amount\": \"\",\n          \"gw_tax_amount_invoiced\": \"\",\n          \"gw_tax_amount_refunded\": \"\",\n          \"item_applied_taxes\": [\n            {\n              \"applied_taxes\": [\n                {}\n              ],\n              \"associated_item_id\": 0,\n              \"extension_attributes\": {},\n              \"item_id\": 0,\n              \"type\": \"\"\n            }\n          ],\n          \"payment_additional_info\": [\n            {\n              \"key\": \"\",\n              \"value\": \"\"\n            }\n          ],\n          \"reward_currency_amount\": \"\",\n          \"reward_points_balance\": 0,\n          \"shipping_assignments\": [\n            {\n              \"extension_attributes\": {},\n              \"items\": [\n                {\n                  \"additional_data\": \"\",\n                  \"amount_refunded\": \"\",\n                  \"applied_rule_ids\": \"\",\n                  \"base_amount_refunded\": \"\",\n                  \"base_cost\": \"\",\n                  \"base_discount_amount\": \"\",\n                  \"base_discount_invoiced\": \"\",\n                  \"base_discount_refunded\": \"\",\n                  \"base_discount_tax_compensation_amount\": \"\",\n                  \"base_discount_tax_compensation_invoiced\": \"\",\n                  \"base_discount_tax_compensation_refunded\": \"\",\n                  \"base_original_price\": \"\",\n                  \"base_price\": \"\",\n                  \"base_price_incl_tax\": \"\",\n                  \"base_row_invoiced\": \"\",\n                  \"base_row_total\": \"\",\n                  \"base_row_total_incl_tax\": \"\",\n                  \"base_tax_amount\": \"\",\n                  \"base_tax_before_discount\": \"\",\n                  \"base_tax_invoiced\": \"\",\n                  \"base_tax_refunded\": \"\",\n                  \"base_weee_tax_applied_amount\": \"\",\n                  \"base_weee_tax_applied_row_amnt\": \"\",\n                  \"base_weee_tax_disposition\": \"\",\n                  \"base_weee_tax_row_disposition\": \"\",\n                  \"created_at\": \"\",\n                  \"description\": \"\",\n                  \"discount_amount\": \"\",\n                  \"discount_invoiced\": \"\",\n                  \"discount_percent\": \"\",\n                  \"discount_refunded\": \"\",\n                  \"discount_tax_compensation_amount\": \"\",\n                  \"discount_tax_compensation_canceled\": \"\",\n                  \"discount_tax_compensation_invoiced\": \"\",\n                  \"discount_tax_compensation_refunded\": \"\",\n                  \"event_id\": 0,\n                  \"ext_order_item_id\": \"\",\n                  \"extension_attributes\": {\n                    \"gift_message\": {},\n                    \"gw_base_price\": \"\",\n                    \"gw_base_price_invoiced\": \"\",\n                    \"gw_base_price_refunded\": \"\",\n                    \"gw_base_tax_amount\": \"\",\n                    \"gw_base_tax_amount_invoiced\": \"\",\n                    \"gw_base_tax_amount_refunded\": \"\",\n                    \"gw_id\": \"\",\n                    \"gw_price\": \"\",\n                    \"gw_price_invoiced\": \"\",\n                    \"gw_price_refunded\": \"\",\n                    \"gw_tax_amount\": \"\",\n                    \"gw_tax_amount_invoiced\": \"\",\n                    \"gw_tax_amount_refunded\": \"\",\n                    \"invoice_text_codes\": [],\n                    \"tax_codes\": [],\n                    \"vertex_tax_codes\": []\n                  },\n                  \"free_shipping\": 0,\n                  \"gw_base_price\": \"\",\n                  \"gw_base_price_invoiced\": \"\",\n                  \"gw_base_price_refunded\": \"\",\n                  \"gw_base_tax_amount\": \"\",\n                  \"gw_base_tax_amount_invoiced\": \"\",\n                  \"gw_base_tax_amount_refunded\": \"\",\n                  \"gw_id\": 0,\n                  \"gw_price\": \"\",\n                  \"gw_price_invoiced\": \"\",\n                  \"gw_price_refunded\": \"\",\n                  \"gw_tax_amount\": \"\",\n                  \"gw_tax_amount_invoiced\": \"\",\n                  \"gw_tax_amount_refunded\": \"\",\n                  \"is_qty_decimal\": 0,\n                  \"is_virtual\": 0,\n                  \"item_id\": 0,\n                  \"locked_do_invoice\": 0,\n                  \"locked_do_ship\": 0,\n                  \"name\": \"\",\n                  \"no_discount\": 0,\n                  \"order_id\": 0,\n                  \"original_price\": \"\",\n                  \"parent_item\": \"\",\n                  \"parent_item_id\": 0,\n                  \"price\": \"\",\n                  \"price_incl_tax\": \"\",\n                  \"product_id\": 0,\n                  \"product_option\": {\n                    \"extension_attributes\": {\n                      \"bundle_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": 0,\n                          \"option_qty\": 0,\n                          \"option_selections\": []\n                        }\n                      ],\n                      \"configurable_item_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": \"\",\n                          \"option_value\": 0\n                        }\n                      ],\n                      \"custom_options\": [\n                        {\n                          \"extension_attributes\": {\n                            \"file_info\": {\n                              \"base64_encoded_data\": \"\",\n                              \"name\": \"\",\n                              \"type\": \"\"\n                            }\n                          },\n                          \"option_id\": \"\",\n                          \"option_value\": \"\"\n                        }\n                      ],\n                      \"downloadable_option\": {\n                        \"downloadable_links\": []\n                      },\n                      \"giftcard_item_option\": {\n                        \"custom_giftcard_amount\": \"\",\n                        \"extension_attributes\": {},\n                        \"giftcard_amount\": \"\",\n                        \"giftcard_message\": \"\",\n                        \"giftcard_recipient_email\": \"\",\n                        \"giftcard_recipient_name\": \"\",\n                        \"giftcard_sender_email\": \"\",\n                        \"giftcard_sender_name\": \"\"\n                      }\n                    }\n                  },\n                  \"product_type\": \"\",\n                  \"qty_backordered\": \"\",\n                  \"qty_canceled\": \"\",\n                  \"qty_invoiced\": \"\",\n                  \"qty_ordered\": \"\",\n                  \"qty_refunded\": \"\",\n                  \"qty_returned\": \"\",\n                  \"qty_shipped\": \"\",\n                  \"quote_item_id\": 0,\n                  \"row_invoiced\": \"\",\n                  \"row_total\": \"\",\n                  \"row_total_incl_tax\": \"\",\n                  \"row_weight\": \"\",\n                  \"sku\": \"\",\n                  \"store_id\": 0,\n                  \"tax_amount\": \"\",\n                  \"tax_before_discount\": \"\",\n                  \"tax_canceled\": \"\",\n                  \"tax_invoiced\": \"\",\n                  \"tax_percent\": \"\",\n                  \"tax_refunded\": \"\",\n                  \"updated_at\": \"\",\n                  \"weee_tax_applied\": \"\",\n                  \"weee_tax_applied_amount\": \"\",\n                  \"weee_tax_applied_row_amount\": \"\",\n                  \"weee_tax_disposition\": \"\",\n                  \"weee_tax_row_disposition\": \"\",\n                  \"weight\": \"\"\n                }\n              ],\n              \"shipping\": {\n                \"address\": {},\n                \"extension_attributes\": {\n                  \"collection_point\": {\n                    \"city\": \"\",\n                    \"collection_point_id\": \"\",\n                    \"country\": \"\",\n                    \"name\": \"\",\n                    \"postcode\": \"\",\n                    \"recipient_address_id\": 0,\n                    \"region\": \"\",\n                    \"street\": []\n                  },\n                  \"ext_order_id\": \"\",\n                  \"shipping_experience\": {\n                    \"code\": \"\",\n                    \"cost\": \"\",\n                    \"label\": \"\"\n                  }\n                },\n                \"method\": \"\",\n                \"total\": {\n                  \"base_shipping_amount\": \"\",\n                  \"base_shipping_canceled\": \"\",\n                  \"base_shipping_discount_amount\": \"\",\n                  \"base_shipping_discount_tax_compensation_amnt\": \"\",\n                  \"base_shipping_incl_tax\": \"\",\n                  \"base_shipping_invoiced\": \"\",\n                  \"base_shipping_refunded\": \"\",\n                  \"base_shipping_tax_amount\": \"\",\n                  \"base_shipping_tax_refunded\": \"\",\n                  \"extension_attributes\": {},\n                  \"shipping_amount\": \"\",\n                  \"shipping_canceled\": \"\",\n                  \"shipping_discount_amount\": \"\",\n                  \"shipping_discount_tax_compensation_amount\": \"\",\n                  \"shipping_incl_tax\": \"\",\n                  \"shipping_invoiced\": \"\",\n                  \"shipping_refunded\": \"\",\n                  \"shipping_tax_amount\": \"\",\n                  \"shipping_tax_refunded\": \"\"\n                }\n              },\n              \"stock_id\": 0\n            }\n          ]\n        },\n        \"forced_shipment_with_invoice\": 0,\n        \"global_currency_code\": \"\",\n        \"grand_total\": \"\",\n        \"hold_before_state\": \"\",\n        \"hold_before_status\": \"\",\n        \"increment_id\": \"\",\n        \"is_virtual\": 0,\n        \"items\": [\n          {}\n        ],\n        \"order_currency_code\": \"\",\n        \"original_increment_id\": \"\",\n        \"payment\": {\n          \"account_status\": \"\",\n          \"additional_data\": \"\",\n          \"additional_information\": [],\n          \"address_status\": \"\",\n          \"amount_authorized\": \"\",\n          \"amount_canceled\": \"\",\n          \"amount_ordered\": \"\",\n          \"amount_paid\": \"\",\n          \"amount_refunded\": \"\",\n          \"anet_trans_method\": \"\",\n          \"base_amount_authorized\": \"\",\n          \"base_amount_canceled\": \"\",\n          \"base_amount_ordered\": \"\",\n          \"base_amount_paid\": \"\",\n          \"base_amount_paid_online\": \"\",\n          \"base_amount_refunded\": \"\",\n          \"base_amount_refunded_online\": \"\",\n          \"base_shipping_amount\": \"\",\n          \"base_shipping_captured\": \"\",\n          \"base_shipping_refunded\": \"\",\n          \"cc_approval\": \"\",\n          \"cc_avs_status\": \"\",\n          \"cc_cid_status\": \"\",\n          \"cc_debug_request_body\": \"\",\n          \"cc_debug_response_body\": \"\",\n          \"cc_debug_response_serialized\": \"\",\n          \"cc_exp_month\": \"\",\n          \"cc_exp_year\": \"\",\n          \"cc_last4\": \"\",\n          \"cc_number_enc\": \"\",\n          \"cc_owner\": \"\",\n          \"cc_secure_verify\": \"\",\n          \"cc_ss_issue\": \"\",\n          \"cc_ss_start_month\": \"\",\n          \"cc_ss_start_year\": \"\",\n          \"cc_status\": \"\",\n          \"cc_status_description\": \"\",\n          \"cc_trans_id\": \"\",\n          \"cc_type\": \"\",\n          \"echeck_account_name\": \"\",\n          \"echeck_account_type\": \"\",\n          \"echeck_bank_name\": \"\",\n          \"echeck_routing_number\": \"\",\n          \"echeck_type\": \"\",\n          \"entity_id\": 0,\n          \"extension_attributes\": {\n            \"vault_payment_token\": {\n              \"created_at\": \"\",\n              \"customer_id\": 0,\n              \"entity_id\": 0,\n              \"expires_at\": \"\",\n              \"gateway_token\": \"\",\n              \"is_active\": false,\n              \"is_visible\": false,\n              \"payment_method_code\": \"\",\n              \"public_hash\": \"\",\n              \"token_details\": \"\",\n              \"type\": \"\"\n            }\n          },\n          \"last_trans_id\": \"\",\n          \"method\": \"\",\n          \"parent_id\": 0,\n          \"po_number\": \"\",\n          \"protection_eligibility\": \"\",\n          \"quote_payment_id\": 0,\n          \"shipping_amount\": \"\",\n          \"shipping_captured\": \"\",\n          \"shipping_refunded\": \"\"\n        },\n        \"payment_auth_expiration\": 0,\n        \"payment_authorization_amount\": \"\",\n        \"protect_code\": \"\",\n        \"quote_address_id\": 0,\n        \"quote_id\": 0,\n        \"relation_child_id\": \"\",\n        \"relation_child_real_id\": \"\",\n        \"relation_parent_id\": \"\",\n        \"relation_parent_real_id\": \"\",\n        \"remote_ip\": \"\",\n        \"shipping_amount\": \"\",\n        \"shipping_canceled\": \"\",\n        \"shipping_description\": \"\",\n        \"shipping_discount_amount\": \"\",\n        \"shipping_discount_tax_compensation_amount\": \"\",\n        \"shipping_incl_tax\": \"\",\n        \"shipping_invoiced\": \"\",\n        \"shipping_refunded\": \"\",\n        \"shipping_tax_amount\": \"\",\n        \"shipping_tax_refunded\": \"\",\n        \"state\": \"\",\n        \"status\": \"\",\n        \"status_histories\": [\n          {\n            \"comment\": \"\",\n            \"created_at\": \"\",\n            \"entity_id\": 0,\n            \"entity_name\": \"\",\n            \"extension_attributes\": {},\n            \"is_customer_notified\": 0,\n            \"is_visible_on_front\": 0,\n            \"parent_id\": 0,\n            \"status\": \"\"\n          }\n        ],\n        \"store_currency_code\": \"\",\n        \"store_id\": 0,\n        \"store_name\": \"\",\n        \"store_to_base_rate\": \"\",\n        \"store_to_order_rate\": \"\",\n        \"subtotal\": \"\",\n        \"subtotal_canceled\": \"\",\n        \"subtotal_incl_tax\": \"\",\n        \"subtotal_invoiced\": \"\",\n        \"subtotal_refunded\": \"\",\n        \"tax_amount\": \"\",\n        \"tax_canceled\": \"\",\n        \"tax_invoiced\": \"\",\n        \"tax_refunded\": \"\",\n        \"total_canceled\": \"\",\n        \"total_due\": \"\",\n        \"total_invoiced\": \"\",\n        \"total_item_count\": 0,\n        \"total_offline_refunded\": \"\",\n        \"total_online_refunded\": \"\",\n        \"total_paid\": \"\",\n        \"total_qty_ordered\": \"\",\n        \"total_refunded\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\",\n        \"x_forwarded_for\": \"\"\n      },\n      \"vertex_tax_calculation_shipping_address\": {}\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"is_used_for_refund\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"total_qty\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/invoices/"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"entity\": {\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address_id\": 0,\n    \"can_void_flag\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"vertex_tax_calculation_billing_address\": {\n        \"address_type\": \"\",\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"customer_address_id\": 0,\n        \"customer_id\": 0,\n        \"email\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"checkout_fields\": [\n            {\n              \"attribute_code\": \"\",\n              \"value\": \"\"\n            }\n          ]\n        },\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"parent_id\": 0,\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": \"\",\n        \"region_code\": \"\",\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\",\n        \"vat_is_valid\": 0,\n        \"vat_request_date\": \"\",\n        \"vat_request_id\": \"\",\n        \"vat_request_success\": 0\n      },\n      \"vertex_tax_calculation_order\": {\n        \"adjustment_negative\": \"\",\n        \"adjustment_positive\": \"\",\n        \"applied_rule_ids\": \"\",\n        \"base_adjustment_negative\": \"\",\n        \"base_adjustment_positive\": \"\",\n        \"base_currency_code\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_canceled\": \"\",\n        \"base_discount_invoiced\": \"\",\n        \"base_discount_refunded\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_discount_tax_compensation_invoiced\": \"\",\n        \"base_discount_tax_compensation_refunded\": \"\",\n        \"base_grand_total\": \"\",\n        \"base_shipping_amount\": \"\",\n        \"base_shipping_canceled\": \"\",\n        \"base_shipping_discount_amount\": \"\",\n        \"base_shipping_discount_tax_compensation_amnt\": \"\",\n        \"base_shipping_incl_tax\": \"\",\n        \"base_shipping_invoiced\": \"\",\n        \"base_shipping_refunded\": \"\",\n        \"base_shipping_tax_amount\": \"\",\n        \"base_shipping_tax_refunded\": \"\",\n        \"base_subtotal\": \"\",\n        \"base_subtotal_canceled\": \"\",\n        \"base_subtotal_incl_tax\": \"\",\n        \"base_subtotal_invoiced\": \"\",\n        \"base_subtotal_refunded\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_tax_canceled\": \"\",\n        \"base_tax_invoiced\": \"\",\n        \"base_tax_refunded\": \"\",\n        \"base_to_global_rate\": \"\",\n        \"base_to_order_rate\": \"\",\n        \"base_total_canceled\": \"\",\n        \"base_total_due\": \"\",\n        \"base_total_invoiced\": \"\",\n        \"base_total_invoiced_cost\": \"\",\n        \"base_total_offline_refunded\": \"\",\n        \"base_total_online_refunded\": \"\",\n        \"base_total_paid\": \"\",\n        \"base_total_qty_ordered\": \"\",\n        \"base_total_refunded\": \"\",\n        \"billing_address\": {},\n        \"billing_address_id\": 0,\n        \"can_ship_partially\": 0,\n        \"can_ship_partially_item\": 0,\n        \"coupon_code\": \"\",\n        \"created_at\": \"\",\n        \"customer_dob\": \"\",\n        \"customer_email\": \"\",\n        \"customer_firstname\": \"\",\n        \"customer_gender\": 0,\n        \"customer_group_id\": 0,\n        \"customer_id\": 0,\n        \"customer_is_guest\": 0,\n        \"customer_lastname\": \"\",\n        \"customer_middlename\": \"\",\n        \"customer_note\": \"\",\n        \"customer_note_notify\": 0,\n        \"customer_prefix\": \"\",\n        \"customer_suffix\": \"\",\n        \"customer_taxvat\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_canceled\": \"\",\n        \"discount_description\": \"\",\n        \"discount_invoiced\": \"\",\n        \"discount_refunded\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"discount_tax_compensation_invoiced\": \"\",\n        \"discount_tax_compensation_refunded\": \"\",\n        \"edit_increment\": 0,\n        \"email_sent\": 0,\n        \"entity_id\": 0,\n        \"ext_customer_id\": \"\",\n        \"ext_order_id\": \"\",\n        \"extension_attributes\": {\n          \"amazon_order_reference_id\": \"\",\n          \"applied_taxes\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"extension_attributes\": {\n                \"rates\": [\n                  {\n                    \"code\": \"\",\n                    \"extension_attributes\": {},\n                    \"percent\": \"\",\n                    \"title\": \"\"\n                  }\n                ]\n              },\n              \"percent\": \"\",\n              \"title\": \"\"\n            }\n          ],\n          \"base_customer_balance_amount\": \"\",\n          \"base_customer_balance_invoiced\": \"\",\n          \"base_customer_balance_refunded\": \"\",\n          \"base_customer_balance_total_refunded\": \"\",\n          \"base_gift_cards_amount\": \"\",\n          \"base_gift_cards_invoiced\": \"\",\n          \"base_gift_cards_refunded\": \"\",\n          \"base_reward_currency_amount\": \"\",\n          \"company_order_attributes\": {\n            \"company_id\": 0,\n            \"company_name\": \"\",\n            \"extension_attributes\": {},\n            \"order_id\": 0\n          },\n          \"converting_from_quote\": false,\n          \"customer_balance_amount\": \"\",\n          \"customer_balance_invoiced\": \"\",\n          \"customer_balance_refunded\": \"\",\n          \"customer_balance_total_refunded\": \"\",\n          \"gift_cards\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"id\": 0\n            }\n          ],\n          \"gift_cards_amount\": \"\",\n          \"gift_cards_invoiced\": \"\",\n          \"gift_cards_refunded\": \"\",\n          \"gift_message\": {\n            \"customer_id\": 0,\n            \"extension_attributes\": {\n              \"entity_id\": \"\",\n              \"entity_type\": \"\",\n              \"wrapping_add_printed_card\": false,\n              \"wrapping_allow_gift_receipt\": false,\n              \"wrapping_id\": 0\n            },\n            \"gift_message_id\": 0,\n            \"message\": \"\",\n            \"recipient\": \"\",\n            \"sender\": \"\"\n          },\n          \"gw_add_card\": \"\",\n          \"gw_allow_gift_receipt\": \"\",\n          \"gw_base_price\": \"\",\n          \"gw_base_price_incl_tax\": \"\",\n          \"gw_base_price_invoiced\": \"\",\n          \"gw_base_price_refunded\": \"\",\n          \"gw_base_tax_amount\": \"\",\n          \"gw_base_tax_amount_invoiced\": \"\",\n          \"gw_base_tax_amount_refunded\": \"\",\n          \"gw_card_base_price\": \"\",\n          \"gw_card_base_price_incl_tax\": \"\",\n          \"gw_card_base_price_invoiced\": \"\",\n          \"gw_card_base_price_refunded\": \"\",\n          \"gw_card_base_tax_amount\": \"\",\n          \"gw_card_base_tax_invoiced\": \"\",\n          \"gw_card_base_tax_refunded\": \"\",\n          \"gw_card_price\": \"\",\n          \"gw_card_price_incl_tax\": \"\",\n          \"gw_card_price_invoiced\": \"\",\n          \"gw_card_price_refunded\": \"\",\n          \"gw_card_tax_amount\": \"\",\n          \"gw_card_tax_invoiced\": \"\",\n          \"gw_card_tax_refunded\": \"\",\n          \"gw_id\": \"\",\n          \"gw_items_base_price\": \"\",\n          \"gw_items_base_price_incl_tax\": \"\",\n          \"gw_items_base_price_invoiced\": \"\",\n          \"gw_items_base_price_refunded\": \"\",\n          \"gw_items_base_tax_amount\": \"\",\n          \"gw_items_base_tax_invoiced\": \"\",\n          \"gw_items_base_tax_refunded\": \"\",\n          \"gw_items_price\": \"\",\n          \"gw_items_price_incl_tax\": \"\",\n          \"gw_items_price_invoiced\": \"\",\n          \"gw_items_price_refunded\": \"\",\n          \"gw_items_tax_amount\": \"\",\n          \"gw_items_tax_invoiced\": \"\",\n          \"gw_items_tax_refunded\": \"\",\n          \"gw_price\": \"\",\n          \"gw_price_incl_tax\": \"\",\n          \"gw_price_invoiced\": \"\",\n          \"gw_price_refunded\": \"\",\n          \"gw_tax_amount\": \"\",\n          \"gw_tax_amount_invoiced\": \"\",\n          \"gw_tax_amount_refunded\": \"\",\n          \"item_applied_taxes\": [\n            {\n              \"applied_taxes\": [\n                {}\n              ],\n              \"associated_item_id\": 0,\n              \"extension_attributes\": {},\n              \"item_id\": 0,\n              \"type\": \"\"\n            }\n          ],\n          \"payment_additional_info\": [\n            {\n              \"key\": \"\",\n              \"value\": \"\"\n            }\n          ],\n          \"reward_currency_amount\": \"\",\n          \"reward_points_balance\": 0,\n          \"shipping_assignments\": [\n            {\n              \"extension_attributes\": {},\n              \"items\": [\n                {\n                  \"additional_data\": \"\",\n                  \"amount_refunded\": \"\",\n                  \"applied_rule_ids\": \"\",\n                  \"base_amount_refunded\": \"\",\n                  \"base_cost\": \"\",\n                  \"base_discount_amount\": \"\",\n                  \"base_discount_invoiced\": \"\",\n                  \"base_discount_refunded\": \"\",\n                  \"base_discount_tax_compensation_amount\": \"\",\n                  \"base_discount_tax_compensation_invoiced\": \"\",\n                  \"base_discount_tax_compensation_refunded\": \"\",\n                  \"base_original_price\": \"\",\n                  \"base_price\": \"\",\n                  \"base_price_incl_tax\": \"\",\n                  \"base_row_invoiced\": \"\",\n                  \"base_row_total\": \"\",\n                  \"base_row_total_incl_tax\": \"\",\n                  \"base_tax_amount\": \"\",\n                  \"base_tax_before_discount\": \"\",\n                  \"base_tax_invoiced\": \"\",\n                  \"base_tax_refunded\": \"\",\n                  \"base_weee_tax_applied_amount\": \"\",\n                  \"base_weee_tax_applied_row_amnt\": \"\",\n                  \"base_weee_tax_disposition\": \"\",\n                  \"base_weee_tax_row_disposition\": \"\",\n                  \"created_at\": \"\",\n                  \"description\": \"\",\n                  \"discount_amount\": \"\",\n                  \"discount_invoiced\": \"\",\n                  \"discount_percent\": \"\",\n                  \"discount_refunded\": \"\",\n                  \"discount_tax_compensation_amount\": \"\",\n                  \"discount_tax_compensation_canceled\": \"\",\n                  \"discount_tax_compensation_invoiced\": \"\",\n                  \"discount_tax_compensation_refunded\": \"\",\n                  \"event_id\": 0,\n                  \"ext_order_item_id\": \"\",\n                  \"extension_attributes\": {\n                    \"gift_message\": {},\n                    \"gw_base_price\": \"\",\n                    \"gw_base_price_invoiced\": \"\",\n                    \"gw_base_price_refunded\": \"\",\n                    \"gw_base_tax_amount\": \"\",\n                    \"gw_base_tax_amount_invoiced\": \"\",\n                    \"gw_base_tax_amount_refunded\": \"\",\n                    \"gw_id\": \"\",\n                    \"gw_price\": \"\",\n                    \"gw_price_invoiced\": \"\",\n                    \"gw_price_refunded\": \"\",\n                    \"gw_tax_amount\": \"\",\n                    \"gw_tax_amount_invoiced\": \"\",\n                    \"gw_tax_amount_refunded\": \"\",\n                    \"invoice_text_codes\": [],\n                    \"tax_codes\": [],\n                    \"vertex_tax_codes\": []\n                  },\n                  \"free_shipping\": 0,\n                  \"gw_base_price\": \"\",\n                  \"gw_base_price_invoiced\": \"\",\n                  \"gw_base_price_refunded\": \"\",\n                  \"gw_base_tax_amount\": \"\",\n                  \"gw_base_tax_amount_invoiced\": \"\",\n                  \"gw_base_tax_amount_refunded\": \"\",\n                  \"gw_id\": 0,\n                  \"gw_price\": \"\",\n                  \"gw_price_invoiced\": \"\",\n                  \"gw_price_refunded\": \"\",\n                  \"gw_tax_amount\": \"\",\n                  \"gw_tax_amount_invoiced\": \"\",\n                  \"gw_tax_amount_refunded\": \"\",\n                  \"is_qty_decimal\": 0,\n                  \"is_virtual\": 0,\n                  \"item_id\": 0,\n                  \"locked_do_invoice\": 0,\n                  \"locked_do_ship\": 0,\n                  \"name\": \"\",\n                  \"no_discount\": 0,\n                  \"order_id\": 0,\n                  \"original_price\": \"\",\n                  \"parent_item\": \"\",\n                  \"parent_item_id\": 0,\n                  \"price\": \"\",\n                  \"price_incl_tax\": \"\",\n                  \"product_id\": 0,\n                  \"product_option\": {\n                    \"extension_attributes\": {\n                      \"bundle_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": 0,\n                          \"option_qty\": 0,\n                          \"option_selections\": []\n                        }\n                      ],\n                      \"configurable_item_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": \"\",\n                          \"option_value\": 0\n                        }\n                      ],\n                      \"custom_options\": [\n                        {\n                          \"extension_attributes\": {\n                            \"file_info\": {\n                              \"base64_encoded_data\": \"\",\n                              \"name\": \"\",\n                              \"type\": \"\"\n                            }\n                          },\n                          \"option_id\": \"\",\n                          \"option_value\": \"\"\n                        }\n                      ],\n                      \"downloadable_option\": {\n                        \"downloadable_links\": []\n                      },\n                      \"giftcard_item_option\": {\n                        \"custom_giftcard_amount\": \"\",\n                        \"extension_attributes\": {},\n                        \"giftcard_amount\": \"\",\n                        \"giftcard_message\": \"\",\n                        \"giftcard_recipient_email\": \"\",\n                        \"giftcard_recipient_name\": \"\",\n                        \"giftcard_sender_email\": \"\",\n                        \"giftcard_sender_name\": \"\"\n                      }\n                    }\n                  },\n                  \"product_type\": \"\",\n                  \"qty_backordered\": \"\",\n                  \"qty_canceled\": \"\",\n                  \"qty_invoiced\": \"\",\n                  \"qty_ordered\": \"\",\n                  \"qty_refunded\": \"\",\n                  \"qty_returned\": \"\",\n                  \"qty_shipped\": \"\",\n                  \"quote_item_id\": 0,\n                  \"row_invoiced\": \"\",\n                  \"row_total\": \"\",\n                  \"row_total_incl_tax\": \"\",\n                  \"row_weight\": \"\",\n                  \"sku\": \"\",\n                  \"store_id\": 0,\n                  \"tax_amount\": \"\",\n                  \"tax_before_discount\": \"\",\n                  \"tax_canceled\": \"\",\n                  \"tax_invoiced\": \"\",\n                  \"tax_percent\": \"\",\n                  \"tax_refunded\": \"\",\n                  \"updated_at\": \"\",\n                  \"weee_tax_applied\": \"\",\n                  \"weee_tax_applied_amount\": \"\",\n                  \"weee_tax_applied_row_amount\": \"\",\n                  \"weee_tax_disposition\": \"\",\n                  \"weee_tax_row_disposition\": \"\",\n                  \"weight\": \"\"\n                }\n              ],\n              \"shipping\": {\n                \"address\": {},\n                \"extension_attributes\": {\n                  \"collection_point\": {\n                    \"city\": \"\",\n                    \"collection_point_id\": \"\",\n                    \"country\": \"\",\n                    \"name\": \"\",\n                    \"postcode\": \"\",\n                    \"recipient_address_id\": 0,\n                    \"region\": \"\",\n                    \"street\": []\n                  },\n                  \"ext_order_id\": \"\",\n                  \"shipping_experience\": {\n                    \"code\": \"\",\n                    \"cost\": \"\",\n                    \"label\": \"\"\n                  }\n                },\n                \"method\": \"\",\n                \"total\": {\n                  \"base_shipping_amount\": \"\",\n                  \"base_shipping_canceled\": \"\",\n                  \"base_shipping_discount_amount\": \"\",\n                  \"base_shipping_discount_tax_compensation_amnt\": \"\",\n                  \"base_shipping_incl_tax\": \"\",\n                  \"base_shipping_invoiced\": \"\",\n                  \"base_shipping_refunded\": \"\",\n                  \"base_shipping_tax_amount\": \"\",\n                  \"base_shipping_tax_refunded\": \"\",\n                  \"extension_attributes\": {},\n                  \"shipping_amount\": \"\",\n                  \"shipping_canceled\": \"\",\n                  \"shipping_discount_amount\": \"\",\n                  \"shipping_discount_tax_compensation_amount\": \"\",\n                  \"shipping_incl_tax\": \"\",\n                  \"shipping_invoiced\": \"\",\n                  \"shipping_refunded\": \"\",\n                  \"shipping_tax_amount\": \"\",\n                  \"shipping_tax_refunded\": \"\"\n                }\n              },\n              \"stock_id\": 0\n            }\n          ]\n        },\n        \"forced_shipment_with_invoice\": 0,\n        \"global_currency_code\": \"\",\n        \"grand_total\": \"\",\n        \"hold_before_state\": \"\",\n        \"hold_before_status\": \"\",\n        \"increment_id\": \"\",\n        \"is_virtual\": 0,\n        \"items\": [\n          {}\n        ],\n        \"order_currency_code\": \"\",\n        \"original_increment_id\": \"\",\n        \"payment\": {\n          \"account_status\": \"\",\n          \"additional_data\": \"\",\n          \"additional_information\": [],\n          \"address_status\": \"\",\n          \"amount_authorized\": \"\",\n          \"amount_canceled\": \"\",\n          \"amount_ordered\": \"\",\n          \"amount_paid\": \"\",\n          \"amount_refunded\": \"\",\n          \"anet_trans_method\": \"\",\n          \"base_amount_authorized\": \"\",\n          \"base_amount_canceled\": \"\",\n          \"base_amount_ordered\": \"\",\n          \"base_amount_paid\": \"\",\n          \"base_amount_paid_online\": \"\",\n          \"base_amount_refunded\": \"\",\n          \"base_amount_refunded_online\": \"\",\n          \"base_shipping_amount\": \"\",\n          \"base_shipping_captured\": \"\",\n          \"base_shipping_refunded\": \"\",\n          \"cc_approval\": \"\",\n          \"cc_avs_status\": \"\",\n          \"cc_cid_status\": \"\",\n          \"cc_debug_request_body\": \"\",\n          \"cc_debug_response_body\": \"\",\n          \"cc_debug_response_serialized\": \"\",\n          \"cc_exp_month\": \"\",\n          \"cc_exp_year\": \"\",\n          \"cc_last4\": \"\",\n          \"cc_number_enc\": \"\",\n          \"cc_owner\": \"\",\n          \"cc_secure_verify\": \"\",\n          \"cc_ss_issue\": \"\",\n          \"cc_ss_start_month\": \"\",\n          \"cc_ss_start_year\": \"\",\n          \"cc_status\": \"\",\n          \"cc_status_description\": \"\",\n          \"cc_trans_id\": \"\",\n          \"cc_type\": \"\",\n          \"echeck_account_name\": \"\",\n          \"echeck_account_type\": \"\",\n          \"echeck_bank_name\": \"\",\n          \"echeck_routing_number\": \"\",\n          \"echeck_type\": \"\",\n          \"entity_id\": 0,\n          \"extension_attributes\": {\n            \"vault_payment_token\": {\n              \"created_at\": \"\",\n              \"customer_id\": 0,\n              \"entity_id\": 0,\n              \"expires_at\": \"\",\n              \"gateway_token\": \"\",\n              \"is_active\": false,\n              \"is_visible\": false,\n              \"payment_method_code\": \"\",\n              \"public_hash\": \"\",\n              \"token_details\": \"\",\n              \"type\": \"\"\n            }\n          },\n          \"last_trans_id\": \"\",\n          \"method\": \"\",\n          \"parent_id\": 0,\n          \"po_number\": \"\",\n          \"protection_eligibility\": \"\",\n          \"quote_payment_id\": 0,\n          \"shipping_amount\": \"\",\n          \"shipping_captured\": \"\",\n          \"shipping_refunded\": \"\"\n        },\n        \"payment_auth_expiration\": 0,\n        \"payment_authorization_amount\": \"\",\n        \"protect_code\": \"\",\n        \"quote_address_id\": 0,\n        \"quote_id\": 0,\n        \"relation_child_id\": \"\",\n        \"relation_child_real_id\": \"\",\n        \"relation_parent_id\": \"\",\n        \"relation_parent_real_id\": \"\",\n        \"remote_ip\": \"\",\n        \"shipping_amount\": \"\",\n        \"shipping_canceled\": \"\",\n        \"shipping_description\": \"\",\n        \"shipping_discount_amount\": \"\",\n        \"shipping_discount_tax_compensation_amount\": \"\",\n        \"shipping_incl_tax\": \"\",\n        \"shipping_invoiced\": \"\",\n        \"shipping_refunded\": \"\",\n        \"shipping_tax_amount\": \"\",\n        \"shipping_tax_refunded\": \"\",\n        \"state\": \"\",\n        \"status\": \"\",\n        \"status_histories\": [\n          {\n            \"comment\": \"\",\n            \"created_at\": \"\",\n            \"entity_id\": 0,\n            \"entity_name\": \"\",\n            \"extension_attributes\": {},\n            \"is_customer_notified\": 0,\n            \"is_visible_on_front\": 0,\n            \"parent_id\": 0,\n            \"status\": \"\"\n          }\n        ],\n        \"store_currency_code\": \"\",\n        \"store_id\": 0,\n        \"store_name\": \"\",\n        \"store_to_base_rate\": \"\",\n        \"store_to_order_rate\": \"\",\n        \"subtotal\": \"\",\n        \"subtotal_canceled\": \"\",\n        \"subtotal_incl_tax\": \"\",\n        \"subtotal_invoiced\": \"\",\n        \"subtotal_refunded\": \"\",\n        \"tax_amount\": \"\",\n        \"tax_canceled\": \"\",\n        \"tax_invoiced\": \"\",\n        \"tax_refunded\": \"\",\n        \"total_canceled\": \"\",\n        \"total_due\": \"\",\n        \"total_invoiced\": \"\",\n        \"total_item_count\": 0,\n        \"total_offline_refunded\": \"\",\n        \"total_online_refunded\": \"\",\n        \"total_paid\": \"\",\n        \"total_qty_ordered\": \"\",\n        \"total_refunded\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\",\n        \"x_forwarded_for\": \"\"\n      },\n      \"vertex_tax_calculation_shipping_address\": {}\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"is_used_for_refund\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"total_qty\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\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  \"entity\": {\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address_id\": 0,\n    \"can_void_flag\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"vertex_tax_calculation_billing_address\": {\n        \"address_type\": \"\",\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"customer_address_id\": 0,\n        \"customer_id\": 0,\n        \"email\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"checkout_fields\": [\n            {\n              \"attribute_code\": \"\",\n              \"value\": \"\"\n            }\n          ]\n        },\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"parent_id\": 0,\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": \"\",\n        \"region_code\": \"\",\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\",\n        \"vat_is_valid\": 0,\n        \"vat_request_date\": \"\",\n        \"vat_request_id\": \"\",\n        \"vat_request_success\": 0\n      },\n      \"vertex_tax_calculation_order\": {\n        \"adjustment_negative\": \"\",\n        \"adjustment_positive\": \"\",\n        \"applied_rule_ids\": \"\",\n        \"base_adjustment_negative\": \"\",\n        \"base_adjustment_positive\": \"\",\n        \"base_currency_code\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_canceled\": \"\",\n        \"base_discount_invoiced\": \"\",\n        \"base_discount_refunded\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_discount_tax_compensation_invoiced\": \"\",\n        \"base_discount_tax_compensation_refunded\": \"\",\n        \"base_grand_total\": \"\",\n        \"base_shipping_amount\": \"\",\n        \"base_shipping_canceled\": \"\",\n        \"base_shipping_discount_amount\": \"\",\n        \"base_shipping_discount_tax_compensation_amnt\": \"\",\n        \"base_shipping_incl_tax\": \"\",\n        \"base_shipping_invoiced\": \"\",\n        \"base_shipping_refunded\": \"\",\n        \"base_shipping_tax_amount\": \"\",\n        \"base_shipping_tax_refunded\": \"\",\n        \"base_subtotal\": \"\",\n        \"base_subtotal_canceled\": \"\",\n        \"base_subtotal_incl_tax\": \"\",\n        \"base_subtotal_invoiced\": \"\",\n        \"base_subtotal_refunded\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_tax_canceled\": \"\",\n        \"base_tax_invoiced\": \"\",\n        \"base_tax_refunded\": \"\",\n        \"base_to_global_rate\": \"\",\n        \"base_to_order_rate\": \"\",\n        \"base_total_canceled\": \"\",\n        \"base_total_due\": \"\",\n        \"base_total_invoiced\": \"\",\n        \"base_total_invoiced_cost\": \"\",\n        \"base_total_offline_refunded\": \"\",\n        \"base_total_online_refunded\": \"\",\n        \"base_total_paid\": \"\",\n        \"base_total_qty_ordered\": \"\",\n        \"base_total_refunded\": \"\",\n        \"billing_address\": {},\n        \"billing_address_id\": 0,\n        \"can_ship_partially\": 0,\n        \"can_ship_partially_item\": 0,\n        \"coupon_code\": \"\",\n        \"created_at\": \"\",\n        \"customer_dob\": \"\",\n        \"customer_email\": \"\",\n        \"customer_firstname\": \"\",\n        \"customer_gender\": 0,\n        \"customer_group_id\": 0,\n        \"customer_id\": 0,\n        \"customer_is_guest\": 0,\n        \"customer_lastname\": \"\",\n        \"customer_middlename\": \"\",\n        \"customer_note\": \"\",\n        \"customer_note_notify\": 0,\n        \"customer_prefix\": \"\",\n        \"customer_suffix\": \"\",\n        \"customer_taxvat\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_canceled\": \"\",\n        \"discount_description\": \"\",\n        \"discount_invoiced\": \"\",\n        \"discount_refunded\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"discount_tax_compensation_invoiced\": \"\",\n        \"discount_tax_compensation_refunded\": \"\",\n        \"edit_increment\": 0,\n        \"email_sent\": 0,\n        \"entity_id\": 0,\n        \"ext_customer_id\": \"\",\n        \"ext_order_id\": \"\",\n        \"extension_attributes\": {\n          \"amazon_order_reference_id\": \"\",\n          \"applied_taxes\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"extension_attributes\": {\n                \"rates\": [\n                  {\n                    \"code\": \"\",\n                    \"extension_attributes\": {},\n                    \"percent\": \"\",\n                    \"title\": \"\"\n                  }\n                ]\n              },\n              \"percent\": \"\",\n              \"title\": \"\"\n            }\n          ],\n          \"base_customer_balance_amount\": \"\",\n          \"base_customer_balance_invoiced\": \"\",\n          \"base_customer_balance_refunded\": \"\",\n          \"base_customer_balance_total_refunded\": \"\",\n          \"base_gift_cards_amount\": \"\",\n          \"base_gift_cards_invoiced\": \"\",\n          \"base_gift_cards_refunded\": \"\",\n          \"base_reward_currency_amount\": \"\",\n          \"company_order_attributes\": {\n            \"company_id\": 0,\n            \"company_name\": \"\",\n            \"extension_attributes\": {},\n            \"order_id\": 0\n          },\n          \"converting_from_quote\": false,\n          \"customer_balance_amount\": \"\",\n          \"customer_balance_invoiced\": \"\",\n          \"customer_balance_refunded\": \"\",\n          \"customer_balance_total_refunded\": \"\",\n          \"gift_cards\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"id\": 0\n            }\n          ],\n          \"gift_cards_amount\": \"\",\n          \"gift_cards_invoiced\": \"\",\n          \"gift_cards_refunded\": \"\",\n          \"gift_message\": {\n            \"customer_id\": 0,\n            \"extension_attributes\": {\n              \"entity_id\": \"\",\n              \"entity_type\": \"\",\n              \"wrapping_add_printed_card\": false,\n              \"wrapping_allow_gift_receipt\": false,\n              \"wrapping_id\": 0\n            },\n            \"gift_message_id\": 0,\n            \"message\": \"\",\n            \"recipient\": \"\",\n            \"sender\": \"\"\n          },\n          \"gw_add_card\": \"\",\n          \"gw_allow_gift_receipt\": \"\",\n          \"gw_base_price\": \"\",\n          \"gw_base_price_incl_tax\": \"\",\n          \"gw_base_price_invoiced\": \"\",\n          \"gw_base_price_refunded\": \"\",\n          \"gw_base_tax_amount\": \"\",\n          \"gw_base_tax_amount_invoiced\": \"\",\n          \"gw_base_tax_amount_refunded\": \"\",\n          \"gw_card_base_price\": \"\",\n          \"gw_card_base_price_incl_tax\": \"\",\n          \"gw_card_base_price_invoiced\": \"\",\n          \"gw_card_base_price_refunded\": \"\",\n          \"gw_card_base_tax_amount\": \"\",\n          \"gw_card_base_tax_invoiced\": \"\",\n          \"gw_card_base_tax_refunded\": \"\",\n          \"gw_card_price\": \"\",\n          \"gw_card_price_incl_tax\": \"\",\n          \"gw_card_price_invoiced\": \"\",\n          \"gw_card_price_refunded\": \"\",\n          \"gw_card_tax_amount\": \"\",\n          \"gw_card_tax_invoiced\": \"\",\n          \"gw_card_tax_refunded\": \"\",\n          \"gw_id\": \"\",\n          \"gw_items_base_price\": \"\",\n          \"gw_items_base_price_incl_tax\": \"\",\n          \"gw_items_base_price_invoiced\": \"\",\n          \"gw_items_base_price_refunded\": \"\",\n          \"gw_items_base_tax_amount\": \"\",\n          \"gw_items_base_tax_invoiced\": \"\",\n          \"gw_items_base_tax_refunded\": \"\",\n          \"gw_items_price\": \"\",\n          \"gw_items_price_incl_tax\": \"\",\n          \"gw_items_price_invoiced\": \"\",\n          \"gw_items_price_refunded\": \"\",\n          \"gw_items_tax_amount\": \"\",\n          \"gw_items_tax_invoiced\": \"\",\n          \"gw_items_tax_refunded\": \"\",\n          \"gw_price\": \"\",\n          \"gw_price_incl_tax\": \"\",\n          \"gw_price_invoiced\": \"\",\n          \"gw_price_refunded\": \"\",\n          \"gw_tax_amount\": \"\",\n          \"gw_tax_amount_invoiced\": \"\",\n          \"gw_tax_amount_refunded\": \"\",\n          \"item_applied_taxes\": [\n            {\n              \"applied_taxes\": [\n                {}\n              ],\n              \"associated_item_id\": 0,\n              \"extension_attributes\": {},\n              \"item_id\": 0,\n              \"type\": \"\"\n            }\n          ],\n          \"payment_additional_info\": [\n            {\n              \"key\": \"\",\n              \"value\": \"\"\n            }\n          ],\n          \"reward_currency_amount\": \"\",\n          \"reward_points_balance\": 0,\n          \"shipping_assignments\": [\n            {\n              \"extension_attributes\": {},\n              \"items\": [\n                {\n                  \"additional_data\": \"\",\n                  \"amount_refunded\": \"\",\n                  \"applied_rule_ids\": \"\",\n                  \"base_amount_refunded\": \"\",\n                  \"base_cost\": \"\",\n                  \"base_discount_amount\": \"\",\n                  \"base_discount_invoiced\": \"\",\n                  \"base_discount_refunded\": \"\",\n                  \"base_discount_tax_compensation_amount\": \"\",\n                  \"base_discount_tax_compensation_invoiced\": \"\",\n                  \"base_discount_tax_compensation_refunded\": \"\",\n                  \"base_original_price\": \"\",\n                  \"base_price\": \"\",\n                  \"base_price_incl_tax\": \"\",\n                  \"base_row_invoiced\": \"\",\n                  \"base_row_total\": \"\",\n                  \"base_row_total_incl_tax\": \"\",\n                  \"base_tax_amount\": \"\",\n                  \"base_tax_before_discount\": \"\",\n                  \"base_tax_invoiced\": \"\",\n                  \"base_tax_refunded\": \"\",\n                  \"base_weee_tax_applied_amount\": \"\",\n                  \"base_weee_tax_applied_row_amnt\": \"\",\n                  \"base_weee_tax_disposition\": \"\",\n                  \"base_weee_tax_row_disposition\": \"\",\n                  \"created_at\": \"\",\n                  \"description\": \"\",\n                  \"discount_amount\": \"\",\n                  \"discount_invoiced\": \"\",\n                  \"discount_percent\": \"\",\n                  \"discount_refunded\": \"\",\n                  \"discount_tax_compensation_amount\": \"\",\n                  \"discount_tax_compensation_canceled\": \"\",\n                  \"discount_tax_compensation_invoiced\": \"\",\n                  \"discount_tax_compensation_refunded\": \"\",\n                  \"event_id\": 0,\n                  \"ext_order_item_id\": \"\",\n                  \"extension_attributes\": {\n                    \"gift_message\": {},\n                    \"gw_base_price\": \"\",\n                    \"gw_base_price_invoiced\": \"\",\n                    \"gw_base_price_refunded\": \"\",\n                    \"gw_base_tax_amount\": \"\",\n                    \"gw_base_tax_amount_invoiced\": \"\",\n                    \"gw_base_tax_amount_refunded\": \"\",\n                    \"gw_id\": \"\",\n                    \"gw_price\": \"\",\n                    \"gw_price_invoiced\": \"\",\n                    \"gw_price_refunded\": \"\",\n                    \"gw_tax_amount\": \"\",\n                    \"gw_tax_amount_invoiced\": \"\",\n                    \"gw_tax_amount_refunded\": \"\",\n                    \"invoice_text_codes\": [],\n                    \"tax_codes\": [],\n                    \"vertex_tax_codes\": []\n                  },\n                  \"free_shipping\": 0,\n                  \"gw_base_price\": \"\",\n                  \"gw_base_price_invoiced\": \"\",\n                  \"gw_base_price_refunded\": \"\",\n                  \"gw_base_tax_amount\": \"\",\n                  \"gw_base_tax_amount_invoiced\": \"\",\n                  \"gw_base_tax_amount_refunded\": \"\",\n                  \"gw_id\": 0,\n                  \"gw_price\": \"\",\n                  \"gw_price_invoiced\": \"\",\n                  \"gw_price_refunded\": \"\",\n                  \"gw_tax_amount\": \"\",\n                  \"gw_tax_amount_invoiced\": \"\",\n                  \"gw_tax_amount_refunded\": \"\",\n                  \"is_qty_decimal\": 0,\n                  \"is_virtual\": 0,\n                  \"item_id\": 0,\n                  \"locked_do_invoice\": 0,\n                  \"locked_do_ship\": 0,\n                  \"name\": \"\",\n                  \"no_discount\": 0,\n                  \"order_id\": 0,\n                  \"original_price\": \"\",\n                  \"parent_item\": \"\",\n                  \"parent_item_id\": 0,\n                  \"price\": \"\",\n                  \"price_incl_tax\": \"\",\n                  \"product_id\": 0,\n                  \"product_option\": {\n                    \"extension_attributes\": {\n                      \"bundle_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": 0,\n                          \"option_qty\": 0,\n                          \"option_selections\": []\n                        }\n                      ],\n                      \"configurable_item_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": \"\",\n                          \"option_value\": 0\n                        }\n                      ],\n                      \"custom_options\": [\n                        {\n                          \"extension_attributes\": {\n                            \"file_info\": {\n                              \"base64_encoded_data\": \"\",\n                              \"name\": \"\",\n                              \"type\": \"\"\n                            }\n                          },\n                          \"option_id\": \"\",\n                          \"option_value\": \"\"\n                        }\n                      ],\n                      \"downloadable_option\": {\n                        \"downloadable_links\": []\n                      },\n                      \"giftcard_item_option\": {\n                        \"custom_giftcard_amount\": \"\",\n                        \"extension_attributes\": {},\n                        \"giftcard_amount\": \"\",\n                        \"giftcard_message\": \"\",\n                        \"giftcard_recipient_email\": \"\",\n                        \"giftcard_recipient_name\": \"\",\n                        \"giftcard_sender_email\": \"\",\n                        \"giftcard_sender_name\": \"\"\n                      }\n                    }\n                  },\n                  \"product_type\": \"\",\n                  \"qty_backordered\": \"\",\n                  \"qty_canceled\": \"\",\n                  \"qty_invoiced\": \"\",\n                  \"qty_ordered\": \"\",\n                  \"qty_refunded\": \"\",\n                  \"qty_returned\": \"\",\n                  \"qty_shipped\": \"\",\n                  \"quote_item_id\": 0,\n                  \"row_invoiced\": \"\",\n                  \"row_total\": \"\",\n                  \"row_total_incl_tax\": \"\",\n                  \"row_weight\": \"\",\n                  \"sku\": \"\",\n                  \"store_id\": 0,\n                  \"tax_amount\": \"\",\n                  \"tax_before_discount\": \"\",\n                  \"tax_canceled\": \"\",\n                  \"tax_invoiced\": \"\",\n                  \"tax_percent\": \"\",\n                  \"tax_refunded\": \"\",\n                  \"updated_at\": \"\",\n                  \"weee_tax_applied\": \"\",\n                  \"weee_tax_applied_amount\": \"\",\n                  \"weee_tax_applied_row_amount\": \"\",\n                  \"weee_tax_disposition\": \"\",\n                  \"weee_tax_row_disposition\": \"\",\n                  \"weight\": \"\"\n                }\n              ],\n              \"shipping\": {\n                \"address\": {},\n                \"extension_attributes\": {\n                  \"collection_point\": {\n                    \"city\": \"\",\n                    \"collection_point_id\": \"\",\n                    \"country\": \"\",\n                    \"name\": \"\",\n                    \"postcode\": \"\",\n                    \"recipient_address_id\": 0,\n                    \"region\": \"\",\n                    \"street\": []\n                  },\n                  \"ext_order_id\": \"\",\n                  \"shipping_experience\": {\n                    \"code\": \"\",\n                    \"cost\": \"\",\n                    \"label\": \"\"\n                  }\n                },\n                \"method\": \"\",\n                \"total\": {\n                  \"base_shipping_amount\": \"\",\n                  \"base_shipping_canceled\": \"\",\n                  \"base_shipping_discount_amount\": \"\",\n                  \"base_shipping_discount_tax_compensation_amnt\": \"\",\n                  \"base_shipping_incl_tax\": \"\",\n                  \"base_shipping_invoiced\": \"\",\n                  \"base_shipping_refunded\": \"\",\n                  \"base_shipping_tax_amount\": \"\",\n                  \"base_shipping_tax_refunded\": \"\",\n                  \"extension_attributes\": {},\n                  \"shipping_amount\": \"\",\n                  \"shipping_canceled\": \"\",\n                  \"shipping_discount_amount\": \"\",\n                  \"shipping_discount_tax_compensation_amount\": \"\",\n                  \"shipping_incl_tax\": \"\",\n                  \"shipping_invoiced\": \"\",\n                  \"shipping_refunded\": \"\",\n                  \"shipping_tax_amount\": \"\",\n                  \"shipping_tax_refunded\": \"\"\n                }\n              },\n              \"stock_id\": 0\n            }\n          ]\n        },\n        \"forced_shipment_with_invoice\": 0,\n        \"global_currency_code\": \"\",\n        \"grand_total\": \"\",\n        \"hold_before_state\": \"\",\n        \"hold_before_status\": \"\",\n        \"increment_id\": \"\",\n        \"is_virtual\": 0,\n        \"items\": [\n          {}\n        ],\n        \"order_currency_code\": \"\",\n        \"original_increment_id\": \"\",\n        \"payment\": {\n          \"account_status\": \"\",\n          \"additional_data\": \"\",\n          \"additional_information\": [],\n          \"address_status\": \"\",\n          \"amount_authorized\": \"\",\n          \"amount_canceled\": \"\",\n          \"amount_ordered\": \"\",\n          \"amount_paid\": \"\",\n          \"amount_refunded\": \"\",\n          \"anet_trans_method\": \"\",\n          \"base_amount_authorized\": \"\",\n          \"base_amount_canceled\": \"\",\n          \"base_amount_ordered\": \"\",\n          \"base_amount_paid\": \"\",\n          \"base_amount_paid_online\": \"\",\n          \"base_amount_refunded\": \"\",\n          \"base_amount_refunded_online\": \"\",\n          \"base_shipping_amount\": \"\",\n          \"base_shipping_captured\": \"\",\n          \"base_shipping_refunded\": \"\",\n          \"cc_approval\": \"\",\n          \"cc_avs_status\": \"\",\n          \"cc_cid_status\": \"\",\n          \"cc_debug_request_body\": \"\",\n          \"cc_debug_response_body\": \"\",\n          \"cc_debug_response_serialized\": \"\",\n          \"cc_exp_month\": \"\",\n          \"cc_exp_year\": \"\",\n          \"cc_last4\": \"\",\n          \"cc_number_enc\": \"\",\n          \"cc_owner\": \"\",\n          \"cc_secure_verify\": \"\",\n          \"cc_ss_issue\": \"\",\n          \"cc_ss_start_month\": \"\",\n          \"cc_ss_start_year\": \"\",\n          \"cc_status\": \"\",\n          \"cc_status_description\": \"\",\n          \"cc_trans_id\": \"\",\n          \"cc_type\": \"\",\n          \"echeck_account_name\": \"\",\n          \"echeck_account_type\": \"\",\n          \"echeck_bank_name\": \"\",\n          \"echeck_routing_number\": \"\",\n          \"echeck_type\": \"\",\n          \"entity_id\": 0,\n          \"extension_attributes\": {\n            \"vault_payment_token\": {\n              \"created_at\": \"\",\n              \"customer_id\": 0,\n              \"entity_id\": 0,\n              \"expires_at\": \"\",\n              \"gateway_token\": \"\",\n              \"is_active\": false,\n              \"is_visible\": false,\n              \"payment_method_code\": \"\",\n              \"public_hash\": \"\",\n              \"token_details\": \"\",\n              \"type\": \"\"\n            }\n          },\n          \"last_trans_id\": \"\",\n          \"method\": \"\",\n          \"parent_id\": 0,\n          \"po_number\": \"\",\n          \"protection_eligibility\": \"\",\n          \"quote_payment_id\": 0,\n          \"shipping_amount\": \"\",\n          \"shipping_captured\": \"\",\n          \"shipping_refunded\": \"\"\n        },\n        \"payment_auth_expiration\": 0,\n        \"payment_authorization_amount\": \"\",\n        \"protect_code\": \"\",\n        \"quote_address_id\": 0,\n        \"quote_id\": 0,\n        \"relation_child_id\": \"\",\n        \"relation_child_real_id\": \"\",\n        \"relation_parent_id\": \"\",\n        \"relation_parent_real_id\": \"\",\n        \"remote_ip\": \"\",\n        \"shipping_amount\": \"\",\n        \"shipping_canceled\": \"\",\n        \"shipping_description\": \"\",\n        \"shipping_discount_amount\": \"\",\n        \"shipping_discount_tax_compensation_amount\": \"\",\n        \"shipping_incl_tax\": \"\",\n        \"shipping_invoiced\": \"\",\n        \"shipping_refunded\": \"\",\n        \"shipping_tax_amount\": \"\",\n        \"shipping_tax_refunded\": \"\",\n        \"state\": \"\",\n        \"status\": \"\",\n        \"status_histories\": [\n          {\n            \"comment\": \"\",\n            \"created_at\": \"\",\n            \"entity_id\": 0,\n            \"entity_name\": \"\",\n            \"extension_attributes\": {},\n            \"is_customer_notified\": 0,\n            \"is_visible_on_front\": 0,\n            \"parent_id\": 0,\n            \"status\": \"\"\n          }\n        ],\n        \"store_currency_code\": \"\",\n        \"store_id\": 0,\n        \"store_name\": \"\",\n        \"store_to_base_rate\": \"\",\n        \"store_to_order_rate\": \"\",\n        \"subtotal\": \"\",\n        \"subtotal_canceled\": \"\",\n        \"subtotal_incl_tax\": \"\",\n        \"subtotal_invoiced\": \"\",\n        \"subtotal_refunded\": \"\",\n        \"tax_amount\": \"\",\n        \"tax_canceled\": \"\",\n        \"tax_invoiced\": \"\",\n        \"tax_refunded\": \"\",\n        \"total_canceled\": \"\",\n        \"total_due\": \"\",\n        \"total_invoiced\": \"\",\n        \"total_item_count\": 0,\n        \"total_offline_refunded\": \"\",\n        \"total_online_refunded\": \"\",\n        \"total_paid\": \"\",\n        \"total_qty_ordered\": \"\",\n        \"total_refunded\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\",\n        \"x_forwarded_for\": \"\"\n      },\n      \"vertex_tax_calculation_shipping_address\": {}\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"is_used_for_refund\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"total_qty\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/invoices/")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/invoices/")
  .header("content-type", "application/json")
  .body("{\n  \"entity\": {\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address_id\": 0,\n    \"can_void_flag\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"vertex_tax_calculation_billing_address\": {\n        \"address_type\": \"\",\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"customer_address_id\": 0,\n        \"customer_id\": 0,\n        \"email\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"checkout_fields\": [\n            {\n              \"attribute_code\": \"\",\n              \"value\": \"\"\n            }\n          ]\n        },\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"parent_id\": 0,\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": \"\",\n        \"region_code\": \"\",\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\",\n        \"vat_is_valid\": 0,\n        \"vat_request_date\": \"\",\n        \"vat_request_id\": \"\",\n        \"vat_request_success\": 0\n      },\n      \"vertex_tax_calculation_order\": {\n        \"adjustment_negative\": \"\",\n        \"adjustment_positive\": \"\",\n        \"applied_rule_ids\": \"\",\n        \"base_adjustment_negative\": \"\",\n        \"base_adjustment_positive\": \"\",\n        \"base_currency_code\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_canceled\": \"\",\n        \"base_discount_invoiced\": \"\",\n        \"base_discount_refunded\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_discount_tax_compensation_invoiced\": \"\",\n        \"base_discount_tax_compensation_refunded\": \"\",\n        \"base_grand_total\": \"\",\n        \"base_shipping_amount\": \"\",\n        \"base_shipping_canceled\": \"\",\n        \"base_shipping_discount_amount\": \"\",\n        \"base_shipping_discount_tax_compensation_amnt\": \"\",\n        \"base_shipping_incl_tax\": \"\",\n        \"base_shipping_invoiced\": \"\",\n        \"base_shipping_refunded\": \"\",\n        \"base_shipping_tax_amount\": \"\",\n        \"base_shipping_tax_refunded\": \"\",\n        \"base_subtotal\": \"\",\n        \"base_subtotal_canceled\": \"\",\n        \"base_subtotal_incl_tax\": \"\",\n        \"base_subtotal_invoiced\": \"\",\n        \"base_subtotal_refunded\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_tax_canceled\": \"\",\n        \"base_tax_invoiced\": \"\",\n        \"base_tax_refunded\": \"\",\n        \"base_to_global_rate\": \"\",\n        \"base_to_order_rate\": \"\",\n        \"base_total_canceled\": \"\",\n        \"base_total_due\": \"\",\n        \"base_total_invoiced\": \"\",\n        \"base_total_invoiced_cost\": \"\",\n        \"base_total_offline_refunded\": \"\",\n        \"base_total_online_refunded\": \"\",\n        \"base_total_paid\": \"\",\n        \"base_total_qty_ordered\": \"\",\n        \"base_total_refunded\": \"\",\n        \"billing_address\": {},\n        \"billing_address_id\": 0,\n        \"can_ship_partially\": 0,\n        \"can_ship_partially_item\": 0,\n        \"coupon_code\": \"\",\n        \"created_at\": \"\",\n        \"customer_dob\": \"\",\n        \"customer_email\": \"\",\n        \"customer_firstname\": \"\",\n        \"customer_gender\": 0,\n        \"customer_group_id\": 0,\n        \"customer_id\": 0,\n        \"customer_is_guest\": 0,\n        \"customer_lastname\": \"\",\n        \"customer_middlename\": \"\",\n        \"customer_note\": \"\",\n        \"customer_note_notify\": 0,\n        \"customer_prefix\": \"\",\n        \"customer_suffix\": \"\",\n        \"customer_taxvat\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_canceled\": \"\",\n        \"discount_description\": \"\",\n        \"discount_invoiced\": \"\",\n        \"discount_refunded\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"discount_tax_compensation_invoiced\": \"\",\n        \"discount_tax_compensation_refunded\": \"\",\n        \"edit_increment\": 0,\n        \"email_sent\": 0,\n        \"entity_id\": 0,\n        \"ext_customer_id\": \"\",\n        \"ext_order_id\": \"\",\n        \"extension_attributes\": {\n          \"amazon_order_reference_id\": \"\",\n          \"applied_taxes\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"extension_attributes\": {\n                \"rates\": [\n                  {\n                    \"code\": \"\",\n                    \"extension_attributes\": {},\n                    \"percent\": \"\",\n                    \"title\": \"\"\n                  }\n                ]\n              },\n              \"percent\": \"\",\n              \"title\": \"\"\n            }\n          ],\n          \"base_customer_balance_amount\": \"\",\n          \"base_customer_balance_invoiced\": \"\",\n          \"base_customer_balance_refunded\": \"\",\n          \"base_customer_balance_total_refunded\": \"\",\n          \"base_gift_cards_amount\": \"\",\n          \"base_gift_cards_invoiced\": \"\",\n          \"base_gift_cards_refunded\": \"\",\n          \"base_reward_currency_amount\": \"\",\n          \"company_order_attributes\": {\n            \"company_id\": 0,\n            \"company_name\": \"\",\n            \"extension_attributes\": {},\n            \"order_id\": 0\n          },\n          \"converting_from_quote\": false,\n          \"customer_balance_amount\": \"\",\n          \"customer_balance_invoiced\": \"\",\n          \"customer_balance_refunded\": \"\",\n          \"customer_balance_total_refunded\": \"\",\n          \"gift_cards\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"id\": 0\n            }\n          ],\n          \"gift_cards_amount\": \"\",\n          \"gift_cards_invoiced\": \"\",\n          \"gift_cards_refunded\": \"\",\n          \"gift_message\": {\n            \"customer_id\": 0,\n            \"extension_attributes\": {\n              \"entity_id\": \"\",\n              \"entity_type\": \"\",\n              \"wrapping_add_printed_card\": false,\n              \"wrapping_allow_gift_receipt\": false,\n              \"wrapping_id\": 0\n            },\n            \"gift_message_id\": 0,\n            \"message\": \"\",\n            \"recipient\": \"\",\n            \"sender\": \"\"\n          },\n          \"gw_add_card\": \"\",\n          \"gw_allow_gift_receipt\": \"\",\n          \"gw_base_price\": \"\",\n          \"gw_base_price_incl_tax\": \"\",\n          \"gw_base_price_invoiced\": \"\",\n          \"gw_base_price_refunded\": \"\",\n          \"gw_base_tax_amount\": \"\",\n          \"gw_base_tax_amount_invoiced\": \"\",\n          \"gw_base_tax_amount_refunded\": \"\",\n          \"gw_card_base_price\": \"\",\n          \"gw_card_base_price_incl_tax\": \"\",\n          \"gw_card_base_price_invoiced\": \"\",\n          \"gw_card_base_price_refunded\": \"\",\n          \"gw_card_base_tax_amount\": \"\",\n          \"gw_card_base_tax_invoiced\": \"\",\n          \"gw_card_base_tax_refunded\": \"\",\n          \"gw_card_price\": \"\",\n          \"gw_card_price_incl_tax\": \"\",\n          \"gw_card_price_invoiced\": \"\",\n          \"gw_card_price_refunded\": \"\",\n          \"gw_card_tax_amount\": \"\",\n          \"gw_card_tax_invoiced\": \"\",\n          \"gw_card_tax_refunded\": \"\",\n          \"gw_id\": \"\",\n          \"gw_items_base_price\": \"\",\n          \"gw_items_base_price_incl_tax\": \"\",\n          \"gw_items_base_price_invoiced\": \"\",\n          \"gw_items_base_price_refunded\": \"\",\n          \"gw_items_base_tax_amount\": \"\",\n          \"gw_items_base_tax_invoiced\": \"\",\n          \"gw_items_base_tax_refunded\": \"\",\n          \"gw_items_price\": \"\",\n          \"gw_items_price_incl_tax\": \"\",\n          \"gw_items_price_invoiced\": \"\",\n          \"gw_items_price_refunded\": \"\",\n          \"gw_items_tax_amount\": \"\",\n          \"gw_items_tax_invoiced\": \"\",\n          \"gw_items_tax_refunded\": \"\",\n          \"gw_price\": \"\",\n          \"gw_price_incl_tax\": \"\",\n          \"gw_price_invoiced\": \"\",\n          \"gw_price_refunded\": \"\",\n          \"gw_tax_amount\": \"\",\n          \"gw_tax_amount_invoiced\": \"\",\n          \"gw_tax_amount_refunded\": \"\",\n          \"item_applied_taxes\": [\n            {\n              \"applied_taxes\": [\n                {}\n              ],\n              \"associated_item_id\": 0,\n              \"extension_attributes\": {},\n              \"item_id\": 0,\n              \"type\": \"\"\n            }\n          ],\n          \"payment_additional_info\": [\n            {\n              \"key\": \"\",\n              \"value\": \"\"\n            }\n          ],\n          \"reward_currency_amount\": \"\",\n          \"reward_points_balance\": 0,\n          \"shipping_assignments\": [\n            {\n              \"extension_attributes\": {},\n              \"items\": [\n                {\n                  \"additional_data\": \"\",\n                  \"amount_refunded\": \"\",\n                  \"applied_rule_ids\": \"\",\n                  \"base_amount_refunded\": \"\",\n                  \"base_cost\": \"\",\n                  \"base_discount_amount\": \"\",\n                  \"base_discount_invoiced\": \"\",\n                  \"base_discount_refunded\": \"\",\n                  \"base_discount_tax_compensation_amount\": \"\",\n                  \"base_discount_tax_compensation_invoiced\": \"\",\n                  \"base_discount_tax_compensation_refunded\": \"\",\n                  \"base_original_price\": \"\",\n                  \"base_price\": \"\",\n                  \"base_price_incl_tax\": \"\",\n                  \"base_row_invoiced\": \"\",\n                  \"base_row_total\": \"\",\n                  \"base_row_total_incl_tax\": \"\",\n                  \"base_tax_amount\": \"\",\n                  \"base_tax_before_discount\": \"\",\n                  \"base_tax_invoiced\": \"\",\n                  \"base_tax_refunded\": \"\",\n                  \"base_weee_tax_applied_amount\": \"\",\n                  \"base_weee_tax_applied_row_amnt\": \"\",\n                  \"base_weee_tax_disposition\": \"\",\n                  \"base_weee_tax_row_disposition\": \"\",\n                  \"created_at\": \"\",\n                  \"description\": \"\",\n                  \"discount_amount\": \"\",\n                  \"discount_invoiced\": \"\",\n                  \"discount_percent\": \"\",\n                  \"discount_refunded\": \"\",\n                  \"discount_tax_compensation_amount\": \"\",\n                  \"discount_tax_compensation_canceled\": \"\",\n                  \"discount_tax_compensation_invoiced\": \"\",\n                  \"discount_tax_compensation_refunded\": \"\",\n                  \"event_id\": 0,\n                  \"ext_order_item_id\": \"\",\n                  \"extension_attributes\": {\n                    \"gift_message\": {},\n                    \"gw_base_price\": \"\",\n                    \"gw_base_price_invoiced\": \"\",\n                    \"gw_base_price_refunded\": \"\",\n                    \"gw_base_tax_amount\": \"\",\n                    \"gw_base_tax_amount_invoiced\": \"\",\n                    \"gw_base_tax_amount_refunded\": \"\",\n                    \"gw_id\": \"\",\n                    \"gw_price\": \"\",\n                    \"gw_price_invoiced\": \"\",\n                    \"gw_price_refunded\": \"\",\n                    \"gw_tax_amount\": \"\",\n                    \"gw_tax_amount_invoiced\": \"\",\n                    \"gw_tax_amount_refunded\": \"\",\n                    \"invoice_text_codes\": [],\n                    \"tax_codes\": [],\n                    \"vertex_tax_codes\": []\n                  },\n                  \"free_shipping\": 0,\n                  \"gw_base_price\": \"\",\n                  \"gw_base_price_invoiced\": \"\",\n                  \"gw_base_price_refunded\": \"\",\n                  \"gw_base_tax_amount\": \"\",\n                  \"gw_base_tax_amount_invoiced\": \"\",\n                  \"gw_base_tax_amount_refunded\": \"\",\n                  \"gw_id\": 0,\n                  \"gw_price\": \"\",\n                  \"gw_price_invoiced\": \"\",\n                  \"gw_price_refunded\": \"\",\n                  \"gw_tax_amount\": \"\",\n                  \"gw_tax_amount_invoiced\": \"\",\n                  \"gw_tax_amount_refunded\": \"\",\n                  \"is_qty_decimal\": 0,\n                  \"is_virtual\": 0,\n                  \"item_id\": 0,\n                  \"locked_do_invoice\": 0,\n                  \"locked_do_ship\": 0,\n                  \"name\": \"\",\n                  \"no_discount\": 0,\n                  \"order_id\": 0,\n                  \"original_price\": \"\",\n                  \"parent_item\": \"\",\n                  \"parent_item_id\": 0,\n                  \"price\": \"\",\n                  \"price_incl_tax\": \"\",\n                  \"product_id\": 0,\n                  \"product_option\": {\n                    \"extension_attributes\": {\n                      \"bundle_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": 0,\n                          \"option_qty\": 0,\n                          \"option_selections\": []\n                        }\n                      ],\n                      \"configurable_item_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": \"\",\n                          \"option_value\": 0\n                        }\n                      ],\n                      \"custom_options\": [\n                        {\n                          \"extension_attributes\": {\n                            \"file_info\": {\n                              \"base64_encoded_data\": \"\",\n                              \"name\": \"\",\n                              \"type\": \"\"\n                            }\n                          },\n                          \"option_id\": \"\",\n                          \"option_value\": \"\"\n                        }\n                      ],\n                      \"downloadable_option\": {\n                        \"downloadable_links\": []\n                      },\n                      \"giftcard_item_option\": {\n                        \"custom_giftcard_amount\": \"\",\n                        \"extension_attributes\": {},\n                        \"giftcard_amount\": \"\",\n                        \"giftcard_message\": \"\",\n                        \"giftcard_recipient_email\": \"\",\n                        \"giftcard_recipient_name\": \"\",\n                        \"giftcard_sender_email\": \"\",\n                        \"giftcard_sender_name\": \"\"\n                      }\n                    }\n                  },\n                  \"product_type\": \"\",\n                  \"qty_backordered\": \"\",\n                  \"qty_canceled\": \"\",\n                  \"qty_invoiced\": \"\",\n                  \"qty_ordered\": \"\",\n                  \"qty_refunded\": \"\",\n                  \"qty_returned\": \"\",\n                  \"qty_shipped\": \"\",\n                  \"quote_item_id\": 0,\n                  \"row_invoiced\": \"\",\n                  \"row_total\": \"\",\n                  \"row_total_incl_tax\": \"\",\n                  \"row_weight\": \"\",\n                  \"sku\": \"\",\n                  \"store_id\": 0,\n                  \"tax_amount\": \"\",\n                  \"tax_before_discount\": \"\",\n                  \"tax_canceled\": \"\",\n                  \"tax_invoiced\": \"\",\n                  \"tax_percent\": \"\",\n                  \"tax_refunded\": \"\",\n                  \"updated_at\": \"\",\n                  \"weee_tax_applied\": \"\",\n                  \"weee_tax_applied_amount\": \"\",\n                  \"weee_tax_applied_row_amount\": \"\",\n                  \"weee_tax_disposition\": \"\",\n                  \"weee_tax_row_disposition\": \"\",\n                  \"weight\": \"\"\n                }\n              ],\n              \"shipping\": {\n                \"address\": {},\n                \"extension_attributes\": {\n                  \"collection_point\": {\n                    \"city\": \"\",\n                    \"collection_point_id\": \"\",\n                    \"country\": \"\",\n                    \"name\": \"\",\n                    \"postcode\": \"\",\n                    \"recipient_address_id\": 0,\n                    \"region\": \"\",\n                    \"street\": []\n                  },\n                  \"ext_order_id\": \"\",\n                  \"shipping_experience\": {\n                    \"code\": \"\",\n                    \"cost\": \"\",\n                    \"label\": \"\"\n                  }\n                },\n                \"method\": \"\",\n                \"total\": {\n                  \"base_shipping_amount\": \"\",\n                  \"base_shipping_canceled\": \"\",\n                  \"base_shipping_discount_amount\": \"\",\n                  \"base_shipping_discount_tax_compensation_amnt\": \"\",\n                  \"base_shipping_incl_tax\": \"\",\n                  \"base_shipping_invoiced\": \"\",\n                  \"base_shipping_refunded\": \"\",\n                  \"base_shipping_tax_amount\": \"\",\n                  \"base_shipping_tax_refunded\": \"\",\n                  \"extension_attributes\": {},\n                  \"shipping_amount\": \"\",\n                  \"shipping_canceled\": \"\",\n                  \"shipping_discount_amount\": \"\",\n                  \"shipping_discount_tax_compensation_amount\": \"\",\n                  \"shipping_incl_tax\": \"\",\n                  \"shipping_invoiced\": \"\",\n                  \"shipping_refunded\": \"\",\n                  \"shipping_tax_amount\": \"\",\n                  \"shipping_tax_refunded\": \"\"\n                }\n              },\n              \"stock_id\": 0\n            }\n          ]\n        },\n        \"forced_shipment_with_invoice\": 0,\n        \"global_currency_code\": \"\",\n        \"grand_total\": \"\",\n        \"hold_before_state\": \"\",\n        \"hold_before_status\": \"\",\n        \"increment_id\": \"\",\n        \"is_virtual\": 0,\n        \"items\": [\n          {}\n        ],\n        \"order_currency_code\": \"\",\n        \"original_increment_id\": \"\",\n        \"payment\": {\n          \"account_status\": \"\",\n          \"additional_data\": \"\",\n          \"additional_information\": [],\n          \"address_status\": \"\",\n          \"amount_authorized\": \"\",\n          \"amount_canceled\": \"\",\n          \"amount_ordered\": \"\",\n          \"amount_paid\": \"\",\n          \"amount_refunded\": \"\",\n          \"anet_trans_method\": \"\",\n          \"base_amount_authorized\": \"\",\n          \"base_amount_canceled\": \"\",\n          \"base_amount_ordered\": \"\",\n          \"base_amount_paid\": \"\",\n          \"base_amount_paid_online\": \"\",\n          \"base_amount_refunded\": \"\",\n          \"base_amount_refunded_online\": \"\",\n          \"base_shipping_amount\": \"\",\n          \"base_shipping_captured\": \"\",\n          \"base_shipping_refunded\": \"\",\n          \"cc_approval\": \"\",\n          \"cc_avs_status\": \"\",\n          \"cc_cid_status\": \"\",\n          \"cc_debug_request_body\": \"\",\n          \"cc_debug_response_body\": \"\",\n          \"cc_debug_response_serialized\": \"\",\n          \"cc_exp_month\": \"\",\n          \"cc_exp_year\": \"\",\n          \"cc_last4\": \"\",\n          \"cc_number_enc\": \"\",\n          \"cc_owner\": \"\",\n          \"cc_secure_verify\": \"\",\n          \"cc_ss_issue\": \"\",\n          \"cc_ss_start_month\": \"\",\n          \"cc_ss_start_year\": \"\",\n          \"cc_status\": \"\",\n          \"cc_status_description\": \"\",\n          \"cc_trans_id\": \"\",\n          \"cc_type\": \"\",\n          \"echeck_account_name\": \"\",\n          \"echeck_account_type\": \"\",\n          \"echeck_bank_name\": \"\",\n          \"echeck_routing_number\": \"\",\n          \"echeck_type\": \"\",\n          \"entity_id\": 0,\n          \"extension_attributes\": {\n            \"vault_payment_token\": {\n              \"created_at\": \"\",\n              \"customer_id\": 0,\n              \"entity_id\": 0,\n              \"expires_at\": \"\",\n              \"gateway_token\": \"\",\n              \"is_active\": false,\n              \"is_visible\": false,\n              \"payment_method_code\": \"\",\n              \"public_hash\": \"\",\n              \"token_details\": \"\",\n              \"type\": \"\"\n            }\n          },\n          \"last_trans_id\": \"\",\n          \"method\": \"\",\n          \"parent_id\": 0,\n          \"po_number\": \"\",\n          \"protection_eligibility\": \"\",\n          \"quote_payment_id\": 0,\n          \"shipping_amount\": \"\",\n          \"shipping_captured\": \"\",\n          \"shipping_refunded\": \"\"\n        },\n        \"payment_auth_expiration\": 0,\n        \"payment_authorization_amount\": \"\",\n        \"protect_code\": \"\",\n        \"quote_address_id\": 0,\n        \"quote_id\": 0,\n        \"relation_child_id\": \"\",\n        \"relation_child_real_id\": \"\",\n        \"relation_parent_id\": \"\",\n        \"relation_parent_real_id\": \"\",\n        \"remote_ip\": \"\",\n        \"shipping_amount\": \"\",\n        \"shipping_canceled\": \"\",\n        \"shipping_description\": \"\",\n        \"shipping_discount_amount\": \"\",\n        \"shipping_discount_tax_compensation_amount\": \"\",\n        \"shipping_incl_tax\": \"\",\n        \"shipping_invoiced\": \"\",\n        \"shipping_refunded\": \"\",\n        \"shipping_tax_amount\": \"\",\n        \"shipping_tax_refunded\": \"\",\n        \"state\": \"\",\n        \"status\": \"\",\n        \"status_histories\": [\n          {\n            \"comment\": \"\",\n            \"created_at\": \"\",\n            \"entity_id\": 0,\n            \"entity_name\": \"\",\n            \"extension_attributes\": {},\n            \"is_customer_notified\": 0,\n            \"is_visible_on_front\": 0,\n            \"parent_id\": 0,\n            \"status\": \"\"\n          }\n        ],\n        \"store_currency_code\": \"\",\n        \"store_id\": 0,\n        \"store_name\": \"\",\n        \"store_to_base_rate\": \"\",\n        \"store_to_order_rate\": \"\",\n        \"subtotal\": \"\",\n        \"subtotal_canceled\": \"\",\n        \"subtotal_incl_tax\": \"\",\n        \"subtotal_invoiced\": \"\",\n        \"subtotal_refunded\": \"\",\n        \"tax_amount\": \"\",\n        \"tax_canceled\": \"\",\n        \"tax_invoiced\": \"\",\n        \"tax_refunded\": \"\",\n        \"total_canceled\": \"\",\n        \"total_due\": \"\",\n        \"total_invoiced\": \"\",\n        \"total_item_count\": 0,\n        \"total_offline_refunded\": \"\",\n        \"total_online_refunded\": \"\",\n        \"total_paid\": \"\",\n        \"total_qty_ordered\": \"\",\n        \"total_refunded\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\",\n        \"x_forwarded_for\": \"\"\n      },\n      \"vertex_tax_calculation_shipping_address\": {}\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"is_used_for_refund\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"total_qty\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  entity: {
    base_currency_code: '',
    base_discount_amount: '',
    base_discount_tax_compensation_amount: '',
    base_grand_total: '',
    base_shipping_amount: '',
    base_shipping_discount_tax_compensation_amnt: '',
    base_shipping_incl_tax: '',
    base_shipping_tax_amount: '',
    base_subtotal: '',
    base_subtotal_incl_tax: '',
    base_tax_amount: '',
    base_to_global_rate: '',
    base_to_order_rate: '',
    base_total_refunded: '',
    billing_address_id: 0,
    can_void_flag: 0,
    comments: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0
      }
    ],
    created_at: '',
    discount_amount: '',
    discount_description: '',
    discount_tax_compensation_amount: '',
    email_sent: 0,
    entity_id: 0,
    extension_attributes: {
      base_customer_balance_amount: '',
      base_gift_cards_amount: '',
      customer_balance_amount: '',
      gift_cards_amount: '',
      gw_base_price: '',
      gw_base_tax_amount: '',
      gw_card_base_price: '',
      gw_card_base_tax_amount: '',
      gw_card_price: '',
      gw_card_tax_amount: '',
      gw_items_base_price: '',
      gw_items_base_tax_amount: '',
      gw_items_price: '',
      gw_items_tax_amount: '',
      gw_price: '',
      gw_tax_amount: '',
      vertex_tax_calculation_billing_address: {
        address_type: '',
        city: '',
        company: '',
        country_id: '',
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        entity_id: 0,
        extension_attributes: {
          checkout_fields: [
            {
              attribute_code: '',
              value: ''
            }
          ]
        },
        fax: '',
        firstname: '',
        lastname: '',
        middlename: '',
        parent_id: 0,
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: '',
        vat_is_valid: 0,
        vat_request_date: '',
        vat_request_id: '',
        vat_request_success: 0
      },
      vertex_tax_calculation_order: {
        adjustment_negative: '',
        adjustment_positive: '',
        applied_rule_ids: '',
        base_adjustment_negative: '',
        base_adjustment_positive: '',
        base_currency_code: '',
        base_discount_amount: '',
        base_discount_canceled: '',
        base_discount_invoiced: '',
        base_discount_refunded: '',
        base_discount_tax_compensation_amount: '',
        base_discount_tax_compensation_invoiced: '',
        base_discount_tax_compensation_refunded: '',
        base_grand_total: '',
        base_shipping_amount: '',
        base_shipping_canceled: '',
        base_shipping_discount_amount: '',
        base_shipping_discount_tax_compensation_amnt: '',
        base_shipping_incl_tax: '',
        base_shipping_invoiced: '',
        base_shipping_refunded: '',
        base_shipping_tax_amount: '',
        base_shipping_tax_refunded: '',
        base_subtotal: '',
        base_subtotal_canceled: '',
        base_subtotal_incl_tax: '',
        base_subtotal_invoiced: '',
        base_subtotal_refunded: '',
        base_tax_amount: '',
        base_tax_canceled: '',
        base_tax_invoiced: '',
        base_tax_refunded: '',
        base_to_global_rate: '',
        base_to_order_rate: '',
        base_total_canceled: '',
        base_total_due: '',
        base_total_invoiced: '',
        base_total_invoiced_cost: '',
        base_total_offline_refunded: '',
        base_total_online_refunded: '',
        base_total_paid: '',
        base_total_qty_ordered: '',
        base_total_refunded: '',
        billing_address: {},
        billing_address_id: 0,
        can_ship_partially: 0,
        can_ship_partially_item: 0,
        coupon_code: '',
        created_at: '',
        customer_dob: '',
        customer_email: '',
        customer_firstname: '',
        customer_gender: 0,
        customer_group_id: 0,
        customer_id: 0,
        customer_is_guest: 0,
        customer_lastname: '',
        customer_middlename: '',
        customer_note: '',
        customer_note_notify: 0,
        customer_prefix: '',
        customer_suffix: '',
        customer_taxvat: '',
        discount_amount: '',
        discount_canceled: '',
        discount_description: '',
        discount_invoiced: '',
        discount_refunded: '',
        discount_tax_compensation_amount: '',
        discount_tax_compensation_invoiced: '',
        discount_tax_compensation_refunded: '',
        edit_increment: 0,
        email_sent: 0,
        entity_id: 0,
        ext_customer_id: '',
        ext_order_id: '',
        extension_attributes: {
          amazon_order_reference_id: '',
          applied_taxes: [
            {
              amount: '',
              base_amount: '',
              code: '',
              extension_attributes: {
                rates: [
                  {
                    code: '',
                    extension_attributes: {},
                    percent: '',
                    title: ''
                  }
                ]
              },
              percent: '',
              title: ''
            }
          ],
          base_customer_balance_amount: '',
          base_customer_balance_invoiced: '',
          base_customer_balance_refunded: '',
          base_customer_balance_total_refunded: '',
          base_gift_cards_amount: '',
          base_gift_cards_invoiced: '',
          base_gift_cards_refunded: '',
          base_reward_currency_amount: '',
          company_order_attributes: {
            company_id: 0,
            company_name: '',
            extension_attributes: {},
            order_id: 0
          },
          converting_from_quote: false,
          customer_balance_amount: '',
          customer_balance_invoiced: '',
          customer_balance_refunded: '',
          customer_balance_total_refunded: '',
          gift_cards: [
            {
              amount: '',
              base_amount: '',
              code: '',
              id: 0
            }
          ],
          gift_cards_amount: '',
          gift_cards_invoiced: '',
          gift_cards_refunded: '',
          gift_message: {
            customer_id: 0,
            extension_attributes: {
              entity_id: '',
              entity_type: '',
              wrapping_add_printed_card: false,
              wrapping_allow_gift_receipt: false,
              wrapping_id: 0
            },
            gift_message_id: 0,
            message: '',
            recipient: '',
            sender: ''
          },
          gw_add_card: '',
          gw_allow_gift_receipt: '',
          gw_base_price: '',
          gw_base_price_incl_tax: '',
          gw_base_price_invoiced: '',
          gw_base_price_refunded: '',
          gw_base_tax_amount: '',
          gw_base_tax_amount_invoiced: '',
          gw_base_tax_amount_refunded: '',
          gw_card_base_price: '',
          gw_card_base_price_incl_tax: '',
          gw_card_base_price_invoiced: '',
          gw_card_base_price_refunded: '',
          gw_card_base_tax_amount: '',
          gw_card_base_tax_invoiced: '',
          gw_card_base_tax_refunded: '',
          gw_card_price: '',
          gw_card_price_incl_tax: '',
          gw_card_price_invoiced: '',
          gw_card_price_refunded: '',
          gw_card_tax_amount: '',
          gw_card_tax_invoiced: '',
          gw_card_tax_refunded: '',
          gw_id: '',
          gw_items_base_price: '',
          gw_items_base_price_incl_tax: '',
          gw_items_base_price_invoiced: '',
          gw_items_base_price_refunded: '',
          gw_items_base_tax_amount: '',
          gw_items_base_tax_invoiced: '',
          gw_items_base_tax_refunded: '',
          gw_items_price: '',
          gw_items_price_incl_tax: '',
          gw_items_price_invoiced: '',
          gw_items_price_refunded: '',
          gw_items_tax_amount: '',
          gw_items_tax_invoiced: '',
          gw_items_tax_refunded: '',
          gw_price: '',
          gw_price_incl_tax: '',
          gw_price_invoiced: '',
          gw_price_refunded: '',
          gw_tax_amount: '',
          gw_tax_amount_invoiced: '',
          gw_tax_amount_refunded: '',
          item_applied_taxes: [
            {
              applied_taxes: [
                {}
              ],
              associated_item_id: 0,
              extension_attributes: {},
              item_id: 0,
              type: ''
            }
          ],
          payment_additional_info: [
            {
              key: '',
              value: ''
            }
          ],
          reward_currency_amount: '',
          reward_points_balance: 0,
          shipping_assignments: [
            {
              extension_attributes: {},
              items: [
                {
                  additional_data: '',
                  amount_refunded: '',
                  applied_rule_ids: '',
                  base_amount_refunded: '',
                  base_cost: '',
                  base_discount_amount: '',
                  base_discount_invoiced: '',
                  base_discount_refunded: '',
                  base_discount_tax_compensation_amount: '',
                  base_discount_tax_compensation_invoiced: '',
                  base_discount_tax_compensation_refunded: '',
                  base_original_price: '',
                  base_price: '',
                  base_price_incl_tax: '',
                  base_row_invoiced: '',
                  base_row_total: '',
                  base_row_total_incl_tax: '',
                  base_tax_amount: '',
                  base_tax_before_discount: '',
                  base_tax_invoiced: '',
                  base_tax_refunded: '',
                  base_weee_tax_applied_amount: '',
                  base_weee_tax_applied_row_amnt: '',
                  base_weee_tax_disposition: '',
                  base_weee_tax_row_disposition: '',
                  created_at: '',
                  description: '',
                  discount_amount: '',
                  discount_invoiced: '',
                  discount_percent: '',
                  discount_refunded: '',
                  discount_tax_compensation_amount: '',
                  discount_tax_compensation_canceled: '',
                  discount_tax_compensation_invoiced: '',
                  discount_tax_compensation_refunded: '',
                  event_id: 0,
                  ext_order_item_id: '',
                  extension_attributes: {
                    gift_message: {},
                    gw_base_price: '',
                    gw_base_price_invoiced: '',
                    gw_base_price_refunded: '',
                    gw_base_tax_amount: '',
                    gw_base_tax_amount_invoiced: '',
                    gw_base_tax_amount_refunded: '',
                    gw_id: '',
                    gw_price: '',
                    gw_price_invoiced: '',
                    gw_price_refunded: '',
                    gw_tax_amount: '',
                    gw_tax_amount_invoiced: '',
                    gw_tax_amount_refunded: '',
                    invoice_text_codes: [],
                    tax_codes: [],
                    vertex_tax_codes: []
                  },
                  free_shipping: 0,
                  gw_base_price: '',
                  gw_base_price_invoiced: '',
                  gw_base_price_refunded: '',
                  gw_base_tax_amount: '',
                  gw_base_tax_amount_invoiced: '',
                  gw_base_tax_amount_refunded: '',
                  gw_id: 0,
                  gw_price: '',
                  gw_price_invoiced: '',
                  gw_price_refunded: '',
                  gw_tax_amount: '',
                  gw_tax_amount_invoiced: '',
                  gw_tax_amount_refunded: '',
                  is_qty_decimal: 0,
                  is_virtual: 0,
                  item_id: 0,
                  locked_do_invoice: 0,
                  locked_do_ship: 0,
                  name: '',
                  no_discount: 0,
                  order_id: 0,
                  original_price: '',
                  parent_item: '',
                  parent_item_id: 0,
                  price: '',
                  price_incl_tax: '',
                  product_id: 0,
                  product_option: {
                    extension_attributes: {
                      bundle_options: [
                        {
                          extension_attributes: {},
                          option_id: 0,
                          option_qty: 0,
                          option_selections: []
                        }
                      ],
                      configurable_item_options: [
                        {
                          extension_attributes: {},
                          option_id: '',
                          option_value: 0
                        }
                      ],
                      custom_options: [
                        {
                          extension_attributes: {
                            file_info: {
                              base64_encoded_data: '',
                              name: '',
                              type: ''
                            }
                          },
                          option_id: '',
                          option_value: ''
                        }
                      ],
                      downloadable_option: {
                        downloadable_links: []
                      },
                      giftcard_item_option: {
                        custom_giftcard_amount: '',
                        extension_attributes: {},
                        giftcard_amount: '',
                        giftcard_message: '',
                        giftcard_recipient_email: '',
                        giftcard_recipient_name: '',
                        giftcard_sender_email: '',
                        giftcard_sender_name: ''
                      }
                    }
                  },
                  product_type: '',
                  qty_backordered: '',
                  qty_canceled: '',
                  qty_invoiced: '',
                  qty_ordered: '',
                  qty_refunded: '',
                  qty_returned: '',
                  qty_shipped: '',
                  quote_item_id: 0,
                  row_invoiced: '',
                  row_total: '',
                  row_total_incl_tax: '',
                  row_weight: '',
                  sku: '',
                  store_id: 0,
                  tax_amount: '',
                  tax_before_discount: '',
                  tax_canceled: '',
                  tax_invoiced: '',
                  tax_percent: '',
                  tax_refunded: '',
                  updated_at: '',
                  weee_tax_applied: '',
                  weee_tax_applied_amount: '',
                  weee_tax_applied_row_amount: '',
                  weee_tax_disposition: '',
                  weee_tax_row_disposition: '',
                  weight: ''
                }
              ],
              shipping: {
                address: {},
                extension_attributes: {
                  collection_point: {
                    city: '',
                    collection_point_id: '',
                    country: '',
                    name: '',
                    postcode: '',
                    recipient_address_id: 0,
                    region: '',
                    street: []
                  },
                  ext_order_id: '',
                  shipping_experience: {
                    code: '',
                    cost: '',
                    label: ''
                  }
                },
                method: '',
                total: {
                  base_shipping_amount: '',
                  base_shipping_canceled: '',
                  base_shipping_discount_amount: '',
                  base_shipping_discount_tax_compensation_amnt: '',
                  base_shipping_incl_tax: '',
                  base_shipping_invoiced: '',
                  base_shipping_refunded: '',
                  base_shipping_tax_amount: '',
                  base_shipping_tax_refunded: '',
                  extension_attributes: {},
                  shipping_amount: '',
                  shipping_canceled: '',
                  shipping_discount_amount: '',
                  shipping_discount_tax_compensation_amount: '',
                  shipping_incl_tax: '',
                  shipping_invoiced: '',
                  shipping_refunded: '',
                  shipping_tax_amount: '',
                  shipping_tax_refunded: ''
                }
              },
              stock_id: 0
            }
          ]
        },
        forced_shipment_with_invoice: 0,
        global_currency_code: '',
        grand_total: '',
        hold_before_state: '',
        hold_before_status: '',
        increment_id: '',
        is_virtual: 0,
        items: [
          {}
        ],
        order_currency_code: '',
        original_increment_id: '',
        payment: {
          account_status: '',
          additional_data: '',
          additional_information: [],
          address_status: '',
          amount_authorized: '',
          amount_canceled: '',
          amount_ordered: '',
          amount_paid: '',
          amount_refunded: '',
          anet_trans_method: '',
          base_amount_authorized: '',
          base_amount_canceled: '',
          base_amount_ordered: '',
          base_amount_paid: '',
          base_amount_paid_online: '',
          base_amount_refunded: '',
          base_amount_refunded_online: '',
          base_shipping_amount: '',
          base_shipping_captured: '',
          base_shipping_refunded: '',
          cc_approval: '',
          cc_avs_status: '',
          cc_cid_status: '',
          cc_debug_request_body: '',
          cc_debug_response_body: '',
          cc_debug_response_serialized: '',
          cc_exp_month: '',
          cc_exp_year: '',
          cc_last4: '',
          cc_number_enc: '',
          cc_owner: '',
          cc_secure_verify: '',
          cc_ss_issue: '',
          cc_ss_start_month: '',
          cc_ss_start_year: '',
          cc_status: '',
          cc_status_description: '',
          cc_trans_id: '',
          cc_type: '',
          echeck_account_name: '',
          echeck_account_type: '',
          echeck_bank_name: '',
          echeck_routing_number: '',
          echeck_type: '',
          entity_id: 0,
          extension_attributes: {
            vault_payment_token: {
              created_at: '',
              customer_id: 0,
              entity_id: 0,
              expires_at: '',
              gateway_token: '',
              is_active: false,
              is_visible: false,
              payment_method_code: '',
              public_hash: '',
              token_details: '',
              type: ''
            }
          },
          last_trans_id: '',
          method: '',
          parent_id: 0,
          po_number: '',
          protection_eligibility: '',
          quote_payment_id: 0,
          shipping_amount: '',
          shipping_captured: '',
          shipping_refunded: ''
        },
        payment_auth_expiration: 0,
        payment_authorization_amount: '',
        protect_code: '',
        quote_address_id: 0,
        quote_id: 0,
        relation_child_id: '',
        relation_child_real_id: '',
        relation_parent_id: '',
        relation_parent_real_id: '',
        remote_ip: '',
        shipping_amount: '',
        shipping_canceled: '',
        shipping_description: '',
        shipping_discount_amount: '',
        shipping_discount_tax_compensation_amount: '',
        shipping_incl_tax: '',
        shipping_invoiced: '',
        shipping_refunded: '',
        shipping_tax_amount: '',
        shipping_tax_refunded: '',
        state: '',
        status: '',
        status_histories: [
          {
            comment: '',
            created_at: '',
            entity_id: 0,
            entity_name: '',
            extension_attributes: {},
            is_customer_notified: 0,
            is_visible_on_front: 0,
            parent_id: 0,
            status: ''
          }
        ],
        store_currency_code: '',
        store_id: 0,
        store_name: '',
        store_to_base_rate: '',
        store_to_order_rate: '',
        subtotal: '',
        subtotal_canceled: '',
        subtotal_incl_tax: '',
        subtotal_invoiced: '',
        subtotal_refunded: '',
        tax_amount: '',
        tax_canceled: '',
        tax_invoiced: '',
        tax_refunded: '',
        total_canceled: '',
        total_due: '',
        total_invoiced: '',
        total_item_count: 0,
        total_offline_refunded: '',
        total_online_refunded: '',
        total_paid: '',
        total_qty_ordered: '',
        total_refunded: '',
        updated_at: '',
        weight: '',
        x_forwarded_for: ''
      },
      vertex_tax_calculation_shipping_address: {}
    },
    global_currency_code: '',
    grand_total: '',
    increment_id: '',
    is_used_for_refund: 0,
    items: [
      {
        additional_data: '',
        base_cost: '',
        base_discount_amount: '',
        base_discount_tax_compensation_amount: '',
        base_price: '',
        base_price_incl_tax: '',
        base_row_total: '',
        base_row_total_incl_tax: '',
        base_tax_amount: '',
        description: '',
        discount_amount: '',
        discount_tax_compensation_amount: '',
        entity_id: 0,
        extension_attributes: {
          invoice_text_codes: [],
          tax_codes: [],
          vertex_tax_codes: []
        },
        name: '',
        order_item_id: 0,
        parent_id: 0,
        price: '',
        price_incl_tax: '',
        product_id: 0,
        qty: '',
        row_total: '',
        row_total_incl_tax: '',
        sku: '',
        tax_amount: ''
      }
    ],
    order_currency_code: '',
    order_id: 0,
    shipping_address_id: 0,
    shipping_amount: '',
    shipping_discount_tax_compensation_amount: '',
    shipping_incl_tax: '',
    shipping_tax_amount: '',
    state: 0,
    store_currency_code: '',
    store_id: 0,
    store_to_base_rate: '',
    store_to_order_rate: '',
    subtotal: '',
    subtotal_incl_tax: '',
    tax_amount: '',
    total_qty: '',
    transaction_id: '',
    updated_at: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/invoices/');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/invoices/',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      base_currency_code: '',
      base_discount_amount: '',
      base_discount_tax_compensation_amount: '',
      base_grand_total: '',
      base_shipping_amount: '',
      base_shipping_discount_tax_compensation_amnt: '',
      base_shipping_incl_tax: '',
      base_shipping_tax_amount: '',
      base_subtotal: '',
      base_subtotal_incl_tax: '',
      base_tax_amount: '',
      base_to_global_rate: '',
      base_to_order_rate: '',
      base_total_refunded: '',
      billing_address_id: 0,
      can_void_flag: 0,
      comments: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0
        }
      ],
      created_at: '',
      discount_amount: '',
      discount_description: '',
      discount_tax_compensation_amount: '',
      email_sent: 0,
      entity_id: 0,
      extension_attributes: {
        base_customer_balance_amount: '',
        base_gift_cards_amount: '',
        customer_balance_amount: '',
        gift_cards_amount: '',
        gw_base_price: '',
        gw_base_tax_amount: '',
        gw_card_base_price: '',
        gw_card_base_tax_amount: '',
        gw_card_price: '',
        gw_card_tax_amount: '',
        gw_items_base_price: '',
        gw_items_base_tax_amount: '',
        gw_items_price: '',
        gw_items_tax_amount: '',
        gw_price: '',
        gw_tax_amount: '',
        vertex_tax_calculation_billing_address: {
          address_type: '',
          city: '',
          company: '',
          country_id: '',
          customer_address_id: 0,
          customer_id: 0,
          email: '',
          entity_id: 0,
          extension_attributes: {checkout_fields: [{attribute_code: '', value: ''}]},
          fax: '',
          firstname: '',
          lastname: '',
          middlename: '',
          parent_id: 0,
          postcode: '',
          prefix: '',
          region: '',
          region_code: '',
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: '',
          vat_is_valid: 0,
          vat_request_date: '',
          vat_request_id: '',
          vat_request_success: 0
        },
        vertex_tax_calculation_order: {
          adjustment_negative: '',
          adjustment_positive: '',
          applied_rule_ids: '',
          base_adjustment_negative: '',
          base_adjustment_positive: '',
          base_currency_code: '',
          base_discount_amount: '',
          base_discount_canceled: '',
          base_discount_invoiced: '',
          base_discount_refunded: '',
          base_discount_tax_compensation_amount: '',
          base_discount_tax_compensation_invoiced: '',
          base_discount_tax_compensation_refunded: '',
          base_grand_total: '',
          base_shipping_amount: '',
          base_shipping_canceled: '',
          base_shipping_discount_amount: '',
          base_shipping_discount_tax_compensation_amnt: '',
          base_shipping_incl_tax: '',
          base_shipping_invoiced: '',
          base_shipping_refunded: '',
          base_shipping_tax_amount: '',
          base_shipping_tax_refunded: '',
          base_subtotal: '',
          base_subtotal_canceled: '',
          base_subtotal_incl_tax: '',
          base_subtotal_invoiced: '',
          base_subtotal_refunded: '',
          base_tax_amount: '',
          base_tax_canceled: '',
          base_tax_invoiced: '',
          base_tax_refunded: '',
          base_to_global_rate: '',
          base_to_order_rate: '',
          base_total_canceled: '',
          base_total_due: '',
          base_total_invoiced: '',
          base_total_invoiced_cost: '',
          base_total_offline_refunded: '',
          base_total_online_refunded: '',
          base_total_paid: '',
          base_total_qty_ordered: '',
          base_total_refunded: '',
          billing_address: {},
          billing_address_id: 0,
          can_ship_partially: 0,
          can_ship_partially_item: 0,
          coupon_code: '',
          created_at: '',
          customer_dob: '',
          customer_email: '',
          customer_firstname: '',
          customer_gender: 0,
          customer_group_id: 0,
          customer_id: 0,
          customer_is_guest: 0,
          customer_lastname: '',
          customer_middlename: '',
          customer_note: '',
          customer_note_notify: 0,
          customer_prefix: '',
          customer_suffix: '',
          customer_taxvat: '',
          discount_amount: '',
          discount_canceled: '',
          discount_description: '',
          discount_invoiced: '',
          discount_refunded: '',
          discount_tax_compensation_amount: '',
          discount_tax_compensation_invoiced: '',
          discount_tax_compensation_refunded: '',
          edit_increment: 0,
          email_sent: 0,
          entity_id: 0,
          ext_customer_id: '',
          ext_order_id: '',
          extension_attributes: {
            amazon_order_reference_id: '',
            applied_taxes: [
              {
                amount: '',
                base_amount: '',
                code: '',
                extension_attributes: {rates: [{code: '', extension_attributes: {}, percent: '', title: ''}]},
                percent: '',
                title: ''
              }
            ],
            base_customer_balance_amount: '',
            base_customer_balance_invoiced: '',
            base_customer_balance_refunded: '',
            base_customer_balance_total_refunded: '',
            base_gift_cards_amount: '',
            base_gift_cards_invoiced: '',
            base_gift_cards_refunded: '',
            base_reward_currency_amount: '',
            company_order_attributes: {company_id: 0, company_name: '', extension_attributes: {}, order_id: 0},
            converting_from_quote: false,
            customer_balance_amount: '',
            customer_balance_invoiced: '',
            customer_balance_refunded: '',
            customer_balance_total_refunded: '',
            gift_cards: [{amount: '', base_amount: '', code: '', id: 0}],
            gift_cards_amount: '',
            gift_cards_invoiced: '',
            gift_cards_refunded: '',
            gift_message: {
              customer_id: 0,
              extension_attributes: {
                entity_id: '',
                entity_type: '',
                wrapping_add_printed_card: false,
                wrapping_allow_gift_receipt: false,
                wrapping_id: 0
              },
              gift_message_id: 0,
              message: '',
              recipient: '',
              sender: ''
            },
            gw_add_card: '',
            gw_allow_gift_receipt: '',
            gw_base_price: '',
            gw_base_price_incl_tax: '',
            gw_base_price_invoiced: '',
            gw_base_price_refunded: '',
            gw_base_tax_amount: '',
            gw_base_tax_amount_invoiced: '',
            gw_base_tax_amount_refunded: '',
            gw_card_base_price: '',
            gw_card_base_price_incl_tax: '',
            gw_card_base_price_invoiced: '',
            gw_card_base_price_refunded: '',
            gw_card_base_tax_amount: '',
            gw_card_base_tax_invoiced: '',
            gw_card_base_tax_refunded: '',
            gw_card_price: '',
            gw_card_price_incl_tax: '',
            gw_card_price_invoiced: '',
            gw_card_price_refunded: '',
            gw_card_tax_amount: '',
            gw_card_tax_invoiced: '',
            gw_card_tax_refunded: '',
            gw_id: '',
            gw_items_base_price: '',
            gw_items_base_price_incl_tax: '',
            gw_items_base_price_invoiced: '',
            gw_items_base_price_refunded: '',
            gw_items_base_tax_amount: '',
            gw_items_base_tax_invoiced: '',
            gw_items_base_tax_refunded: '',
            gw_items_price: '',
            gw_items_price_incl_tax: '',
            gw_items_price_invoiced: '',
            gw_items_price_refunded: '',
            gw_items_tax_amount: '',
            gw_items_tax_invoiced: '',
            gw_items_tax_refunded: '',
            gw_price: '',
            gw_price_incl_tax: '',
            gw_price_invoiced: '',
            gw_price_refunded: '',
            gw_tax_amount: '',
            gw_tax_amount_invoiced: '',
            gw_tax_amount_refunded: '',
            item_applied_taxes: [
              {
                applied_taxes: [{}],
                associated_item_id: 0,
                extension_attributes: {},
                item_id: 0,
                type: ''
              }
            ],
            payment_additional_info: [{key: '', value: ''}],
            reward_currency_amount: '',
            reward_points_balance: 0,
            shipping_assignments: [
              {
                extension_attributes: {},
                items: [
                  {
                    additional_data: '',
                    amount_refunded: '',
                    applied_rule_ids: '',
                    base_amount_refunded: '',
                    base_cost: '',
                    base_discount_amount: '',
                    base_discount_invoiced: '',
                    base_discount_refunded: '',
                    base_discount_tax_compensation_amount: '',
                    base_discount_tax_compensation_invoiced: '',
                    base_discount_tax_compensation_refunded: '',
                    base_original_price: '',
                    base_price: '',
                    base_price_incl_tax: '',
                    base_row_invoiced: '',
                    base_row_total: '',
                    base_row_total_incl_tax: '',
                    base_tax_amount: '',
                    base_tax_before_discount: '',
                    base_tax_invoiced: '',
                    base_tax_refunded: '',
                    base_weee_tax_applied_amount: '',
                    base_weee_tax_applied_row_amnt: '',
                    base_weee_tax_disposition: '',
                    base_weee_tax_row_disposition: '',
                    created_at: '',
                    description: '',
                    discount_amount: '',
                    discount_invoiced: '',
                    discount_percent: '',
                    discount_refunded: '',
                    discount_tax_compensation_amount: '',
                    discount_tax_compensation_canceled: '',
                    discount_tax_compensation_invoiced: '',
                    discount_tax_compensation_refunded: '',
                    event_id: 0,
                    ext_order_item_id: '',
                    extension_attributes: {
                      gift_message: {},
                      gw_base_price: '',
                      gw_base_price_invoiced: '',
                      gw_base_price_refunded: '',
                      gw_base_tax_amount: '',
                      gw_base_tax_amount_invoiced: '',
                      gw_base_tax_amount_refunded: '',
                      gw_id: '',
                      gw_price: '',
                      gw_price_invoiced: '',
                      gw_price_refunded: '',
                      gw_tax_amount: '',
                      gw_tax_amount_invoiced: '',
                      gw_tax_amount_refunded: '',
                      invoice_text_codes: [],
                      tax_codes: [],
                      vertex_tax_codes: []
                    },
                    free_shipping: 0,
                    gw_base_price: '',
                    gw_base_price_invoiced: '',
                    gw_base_price_refunded: '',
                    gw_base_tax_amount: '',
                    gw_base_tax_amount_invoiced: '',
                    gw_base_tax_amount_refunded: '',
                    gw_id: 0,
                    gw_price: '',
                    gw_price_invoiced: '',
                    gw_price_refunded: '',
                    gw_tax_amount: '',
                    gw_tax_amount_invoiced: '',
                    gw_tax_amount_refunded: '',
                    is_qty_decimal: 0,
                    is_virtual: 0,
                    item_id: 0,
                    locked_do_invoice: 0,
                    locked_do_ship: 0,
                    name: '',
                    no_discount: 0,
                    order_id: 0,
                    original_price: '',
                    parent_item: '',
                    parent_item_id: 0,
                    price: '',
                    price_incl_tax: '',
                    product_id: 0,
                    product_option: {
                      extension_attributes: {
                        bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                        configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                        custom_options: [
                          {
                            extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                            option_id: '',
                            option_value: ''
                          }
                        ],
                        downloadable_option: {downloadable_links: []},
                        giftcard_item_option: {
                          custom_giftcard_amount: '',
                          extension_attributes: {},
                          giftcard_amount: '',
                          giftcard_message: '',
                          giftcard_recipient_email: '',
                          giftcard_recipient_name: '',
                          giftcard_sender_email: '',
                          giftcard_sender_name: ''
                        }
                      }
                    },
                    product_type: '',
                    qty_backordered: '',
                    qty_canceled: '',
                    qty_invoiced: '',
                    qty_ordered: '',
                    qty_refunded: '',
                    qty_returned: '',
                    qty_shipped: '',
                    quote_item_id: 0,
                    row_invoiced: '',
                    row_total: '',
                    row_total_incl_tax: '',
                    row_weight: '',
                    sku: '',
                    store_id: 0,
                    tax_amount: '',
                    tax_before_discount: '',
                    tax_canceled: '',
                    tax_invoiced: '',
                    tax_percent: '',
                    tax_refunded: '',
                    updated_at: '',
                    weee_tax_applied: '',
                    weee_tax_applied_amount: '',
                    weee_tax_applied_row_amount: '',
                    weee_tax_disposition: '',
                    weee_tax_row_disposition: '',
                    weight: ''
                  }
                ],
                shipping: {
                  address: {},
                  extension_attributes: {
                    collection_point: {
                      city: '',
                      collection_point_id: '',
                      country: '',
                      name: '',
                      postcode: '',
                      recipient_address_id: 0,
                      region: '',
                      street: []
                    },
                    ext_order_id: '',
                    shipping_experience: {code: '', cost: '', label: ''}
                  },
                  method: '',
                  total: {
                    base_shipping_amount: '',
                    base_shipping_canceled: '',
                    base_shipping_discount_amount: '',
                    base_shipping_discount_tax_compensation_amnt: '',
                    base_shipping_incl_tax: '',
                    base_shipping_invoiced: '',
                    base_shipping_refunded: '',
                    base_shipping_tax_amount: '',
                    base_shipping_tax_refunded: '',
                    extension_attributes: {},
                    shipping_amount: '',
                    shipping_canceled: '',
                    shipping_discount_amount: '',
                    shipping_discount_tax_compensation_amount: '',
                    shipping_incl_tax: '',
                    shipping_invoiced: '',
                    shipping_refunded: '',
                    shipping_tax_amount: '',
                    shipping_tax_refunded: ''
                  }
                },
                stock_id: 0
              }
            ]
          },
          forced_shipment_with_invoice: 0,
          global_currency_code: '',
          grand_total: '',
          hold_before_state: '',
          hold_before_status: '',
          increment_id: '',
          is_virtual: 0,
          items: [{}],
          order_currency_code: '',
          original_increment_id: '',
          payment: {
            account_status: '',
            additional_data: '',
            additional_information: [],
            address_status: '',
            amount_authorized: '',
            amount_canceled: '',
            amount_ordered: '',
            amount_paid: '',
            amount_refunded: '',
            anet_trans_method: '',
            base_amount_authorized: '',
            base_amount_canceled: '',
            base_amount_ordered: '',
            base_amount_paid: '',
            base_amount_paid_online: '',
            base_amount_refunded: '',
            base_amount_refunded_online: '',
            base_shipping_amount: '',
            base_shipping_captured: '',
            base_shipping_refunded: '',
            cc_approval: '',
            cc_avs_status: '',
            cc_cid_status: '',
            cc_debug_request_body: '',
            cc_debug_response_body: '',
            cc_debug_response_serialized: '',
            cc_exp_month: '',
            cc_exp_year: '',
            cc_last4: '',
            cc_number_enc: '',
            cc_owner: '',
            cc_secure_verify: '',
            cc_ss_issue: '',
            cc_ss_start_month: '',
            cc_ss_start_year: '',
            cc_status: '',
            cc_status_description: '',
            cc_trans_id: '',
            cc_type: '',
            echeck_account_name: '',
            echeck_account_type: '',
            echeck_bank_name: '',
            echeck_routing_number: '',
            echeck_type: '',
            entity_id: 0,
            extension_attributes: {
              vault_payment_token: {
                created_at: '',
                customer_id: 0,
                entity_id: 0,
                expires_at: '',
                gateway_token: '',
                is_active: false,
                is_visible: false,
                payment_method_code: '',
                public_hash: '',
                token_details: '',
                type: ''
              }
            },
            last_trans_id: '',
            method: '',
            parent_id: 0,
            po_number: '',
            protection_eligibility: '',
            quote_payment_id: 0,
            shipping_amount: '',
            shipping_captured: '',
            shipping_refunded: ''
          },
          payment_auth_expiration: 0,
          payment_authorization_amount: '',
          protect_code: '',
          quote_address_id: 0,
          quote_id: 0,
          relation_child_id: '',
          relation_child_real_id: '',
          relation_parent_id: '',
          relation_parent_real_id: '',
          remote_ip: '',
          shipping_amount: '',
          shipping_canceled: '',
          shipping_description: '',
          shipping_discount_amount: '',
          shipping_discount_tax_compensation_amount: '',
          shipping_incl_tax: '',
          shipping_invoiced: '',
          shipping_refunded: '',
          shipping_tax_amount: '',
          shipping_tax_refunded: '',
          state: '',
          status: '',
          status_histories: [
            {
              comment: '',
              created_at: '',
              entity_id: 0,
              entity_name: '',
              extension_attributes: {},
              is_customer_notified: 0,
              is_visible_on_front: 0,
              parent_id: 0,
              status: ''
            }
          ],
          store_currency_code: '',
          store_id: 0,
          store_name: '',
          store_to_base_rate: '',
          store_to_order_rate: '',
          subtotal: '',
          subtotal_canceled: '',
          subtotal_incl_tax: '',
          subtotal_invoiced: '',
          subtotal_refunded: '',
          tax_amount: '',
          tax_canceled: '',
          tax_invoiced: '',
          tax_refunded: '',
          total_canceled: '',
          total_due: '',
          total_invoiced: '',
          total_item_count: 0,
          total_offline_refunded: '',
          total_online_refunded: '',
          total_paid: '',
          total_qty_ordered: '',
          total_refunded: '',
          updated_at: '',
          weight: '',
          x_forwarded_for: ''
        },
        vertex_tax_calculation_shipping_address: {}
      },
      global_currency_code: '',
      grand_total: '',
      increment_id: '',
      is_used_for_refund: 0,
      items: [
        {
          additional_data: '',
          base_cost: '',
          base_discount_amount: '',
          base_discount_tax_compensation_amount: '',
          base_price: '',
          base_price_incl_tax: '',
          base_row_total: '',
          base_row_total_incl_tax: '',
          base_tax_amount: '',
          description: '',
          discount_amount: '',
          discount_tax_compensation_amount: '',
          entity_id: 0,
          extension_attributes: {invoice_text_codes: [], tax_codes: [], vertex_tax_codes: []},
          name: '',
          order_item_id: 0,
          parent_id: 0,
          price: '',
          price_incl_tax: '',
          product_id: 0,
          qty: '',
          row_total: '',
          row_total_incl_tax: '',
          sku: '',
          tax_amount: ''
        }
      ],
      order_currency_code: '',
      order_id: 0,
      shipping_address_id: 0,
      shipping_amount: '',
      shipping_discount_tax_compensation_amount: '',
      shipping_incl_tax: '',
      shipping_tax_amount: '',
      state: 0,
      store_currency_code: '',
      store_id: 0,
      store_to_base_rate: '',
      store_to_order_rate: '',
      subtotal: '',
      subtotal_incl_tax: '',
      tax_amount: '',
      total_qty: '',
      transaction_id: '',
      updated_at: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/invoices/';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"base_currency_code":"","base_discount_amount":"","base_discount_tax_compensation_amount":"","base_grand_total":"","base_shipping_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_tax_amount":"","base_subtotal":"","base_subtotal_incl_tax":"","base_tax_amount":"","base_to_global_rate":"","base_to_order_rate":"","base_total_refunded":"","billing_address_id":0,"can_void_flag":0,"comments":[{"comment":"","created_at":"","entity_id":0,"extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_id":0}],"created_at":"","discount_amount":"","discount_description":"","discount_tax_compensation_amount":"","email_sent":0,"entity_id":0,"extension_attributes":{"base_customer_balance_amount":"","base_gift_cards_amount":"","customer_balance_amount":"","gift_cards_amount":"","gw_base_price":"","gw_base_tax_amount":"","gw_card_base_price":"","gw_card_base_tax_amount":"","gw_card_price":"","gw_card_tax_amount":"","gw_items_base_price":"","gw_items_base_tax_amount":"","gw_items_price":"","gw_items_tax_amount":"","gw_price":"","gw_tax_amount":"","vertex_tax_calculation_billing_address":{"address_type":"","city":"","company":"","country_id":"","customer_address_id":0,"customer_id":0,"email":"","entity_id":0,"extension_attributes":{"checkout_fields":[{"attribute_code":"","value":""}]},"fax":"","firstname":"","lastname":"","middlename":"","parent_id":0,"postcode":"","prefix":"","region":"","region_code":"","region_id":0,"street":[],"suffix":"","telephone":"","vat_id":"","vat_is_valid":0,"vat_request_date":"","vat_request_id":"","vat_request_success":0},"vertex_tax_calculation_order":{"adjustment_negative":"","adjustment_positive":"","applied_rule_ids":"","base_adjustment_negative":"","base_adjustment_positive":"","base_currency_code":"","base_discount_amount":"","base_discount_canceled":"","base_discount_invoiced":"","base_discount_refunded":"","base_discount_tax_compensation_amount":"","base_discount_tax_compensation_invoiced":"","base_discount_tax_compensation_refunded":"","base_grand_total":"","base_shipping_amount":"","base_shipping_canceled":"","base_shipping_discount_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_invoiced":"","base_shipping_refunded":"","base_shipping_tax_amount":"","base_shipping_tax_refunded":"","base_subtotal":"","base_subtotal_canceled":"","base_subtotal_incl_tax":"","base_subtotal_invoiced":"","base_subtotal_refunded":"","base_tax_amount":"","base_tax_canceled":"","base_tax_invoiced":"","base_tax_refunded":"","base_to_global_rate":"","base_to_order_rate":"","base_total_canceled":"","base_total_due":"","base_total_invoiced":"","base_total_invoiced_cost":"","base_total_offline_refunded":"","base_total_online_refunded":"","base_total_paid":"","base_total_qty_ordered":"","base_total_refunded":"","billing_address":{},"billing_address_id":0,"can_ship_partially":0,"can_ship_partially_item":0,"coupon_code":"","created_at":"","customer_dob":"","customer_email":"","customer_firstname":"","customer_gender":0,"customer_group_id":0,"customer_id":0,"customer_is_guest":0,"customer_lastname":"","customer_middlename":"","customer_note":"","customer_note_notify":0,"customer_prefix":"","customer_suffix":"","customer_taxvat":"","discount_amount":"","discount_canceled":"","discount_description":"","discount_invoiced":"","discount_refunded":"","discount_tax_compensation_amount":"","discount_tax_compensation_invoiced":"","discount_tax_compensation_refunded":"","edit_increment":0,"email_sent":0,"entity_id":0,"ext_customer_id":"","ext_order_id":"","extension_attributes":{"amazon_order_reference_id":"","applied_taxes":[{"amount":"","base_amount":"","code":"","extension_attributes":{"rates":[{"code":"","extension_attributes":{},"percent":"","title":""}]},"percent":"","title":""}],"base_customer_balance_amount":"","base_customer_balance_invoiced":"","base_customer_balance_refunded":"","base_customer_balance_total_refunded":"","base_gift_cards_amount":"","base_gift_cards_invoiced":"","base_gift_cards_refunded":"","base_reward_currency_amount":"","company_order_attributes":{"company_id":0,"company_name":"","extension_attributes":{},"order_id":0},"converting_from_quote":false,"customer_balance_amount":"","customer_balance_invoiced":"","customer_balance_refunded":"","customer_balance_total_refunded":"","gift_cards":[{"amount":"","base_amount":"","code":"","id":0}],"gift_cards_amount":"","gift_cards_invoiced":"","gift_cards_refunded":"","gift_message":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""},"gw_add_card":"","gw_allow_gift_receipt":"","gw_base_price":"","gw_base_price_incl_tax":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_card_base_price":"","gw_card_base_price_incl_tax":"","gw_card_base_price_invoiced":"","gw_card_base_price_refunded":"","gw_card_base_tax_amount":"","gw_card_base_tax_invoiced":"","gw_card_base_tax_refunded":"","gw_card_price":"","gw_card_price_incl_tax":"","gw_card_price_invoiced":"","gw_card_price_refunded":"","gw_card_tax_amount":"","gw_card_tax_invoiced":"","gw_card_tax_refunded":"","gw_id":"","gw_items_base_price":"","gw_items_base_price_incl_tax":"","gw_items_base_price_invoiced":"","gw_items_base_price_refunded":"","gw_items_base_tax_amount":"","gw_items_base_tax_invoiced":"","gw_items_base_tax_refunded":"","gw_items_price":"","gw_items_price_incl_tax":"","gw_items_price_invoiced":"","gw_items_price_refunded":"","gw_items_tax_amount":"","gw_items_tax_invoiced":"","gw_items_tax_refunded":"","gw_price":"","gw_price_incl_tax":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","item_applied_taxes":[{"applied_taxes":[{}],"associated_item_id":0,"extension_attributes":{},"item_id":0,"type":""}],"payment_additional_info":[{"key":"","value":""}],"reward_currency_amount":"","reward_points_balance":0,"shipping_assignments":[{"extension_attributes":{},"items":[{"additional_data":"","amount_refunded":"","applied_rule_ids":"","base_amount_refunded":"","base_cost":"","base_discount_amount":"","base_discount_invoiced":"","base_discount_refunded":"","base_discount_tax_compensation_amount":"","base_discount_tax_compensation_invoiced":"","base_discount_tax_compensation_refunded":"","base_original_price":"","base_price":"","base_price_incl_tax":"","base_row_invoiced":"","base_row_total":"","base_row_total_incl_tax":"","base_tax_amount":"","base_tax_before_discount":"","base_tax_invoiced":"","base_tax_refunded":"","base_weee_tax_applied_amount":"","base_weee_tax_applied_row_amnt":"","base_weee_tax_disposition":"","base_weee_tax_row_disposition":"","created_at":"","description":"","discount_amount":"","discount_invoiced":"","discount_percent":"","discount_refunded":"","discount_tax_compensation_amount":"","discount_tax_compensation_canceled":"","discount_tax_compensation_invoiced":"","discount_tax_compensation_refunded":"","event_id":0,"ext_order_item_id":"","extension_attributes":{"gift_message":{},"gw_base_price":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_id":"","gw_price":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","invoice_text_codes":[],"tax_codes":[],"vertex_tax_codes":[]},"free_shipping":0,"gw_base_price":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_id":0,"gw_price":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","is_qty_decimal":0,"is_virtual":0,"item_id":0,"locked_do_invoice":0,"locked_do_ship":0,"name":"","no_discount":0,"order_id":0,"original_price":"","parent_item":"","parent_item_id":0,"price":"","price_incl_tax":"","product_id":0,"product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty_backordered":"","qty_canceled":"","qty_invoiced":"","qty_ordered":"","qty_refunded":"","qty_returned":"","qty_shipped":"","quote_item_id":0,"row_invoiced":"","row_total":"","row_total_incl_tax":"","row_weight":"","sku":"","store_id":0,"tax_amount":"","tax_before_discount":"","tax_canceled":"","tax_invoiced":"","tax_percent":"","tax_refunded":"","updated_at":"","weee_tax_applied":"","weee_tax_applied_amount":"","weee_tax_applied_row_amount":"","weee_tax_disposition":"","weee_tax_row_disposition":"","weight":""}],"shipping":{"address":{},"extension_attributes":{"collection_point":{"city":"","collection_point_id":"","country":"","name":"","postcode":"","recipient_address_id":0,"region":"","street":[]},"ext_order_id":"","shipping_experience":{"code":"","cost":"","label":""}},"method":"","total":{"base_shipping_amount":"","base_shipping_canceled":"","base_shipping_discount_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_invoiced":"","base_shipping_refunded":"","base_shipping_tax_amount":"","base_shipping_tax_refunded":"","extension_attributes":{},"shipping_amount":"","shipping_canceled":"","shipping_discount_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_invoiced":"","shipping_refunded":"","shipping_tax_amount":"","shipping_tax_refunded":""}},"stock_id":0}]},"forced_shipment_with_invoice":0,"global_currency_code":"","grand_total":"","hold_before_state":"","hold_before_status":"","increment_id":"","is_virtual":0,"items":[{}],"order_currency_code":"","original_increment_id":"","payment":{"account_status":"","additional_data":"","additional_information":[],"address_status":"","amount_authorized":"","amount_canceled":"","amount_ordered":"","amount_paid":"","amount_refunded":"","anet_trans_method":"","base_amount_authorized":"","base_amount_canceled":"","base_amount_ordered":"","base_amount_paid":"","base_amount_paid_online":"","base_amount_refunded":"","base_amount_refunded_online":"","base_shipping_amount":"","base_shipping_captured":"","base_shipping_refunded":"","cc_approval":"","cc_avs_status":"","cc_cid_status":"","cc_debug_request_body":"","cc_debug_response_body":"","cc_debug_response_serialized":"","cc_exp_month":"","cc_exp_year":"","cc_last4":"","cc_number_enc":"","cc_owner":"","cc_secure_verify":"","cc_ss_issue":"","cc_ss_start_month":"","cc_ss_start_year":"","cc_status":"","cc_status_description":"","cc_trans_id":"","cc_type":"","echeck_account_name":"","echeck_account_type":"","echeck_bank_name":"","echeck_routing_number":"","echeck_type":"","entity_id":0,"extension_attributes":{"vault_payment_token":{"created_at":"","customer_id":0,"entity_id":0,"expires_at":"","gateway_token":"","is_active":false,"is_visible":false,"payment_method_code":"","public_hash":"","token_details":"","type":""}},"last_trans_id":"","method":"","parent_id":0,"po_number":"","protection_eligibility":"","quote_payment_id":0,"shipping_amount":"","shipping_captured":"","shipping_refunded":""},"payment_auth_expiration":0,"payment_authorization_amount":"","protect_code":"","quote_address_id":0,"quote_id":0,"relation_child_id":"","relation_child_real_id":"","relation_parent_id":"","relation_parent_real_id":"","remote_ip":"","shipping_amount":"","shipping_canceled":"","shipping_description":"","shipping_discount_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_invoiced":"","shipping_refunded":"","shipping_tax_amount":"","shipping_tax_refunded":"","state":"","status":"","status_histories":[{"comment":"","created_at":"","entity_id":0,"entity_name":"","extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_id":0,"status":""}],"store_currency_code":"","store_id":0,"store_name":"","store_to_base_rate":"","store_to_order_rate":"","subtotal":"","subtotal_canceled":"","subtotal_incl_tax":"","subtotal_invoiced":"","subtotal_refunded":"","tax_amount":"","tax_canceled":"","tax_invoiced":"","tax_refunded":"","total_canceled":"","total_due":"","total_invoiced":"","total_item_count":0,"total_offline_refunded":"","total_online_refunded":"","total_paid":"","total_qty_ordered":"","total_refunded":"","updated_at":"","weight":"","x_forwarded_for":""},"vertex_tax_calculation_shipping_address":{}},"global_currency_code":"","grand_total":"","increment_id":"","is_used_for_refund":0,"items":[{"additional_data":"","base_cost":"","base_discount_amount":"","base_discount_tax_compensation_amount":"","base_price":"","base_price_incl_tax":"","base_row_total":"","base_row_total_incl_tax":"","base_tax_amount":"","description":"","discount_amount":"","discount_tax_compensation_amount":"","entity_id":0,"extension_attributes":{"invoice_text_codes":[],"tax_codes":[],"vertex_tax_codes":[]},"name":"","order_item_id":0,"parent_id":0,"price":"","price_incl_tax":"","product_id":0,"qty":"","row_total":"","row_total_incl_tax":"","sku":"","tax_amount":""}],"order_currency_code":"","order_id":0,"shipping_address_id":0,"shipping_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_tax_amount":"","state":0,"store_currency_code":"","store_id":0,"store_to_base_rate":"","store_to_order_rate":"","subtotal":"","subtotal_incl_tax":"","tax_amount":"","total_qty":"","transaction_id":"","updated_at":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/invoices/',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "entity": {\n    "base_currency_code": "",\n    "base_discount_amount": "",\n    "base_discount_tax_compensation_amount": "",\n    "base_grand_total": "",\n    "base_shipping_amount": "",\n    "base_shipping_discount_tax_compensation_amnt": "",\n    "base_shipping_incl_tax": "",\n    "base_shipping_tax_amount": "",\n    "base_subtotal": "",\n    "base_subtotal_incl_tax": "",\n    "base_tax_amount": "",\n    "base_to_global_rate": "",\n    "base_to_order_rate": "",\n    "base_total_refunded": "",\n    "billing_address_id": 0,\n    "can_void_flag": 0,\n    "comments": [\n      {\n        "comment": "",\n        "created_at": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "is_customer_notified": 0,\n        "is_visible_on_front": 0,\n        "parent_id": 0\n      }\n    ],\n    "created_at": "",\n    "discount_amount": "",\n    "discount_description": "",\n    "discount_tax_compensation_amount": "",\n    "email_sent": 0,\n    "entity_id": 0,\n    "extension_attributes": {\n      "base_customer_balance_amount": "",\n      "base_gift_cards_amount": "",\n      "customer_balance_amount": "",\n      "gift_cards_amount": "",\n      "gw_base_price": "",\n      "gw_base_tax_amount": "",\n      "gw_card_base_price": "",\n      "gw_card_base_tax_amount": "",\n      "gw_card_price": "",\n      "gw_card_tax_amount": "",\n      "gw_items_base_price": "",\n      "gw_items_base_tax_amount": "",\n      "gw_items_price": "",\n      "gw_items_tax_amount": "",\n      "gw_price": "",\n      "gw_tax_amount": "",\n      "vertex_tax_calculation_billing_address": {\n        "address_type": "",\n        "city": "",\n        "company": "",\n        "country_id": "",\n        "customer_address_id": 0,\n        "customer_id": 0,\n        "email": "",\n        "entity_id": 0,\n        "extension_attributes": {\n          "checkout_fields": [\n            {\n              "attribute_code": "",\n              "value": ""\n            }\n          ]\n        },\n        "fax": "",\n        "firstname": "",\n        "lastname": "",\n        "middlename": "",\n        "parent_id": 0,\n        "postcode": "",\n        "prefix": "",\n        "region": "",\n        "region_code": "",\n        "region_id": 0,\n        "street": [],\n        "suffix": "",\n        "telephone": "",\n        "vat_id": "",\n        "vat_is_valid": 0,\n        "vat_request_date": "",\n        "vat_request_id": "",\n        "vat_request_success": 0\n      },\n      "vertex_tax_calculation_order": {\n        "adjustment_negative": "",\n        "adjustment_positive": "",\n        "applied_rule_ids": "",\n        "base_adjustment_negative": "",\n        "base_adjustment_positive": "",\n        "base_currency_code": "",\n        "base_discount_amount": "",\n        "base_discount_canceled": "",\n        "base_discount_invoiced": "",\n        "base_discount_refunded": "",\n        "base_discount_tax_compensation_amount": "",\n        "base_discount_tax_compensation_invoiced": "",\n        "base_discount_tax_compensation_refunded": "",\n        "base_grand_total": "",\n        "base_shipping_amount": "",\n        "base_shipping_canceled": "",\n        "base_shipping_discount_amount": "",\n        "base_shipping_discount_tax_compensation_amnt": "",\n        "base_shipping_incl_tax": "",\n        "base_shipping_invoiced": "",\n        "base_shipping_refunded": "",\n        "base_shipping_tax_amount": "",\n        "base_shipping_tax_refunded": "",\n        "base_subtotal": "",\n        "base_subtotal_canceled": "",\n        "base_subtotal_incl_tax": "",\n        "base_subtotal_invoiced": "",\n        "base_subtotal_refunded": "",\n        "base_tax_amount": "",\n        "base_tax_canceled": "",\n        "base_tax_invoiced": "",\n        "base_tax_refunded": "",\n        "base_to_global_rate": "",\n        "base_to_order_rate": "",\n        "base_total_canceled": "",\n        "base_total_due": "",\n        "base_total_invoiced": "",\n        "base_total_invoiced_cost": "",\n        "base_total_offline_refunded": "",\n        "base_total_online_refunded": "",\n        "base_total_paid": "",\n        "base_total_qty_ordered": "",\n        "base_total_refunded": "",\n        "billing_address": {},\n        "billing_address_id": 0,\n        "can_ship_partially": 0,\n        "can_ship_partially_item": 0,\n        "coupon_code": "",\n        "created_at": "",\n        "customer_dob": "",\n        "customer_email": "",\n        "customer_firstname": "",\n        "customer_gender": 0,\n        "customer_group_id": 0,\n        "customer_id": 0,\n        "customer_is_guest": 0,\n        "customer_lastname": "",\n        "customer_middlename": "",\n        "customer_note": "",\n        "customer_note_notify": 0,\n        "customer_prefix": "",\n        "customer_suffix": "",\n        "customer_taxvat": "",\n        "discount_amount": "",\n        "discount_canceled": "",\n        "discount_description": "",\n        "discount_invoiced": "",\n        "discount_refunded": "",\n        "discount_tax_compensation_amount": "",\n        "discount_tax_compensation_invoiced": "",\n        "discount_tax_compensation_refunded": "",\n        "edit_increment": 0,\n        "email_sent": 0,\n        "entity_id": 0,\n        "ext_customer_id": "",\n        "ext_order_id": "",\n        "extension_attributes": {\n          "amazon_order_reference_id": "",\n          "applied_taxes": [\n            {\n              "amount": "",\n              "base_amount": "",\n              "code": "",\n              "extension_attributes": {\n                "rates": [\n                  {\n                    "code": "",\n                    "extension_attributes": {},\n                    "percent": "",\n                    "title": ""\n                  }\n                ]\n              },\n              "percent": "",\n              "title": ""\n            }\n          ],\n          "base_customer_balance_amount": "",\n          "base_customer_balance_invoiced": "",\n          "base_customer_balance_refunded": "",\n          "base_customer_balance_total_refunded": "",\n          "base_gift_cards_amount": "",\n          "base_gift_cards_invoiced": "",\n          "base_gift_cards_refunded": "",\n          "base_reward_currency_amount": "",\n          "company_order_attributes": {\n            "company_id": 0,\n            "company_name": "",\n            "extension_attributes": {},\n            "order_id": 0\n          },\n          "converting_from_quote": false,\n          "customer_balance_amount": "",\n          "customer_balance_invoiced": "",\n          "customer_balance_refunded": "",\n          "customer_balance_total_refunded": "",\n          "gift_cards": [\n            {\n              "amount": "",\n              "base_amount": "",\n              "code": "",\n              "id": 0\n            }\n          ],\n          "gift_cards_amount": "",\n          "gift_cards_invoiced": "",\n          "gift_cards_refunded": "",\n          "gift_message": {\n            "customer_id": 0,\n            "extension_attributes": {\n              "entity_id": "",\n              "entity_type": "",\n              "wrapping_add_printed_card": false,\n              "wrapping_allow_gift_receipt": false,\n              "wrapping_id": 0\n            },\n            "gift_message_id": 0,\n            "message": "",\n            "recipient": "",\n            "sender": ""\n          },\n          "gw_add_card": "",\n          "gw_allow_gift_receipt": "",\n          "gw_base_price": "",\n          "gw_base_price_incl_tax": "",\n          "gw_base_price_invoiced": "",\n          "gw_base_price_refunded": "",\n          "gw_base_tax_amount": "",\n          "gw_base_tax_amount_invoiced": "",\n          "gw_base_tax_amount_refunded": "",\n          "gw_card_base_price": "",\n          "gw_card_base_price_incl_tax": "",\n          "gw_card_base_price_invoiced": "",\n          "gw_card_base_price_refunded": "",\n          "gw_card_base_tax_amount": "",\n          "gw_card_base_tax_invoiced": "",\n          "gw_card_base_tax_refunded": "",\n          "gw_card_price": "",\n          "gw_card_price_incl_tax": "",\n          "gw_card_price_invoiced": "",\n          "gw_card_price_refunded": "",\n          "gw_card_tax_amount": "",\n          "gw_card_tax_invoiced": "",\n          "gw_card_tax_refunded": "",\n          "gw_id": "",\n          "gw_items_base_price": "",\n          "gw_items_base_price_incl_tax": "",\n          "gw_items_base_price_invoiced": "",\n          "gw_items_base_price_refunded": "",\n          "gw_items_base_tax_amount": "",\n          "gw_items_base_tax_invoiced": "",\n          "gw_items_base_tax_refunded": "",\n          "gw_items_price": "",\n          "gw_items_price_incl_tax": "",\n          "gw_items_price_invoiced": "",\n          "gw_items_price_refunded": "",\n          "gw_items_tax_amount": "",\n          "gw_items_tax_invoiced": "",\n          "gw_items_tax_refunded": "",\n          "gw_price": "",\n          "gw_price_incl_tax": "",\n          "gw_price_invoiced": "",\n          "gw_price_refunded": "",\n          "gw_tax_amount": "",\n          "gw_tax_amount_invoiced": "",\n          "gw_tax_amount_refunded": "",\n          "item_applied_taxes": [\n            {\n              "applied_taxes": [\n                {}\n              ],\n              "associated_item_id": 0,\n              "extension_attributes": {},\n              "item_id": 0,\n              "type": ""\n            }\n          ],\n          "payment_additional_info": [\n            {\n              "key": "",\n              "value": ""\n            }\n          ],\n          "reward_currency_amount": "",\n          "reward_points_balance": 0,\n          "shipping_assignments": [\n            {\n              "extension_attributes": {},\n              "items": [\n                {\n                  "additional_data": "",\n                  "amount_refunded": "",\n                  "applied_rule_ids": "",\n                  "base_amount_refunded": "",\n                  "base_cost": "",\n                  "base_discount_amount": "",\n                  "base_discount_invoiced": "",\n                  "base_discount_refunded": "",\n                  "base_discount_tax_compensation_amount": "",\n                  "base_discount_tax_compensation_invoiced": "",\n                  "base_discount_tax_compensation_refunded": "",\n                  "base_original_price": "",\n                  "base_price": "",\n                  "base_price_incl_tax": "",\n                  "base_row_invoiced": "",\n                  "base_row_total": "",\n                  "base_row_total_incl_tax": "",\n                  "base_tax_amount": "",\n                  "base_tax_before_discount": "",\n                  "base_tax_invoiced": "",\n                  "base_tax_refunded": "",\n                  "base_weee_tax_applied_amount": "",\n                  "base_weee_tax_applied_row_amnt": "",\n                  "base_weee_tax_disposition": "",\n                  "base_weee_tax_row_disposition": "",\n                  "created_at": "",\n                  "description": "",\n                  "discount_amount": "",\n                  "discount_invoiced": "",\n                  "discount_percent": "",\n                  "discount_refunded": "",\n                  "discount_tax_compensation_amount": "",\n                  "discount_tax_compensation_canceled": "",\n                  "discount_tax_compensation_invoiced": "",\n                  "discount_tax_compensation_refunded": "",\n                  "event_id": 0,\n                  "ext_order_item_id": "",\n                  "extension_attributes": {\n                    "gift_message": {},\n                    "gw_base_price": "",\n                    "gw_base_price_invoiced": "",\n                    "gw_base_price_refunded": "",\n                    "gw_base_tax_amount": "",\n                    "gw_base_tax_amount_invoiced": "",\n                    "gw_base_tax_amount_refunded": "",\n                    "gw_id": "",\n                    "gw_price": "",\n                    "gw_price_invoiced": "",\n                    "gw_price_refunded": "",\n                    "gw_tax_amount": "",\n                    "gw_tax_amount_invoiced": "",\n                    "gw_tax_amount_refunded": "",\n                    "invoice_text_codes": [],\n                    "tax_codes": [],\n                    "vertex_tax_codes": []\n                  },\n                  "free_shipping": 0,\n                  "gw_base_price": "",\n                  "gw_base_price_invoiced": "",\n                  "gw_base_price_refunded": "",\n                  "gw_base_tax_amount": "",\n                  "gw_base_tax_amount_invoiced": "",\n                  "gw_base_tax_amount_refunded": "",\n                  "gw_id": 0,\n                  "gw_price": "",\n                  "gw_price_invoiced": "",\n                  "gw_price_refunded": "",\n                  "gw_tax_amount": "",\n                  "gw_tax_amount_invoiced": "",\n                  "gw_tax_amount_refunded": "",\n                  "is_qty_decimal": 0,\n                  "is_virtual": 0,\n                  "item_id": 0,\n                  "locked_do_invoice": 0,\n                  "locked_do_ship": 0,\n                  "name": "",\n                  "no_discount": 0,\n                  "order_id": 0,\n                  "original_price": "",\n                  "parent_item": "",\n                  "parent_item_id": 0,\n                  "price": "",\n                  "price_incl_tax": "",\n                  "product_id": 0,\n                  "product_option": {\n                    "extension_attributes": {\n                      "bundle_options": [\n                        {\n                          "extension_attributes": {},\n                          "option_id": 0,\n                          "option_qty": 0,\n                          "option_selections": []\n                        }\n                      ],\n                      "configurable_item_options": [\n                        {\n                          "extension_attributes": {},\n                          "option_id": "",\n                          "option_value": 0\n                        }\n                      ],\n                      "custom_options": [\n                        {\n                          "extension_attributes": {\n                            "file_info": {\n                              "base64_encoded_data": "",\n                              "name": "",\n                              "type": ""\n                            }\n                          },\n                          "option_id": "",\n                          "option_value": ""\n                        }\n                      ],\n                      "downloadable_option": {\n                        "downloadable_links": []\n                      },\n                      "giftcard_item_option": {\n                        "custom_giftcard_amount": "",\n                        "extension_attributes": {},\n                        "giftcard_amount": "",\n                        "giftcard_message": "",\n                        "giftcard_recipient_email": "",\n                        "giftcard_recipient_name": "",\n                        "giftcard_sender_email": "",\n                        "giftcard_sender_name": ""\n                      }\n                    }\n                  },\n                  "product_type": "",\n                  "qty_backordered": "",\n                  "qty_canceled": "",\n                  "qty_invoiced": "",\n                  "qty_ordered": "",\n                  "qty_refunded": "",\n                  "qty_returned": "",\n                  "qty_shipped": "",\n                  "quote_item_id": 0,\n                  "row_invoiced": "",\n                  "row_total": "",\n                  "row_total_incl_tax": "",\n                  "row_weight": "",\n                  "sku": "",\n                  "store_id": 0,\n                  "tax_amount": "",\n                  "tax_before_discount": "",\n                  "tax_canceled": "",\n                  "tax_invoiced": "",\n                  "tax_percent": "",\n                  "tax_refunded": "",\n                  "updated_at": "",\n                  "weee_tax_applied": "",\n                  "weee_tax_applied_amount": "",\n                  "weee_tax_applied_row_amount": "",\n                  "weee_tax_disposition": "",\n                  "weee_tax_row_disposition": "",\n                  "weight": ""\n                }\n              ],\n              "shipping": {\n                "address": {},\n                "extension_attributes": {\n                  "collection_point": {\n                    "city": "",\n                    "collection_point_id": "",\n                    "country": "",\n                    "name": "",\n                    "postcode": "",\n                    "recipient_address_id": 0,\n                    "region": "",\n                    "street": []\n                  },\n                  "ext_order_id": "",\n                  "shipping_experience": {\n                    "code": "",\n                    "cost": "",\n                    "label": ""\n                  }\n                },\n                "method": "",\n                "total": {\n                  "base_shipping_amount": "",\n                  "base_shipping_canceled": "",\n                  "base_shipping_discount_amount": "",\n                  "base_shipping_discount_tax_compensation_amnt": "",\n                  "base_shipping_incl_tax": "",\n                  "base_shipping_invoiced": "",\n                  "base_shipping_refunded": "",\n                  "base_shipping_tax_amount": "",\n                  "base_shipping_tax_refunded": "",\n                  "extension_attributes": {},\n                  "shipping_amount": "",\n                  "shipping_canceled": "",\n                  "shipping_discount_amount": "",\n                  "shipping_discount_tax_compensation_amount": "",\n                  "shipping_incl_tax": "",\n                  "shipping_invoiced": "",\n                  "shipping_refunded": "",\n                  "shipping_tax_amount": "",\n                  "shipping_tax_refunded": ""\n                }\n              },\n              "stock_id": 0\n            }\n          ]\n        },\n        "forced_shipment_with_invoice": 0,\n        "global_currency_code": "",\n        "grand_total": "",\n        "hold_before_state": "",\n        "hold_before_status": "",\n        "increment_id": "",\n        "is_virtual": 0,\n        "items": [\n          {}\n        ],\n        "order_currency_code": "",\n        "original_increment_id": "",\n        "payment": {\n          "account_status": "",\n          "additional_data": "",\n          "additional_information": [],\n          "address_status": "",\n          "amount_authorized": "",\n          "amount_canceled": "",\n          "amount_ordered": "",\n          "amount_paid": "",\n          "amount_refunded": "",\n          "anet_trans_method": "",\n          "base_amount_authorized": "",\n          "base_amount_canceled": "",\n          "base_amount_ordered": "",\n          "base_amount_paid": "",\n          "base_amount_paid_online": "",\n          "base_amount_refunded": "",\n          "base_amount_refunded_online": "",\n          "base_shipping_amount": "",\n          "base_shipping_captured": "",\n          "base_shipping_refunded": "",\n          "cc_approval": "",\n          "cc_avs_status": "",\n          "cc_cid_status": "",\n          "cc_debug_request_body": "",\n          "cc_debug_response_body": "",\n          "cc_debug_response_serialized": "",\n          "cc_exp_month": "",\n          "cc_exp_year": "",\n          "cc_last4": "",\n          "cc_number_enc": "",\n          "cc_owner": "",\n          "cc_secure_verify": "",\n          "cc_ss_issue": "",\n          "cc_ss_start_month": "",\n          "cc_ss_start_year": "",\n          "cc_status": "",\n          "cc_status_description": "",\n          "cc_trans_id": "",\n          "cc_type": "",\n          "echeck_account_name": "",\n          "echeck_account_type": "",\n          "echeck_bank_name": "",\n          "echeck_routing_number": "",\n          "echeck_type": "",\n          "entity_id": 0,\n          "extension_attributes": {\n            "vault_payment_token": {\n              "created_at": "",\n              "customer_id": 0,\n              "entity_id": 0,\n              "expires_at": "",\n              "gateway_token": "",\n              "is_active": false,\n              "is_visible": false,\n              "payment_method_code": "",\n              "public_hash": "",\n              "token_details": "",\n              "type": ""\n            }\n          },\n          "last_trans_id": "",\n          "method": "",\n          "parent_id": 0,\n          "po_number": "",\n          "protection_eligibility": "",\n          "quote_payment_id": 0,\n          "shipping_amount": "",\n          "shipping_captured": "",\n          "shipping_refunded": ""\n        },\n        "payment_auth_expiration": 0,\n        "payment_authorization_amount": "",\n        "protect_code": "",\n        "quote_address_id": 0,\n        "quote_id": 0,\n        "relation_child_id": "",\n        "relation_child_real_id": "",\n        "relation_parent_id": "",\n        "relation_parent_real_id": "",\n        "remote_ip": "",\n        "shipping_amount": "",\n        "shipping_canceled": "",\n        "shipping_description": "",\n        "shipping_discount_amount": "",\n        "shipping_discount_tax_compensation_amount": "",\n        "shipping_incl_tax": "",\n        "shipping_invoiced": "",\n        "shipping_refunded": "",\n        "shipping_tax_amount": "",\n        "shipping_tax_refunded": "",\n        "state": "",\n        "status": "",\n        "status_histories": [\n          {\n            "comment": "",\n            "created_at": "",\n            "entity_id": 0,\n            "entity_name": "",\n            "extension_attributes": {},\n            "is_customer_notified": 0,\n            "is_visible_on_front": 0,\n            "parent_id": 0,\n            "status": ""\n          }\n        ],\n        "store_currency_code": "",\n        "store_id": 0,\n        "store_name": "",\n        "store_to_base_rate": "",\n        "store_to_order_rate": "",\n        "subtotal": "",\n        "subtotal_canceled": "",\n        "subtotal_incl_tax": "",\n        "subtotal_invoiced": "",\n        "subtotal_refunded": "",\n        "tax_amount": "",\n        "tax_canceled": "",\n        "tax_invoiced": "",\n        "tax_refunded": "",\n        "total_canceled": "",\n        "total_due": "",\n        "total_invoiced": "",\n        "total_item_count": 0,\n        "total_offline_refunded": "",\n        "total_online_refunded": "",\n        "total_paid": "",\n        "total_qty_ordered": "",\n        "total_refunded": "",\n        "updated_at": "",\n        "weight": "",\n        "x_forwarded_for": ""\n      },\n      "vertex_tax_calculation_shipping_address": {}\n    },\n    "global_currency_code": "",\n    "grand_total": "",\n    "increment_id": "",\n    "is_used_for_refund": 0,\n    "items": [\n      {\n        "additional_data": "",\n        "base_cost": "",\n        "base_discount_amount": "",\n        "base_discount_tax_compensation_amount": "",\n        "base_price": "",\n        "base_price_incl_tax": "",\n        "base_row_total": "",\n        "base_row_total_incl_tax": "",\n        "base_tax_amount": "",\n        "description": "",\n        "discount_amount": "",\n        "discount_tax_compensation_amount": "",\n        "entity_id": 0,\n        "extension_attributes": {\n          "invoice_text_codes": [],\n          "tax_codes": [],\n          "vertex_tax_codes": []\n        },\n        "name": "",\n        "order_item_id": 0,\n        "parent_id": 0,\n        "price": "",\n        "price_incl_tax": "",\n        "product_id": 0,\n        "qty": "",\n        "row_total": "",\n        "row_total_incl_tax": "",\n        "sku": "",\n        "tax_amount": ""\n      }\n    ],\n    "order_currency_code": "",\n    "order_id": 0,\n    "shipping_address_id": 0,\n    "shipping_amount": "",\n    "shipping_discount_tax_compensation_amount": "",\n    "shipping_incl_tax": "",\n    "shipping_tax_amount": "",\n    "state": 0,\n    "store_currency_code": "",\n    "store_id": 0,\n    "store_to_base_rate": "",\n    "store_to_order_rate": "",\n    "subtotal": "",\n    "subtotal_incl_tax": "",\n    "tax_amount": "",\n    "total_qty": "",\n    "transaction_id": "",\n    "updated_at": ""\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  \"entity\": {\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address_id\": 0,\n    \"can_void_flag\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"vertex_tax_calculation_billing_address\": {\n        \"address_type\": \"\",\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"customer_address_id\": 0,\n        \"customer_id\": 0,\n        \"email\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"checkout_fields\": [\n            {\n              \"attribute_code\": \"\",\n              \"value\": \"\"\n            }\n          ]\n        },\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"parent_id\": 0,\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": \"\",\n        \"region_code\": \"\",\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\",\n        \"vat_is_valid\": 0,\n        \"vat_request_date\": \"\",\n        \"vat_request_id\": \"\",\n        \"vat_request_success\": 0\n      },\n      \"vertex_tax_calculation_order\": {\n        \"adjustment_negative\": \"\",\n        \"adjustment_positive\": \"\",\n        \"applied_rule_ids\": \"\",\n        \"base_adjustment_negative\": \"\",\n        \"base_adjustment_positive\": \"\",\n        \"base_currency_code\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_canceled\": \"\",\n        \"base_discount_invoiced\": \"\",\n        \"base_discount_refunded\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_discount_tax_compensation_invoiced\": \"\",\n        \"base_discount_tax_compensation_refunded\": \"\",\n        \"base_grand_total\": \"\",\n        \"base_shipping_amount\": \"\",\n        \"base_shipping_canceled\": \"\",\n        \"base_shipping_discount_amount\": \"\",\n        \"base_shipping_discount_tax_compensation_amnt\": \"\",\n        \"base_shipping_incl_tax\": \"\",\n        \"base_shipping_invoiced\": \"\",\n        \"base_shipping_refunded\": \"\",\n        \"base_shipping_tax_amount\": \"\",\n        \"base_shipping_tax_refunded\": \"\",\n        \"base_subtotal\": \"\",\n        \"base_subtotal_canceled\": \"\",\n        \"base_subtotal_incl_tax\": \"\",\n        \"base_subtotal_invoiced\": \"\",\n        \"base_subtotal_refunded\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_tax_canceled\": \"\",\n        \"base_tax_invoiced\": \"\",\n        \"base_tax_refunded\": \"\",\n        \"base_to_global_rate\": \"\",\n        \"base_to_order_rate\": \"\",\n        \"base_total_canceled\": \"\",\n        \"base_total_due\": \"\",\n        \"base_total_invoiced\": \"\",\n        \"base_total_invoiced_cost\": \"\",\n        \"base_total_offline_refunded\": \"\",\n        \"base_total_online_refunded\": \"\",\n        \"base_total_paid\": \"\",\n        \"base_total_qty_ordered\": \"\",\n        \"base_total_refunded\": \"\",\n        \"billing_address\": {},\n        \"billing_address_id\": 0,\n        \"can_ship_partially\": 0,\n        \"can_ship_partially_item\": 0,\n        \"coupon_code\": \"\",\n        \"created_at\": \"\",\n        \"customer_dob\": \"\",\n        \"customer_email\": \"\",\n        \"customer_firstname\": \"\",\n        \"customer_gender\": 0,\n        \"customer_group_id\": 0,\n        \"customer_id\": 0,\n        \"customer_is_guest\": 0,\n        \"customer_lastname\": \"\",\n        \"customer_middlename\": \"\",\n        \"customer_note\": \"\",\n        \"customer_note_notify\": 0,\n        \"customer_prefix\": \"\",\n        \"customer_suffix\": \"\",\n        \"customer_taxvat\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_canceled\": \"\",\n        \"discount_description\": \"\",\n        \"discount_invoiced\": \"\",\n        \"discount_refunded\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"discount_tax_compensation_invoiced\": \"\",\n        \"discount_tax_compensation_refunded\": \"\",\n        \"edit_increment\": 0,\n        \"email_sent\": 0,\n        \"entity_id\": 0,\n        \"ext_customer_id\": \"\",\n        \"ext_order_id\": \"\",\n        \"extension_attributes\": {\n          \"amazon_order_reference_id\": \"\",\n          \"applied_taxes\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"extension_attributes\": {\n                \"rates\": [\n                  {\n                    \"code\": \"\",\n                    \"extension_attributes\": {},\n                    \"percent\": \"\",\n                    \"title\": \"\"\n                  }\n                ]\n              },\n              \"percent\": \"\",\n              \"title\": \"\"\n            }\n          ],\n          \"base_customer_balance_amount\": \"\",\n          \"base_customer_balance_invoiced\": \"\",\n          \"base_customer_balance_refunded\": \"\",\n          \"base_customer_balance_total_refunded\": \"\",\n          \"base_gift_cards_amount\": \"\",\n          \"base_gift_cards_invoiced\": \"\",\n          \"base_gift_cards_refunded\": \"\",\n          \"base_reward_currency_amount\": \"\",\n          \"company_order_attributes\": {\n            \"company_id\": 0,\n            \"company_name\": \"\",\n            \"extension_attributes\": {},\n            \"order_id\": 0\n          },\n          \"converting_from_quote\": false,\n          \"customer_balance_amount\": \"\",\n          \"customer_balance_invoiced\": \"\",\n          \"customer_balance_refunded\": \"\",\n          \"customer_balance_total_refunded\": \"\",\n          \"gift_cards\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"id\": 0\n            }\n          ],\n          \"gift_cards_amount\": \"\",\n          \"gift_cards_invoiced\": \"\",\n          \"gift_cards_refunded\": \"\",\n          \"gift_message\": {\n            \"customer_id\": 0,\n            \"extension_attributes\": {\n              \"entity_id\": \"\",\n              \"entity_type\": \"\",\n              \"wrapping_add_printed_card\": false,\n              \"wrapping_allow_gift_receipt\": false,\n              \"wrapping_id\": 0\n            },\n            \"gift_message_id\": 0,\n            \"message\": \"\",\n            \"recipient\": \"\",\n            \"sender\": \"\"\n          },\n          \"gw_add_card\": \"\",\n          \"gw_allow_gift_receipt\": \"\",\n          \"gw_base_price\": \"\",\n          \"gw_base_price_incl_tax\": \"\",\n          \"gw_base_price_invoiced\": \"\",\n          \"gw_base_price_refunded\": \"\",\n          \"gw_base_tax_amount\": \"\",\n          \"gw_base_tax_amount_invoiced\": \"\",\n          \"gw_base_tax_amount_refunded\": \"\",\n          \"gw_card_base_price\": \"\",\n          \"gw_card_base_price_incl_tax\": \"\",\n          \"gw_card_base_price_invoiced\": \"\",\n          \"gw_card_base_price_refunded\": \"\",\n          \"gw_card_base_tax_amount\": \"\",\n          \"gw_card_base_tax_invoiced\": \"\",\n          \"gw_card_base_tax_refunded\": \"\",\n          \"gw_card_price\": \"\",\n          \"gw_card_price_incl_tax\": \"\",\n          \"gw_card_price_invoiced\": \"\",\n          \"gw_card_price_refunded\": \"\",\n          \"gw_card_tax_amount\": \"\",\n          \"gw_card_tax_invoiced\": \"\",\n          \"gw_card_tax_refunded\": \"\",\n          \"gw_id\": \"\",\n          \"gw_items_base_price\": \"\",\n          \"gw_items_base_price_incl_tax\": \"\",\n          \"gw_items_base_price_invoiced\": \"\",\n          \"gw_items_base_price_refunded\": \"\",\n          \"gw_items_base_tax_amount\": \"\",\n          \"gw_items_base_tax_invoiced\": \"\",\n          \"gw_items_base_tax_refunded\": \"\",\n          \"gw_items_price\": \"\",\n          \"gw_items_price_incl_tax\": \"\",\n          \"gw_items_price_invoiced\": \"\",\n          \"gw_items_price_refunded\": \"\",\n          \"gw_items_tax_amount\": \"\",\n          \"gw_items_tax_invoiced\": \"\",\n          \"gw_items_tax_refunded\": \"\",\n          \"gw_price\": \"\",\n          \"gw_price_incl_tax\": \"\",\n          \"gw_price_invoiced\": \"\",\n          \"gw_price_refunded\": \"\",\n          \"gw_tax_amount\": \"\",\n          \"gw_tax_amount_invoiced\": \"\",\n          \"gw_tax_amount_refunded\": \"\",\n          \"item_applied_taxes\": [\n            {\n              \"applied_taxes\": [\n                {}\n              ],\n              \"associated_item_id\": 0,\n              \"extension_attributes\": {},\n              \"item_id\": 0,\n              \"type\": \"\"\n            }\n          ],\n          \"payment_additional_info\": [\n            {\n              \"key\": \"\",\n              \"value\": \"\"\n            }\n          ],\n          \"reward_currency_amount\": \"\",\n          \"reward_points_balance\": 0,\n          \"shipping_assignments\": [\n            {\n              \"extension_attributes\": {},\n              \"items\": [\n                {\n                  \"additional_data\": \"\",\n                  \"amount_refunded\": \"\",\n                  \"applied_rule_ids\": \"\",\n                  \"base_amount_refunded\": \"\",\n                  \"base_cost\": \"\",\n                  \"base_discount_amount\": \"\",\n                  \"base_discount_invoiced\": \"\",\n                  \"base_discount_refunded\": \"\",\n                  \"base_discount_tax_compensation_amount\": \"\",\n                  \"base_discount_tax_compensation_invoiced\": \"\",\n                  \"base_discount_tax_compensation_refunded\": \"\",\n                  \"base_original_price\": \"\",\n                  \"base_price\": \"\",\n                  \"base_price_incl_tax\": \"\",\n                  \"base_row_invoiced\": \"\",\n                  \"base_row_total\": \"\",\n                  \"base_row_total_incl_tax\": \"\",\n                  \"base_tax_amount\": \"\",\n                  \"base_tax_before_discount\": \"\",\n                  \"base_tax_invoiced\": \"\",\n                  \"base_tax_refunded\": \"\",\n                  \"base_weee_tax_applied_amount\": \"\",\n                  \"base_weee_tax_applied_row_amnt\": \"\",\n                  \"base_weee_tax_disposition\": \"\",\n                  \"base_weee_tax_row_disposition\": \"\",\n                  \"created_at\": \"\",\n                  \"description\": \"\",\n                  \"discount_amount\": \"\",\n                  \"discount_invoiced\": \"\",\n                  \"discount_percent\": \"\",\n                  \"discount_refunded\": \"\",\n                  \"discount_tax_compensation_amount\": \"\",\n                  \"discount_tax_compensation_canceled\": \"\",\n                  \"discount_tax_compensation_invoiced\": \"\",\n                  \"discount_tax_compensation_refunded\": \"\",\n                  \"event_id\": 0,\n                  \"ext_order_item_id\": \"\",\n                  \"extension_attributes\": {\n                    \"gift_message\": {},\n                    \"gw_base_price\": \"\",\n                    \"gw_base_price_invoiced\": \"\",\n                    \"gw_base_price_refunded\": \"\",\n                    \"gw_base_tax_amount\": \"\",\n                    \"gw_base_tax_amount_invoiced\": \"\",\n                    \"gw_base_tax_amount_refunded\": \"\",\n                    \"gw_id\": \"\",\n                    \"gw_price\": \"\",\n                    \"gw_price_invoiced\": \"\",\n                    \"gw_price_refunded\": \"\",\n                    \"gw_tax_amount\": \"\",\n                    \"gw_tax_amount_invoiced\": \"\",\n                    \"gw_tax_amount_refunded\": \"\",\n                    \"invoice_text_codes\": [],\n                    \"tax_codes\": [],\n                    \"vertex_tax_codes\": []\n                  },\n                  \"free_shipping\": 0,\n                  \"gw_base_price\": \"\",\n                  \"gw_base_price_invoiced\": \"\",\n                  \"gw_base_price_refunded\": \"\",\n                  \"gw_base_tax_amount\": \"\",\n                  \"gw_base_tax_amount_invoiced\": \"\",\n                  \"gw_base_tax_amount_refunded\": \"\",\n                  \"gw_id\": 0,\n                  \"gw_price\": \"\",\n                  \"gw_price_invoiced\": \"\",\n                  \"gw_price_refunded\": \"\",\n                  \"gw_tax_amount\": \"\",\n                  \"gw_tax_amount_invoiced\": \"\",\n                  \"gw_tax_amount_refunded\": \"\",\n                  \"is_qty_decimal\": 0,\n                  \"is_virtual\": 0,\n                  \"item_id\": 0,\n                  \"locked_do_invoice\": 0,\n                  \"locked_do_ship\": 0,\n                  \"name\": \"\",\n                  \"no_discount\": 0,\n                  \"order_id\": 0,\n                  \"original_price\": \"\",\n                  \"parent_item\": \"\",\n                  \"parent_item_id\": 0,\n                  \"price\": \"\",\n                  \"price_incl_tax\": \"\",\n                  \"product_id\": 0,\n                  \"product_option\": {\n                    \"extension_attributes\": {\n                      \"bundle_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": 0,\n                          \"option_qty\": 0,\n                          \"option_selections\": []\n                        }\n                      ],\n                      \"configurable_item_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": \"\",\n                          \"option_value\": 0\n                        }\n                      ],\n                      \"custom_options\": [\n                        {\n                          \"extension_attributes\": {\n                            \"file_info\": {\n                              \"base64_encoded_data\": \"\",\n                              \"name\": \"\",\n                              \"type\": \"\"\n                            }\n                          },\n                          \"option_id\": \"\",\n                          \"option_value\": \"\"\n                        }\n                      ],\n                      \"downloadable_option\": {\n                        \"downloadable_links\": []\n                      },\n                      \"giftcard_item_option\": {\n                        \"custom_giftcard_amount\": \"\",\n                        \"extension_attributes\": {},\n                        \"giftcard_amount\": \"\",\n                        \"giftcard_message\": \"\",\n                        \"giftcard_recipient_email\": \"\",\n                        \"giftcard_recipient_name\": \"\",\n                        \"giftcard_sender_email\": \"\",\n                        \"giftcard_sender_name\": \"\"\n                      }\n                    }\n                  },\n                  \"product_type\": \"\",\n                  \"qty_backordered\": \"\",\n                  \"qty_canceled\": \"\",\n                  \"qty_invoiced\": \"\",\n                  \"qty_ordered\": \"\",\n                  \"qty_refunded\": \"\",\n                  \"qty_returned\": \"\",\n                  \"qty_shipped\": \"\",\n                  \"quote_item_id\": 0,\n                  \"row_invoiced\": \"\",\n                  \"row_total\": \"\",\n                  \"row_total_incl_tax\": \"\",\n                  \"row_weight\": \"\",\n                  \"sku\": \"\",\n                  \"store_id\": 0,\n                  \"tax_amount\": \"\",\n                  \"tax_before_discount\": \"\",\n                  \"tax_canceled\": \"\",\n                  \"tax_invoiced\": \"\",\n                  \"tax_percent\": \"\",\n                  \"tax_refunded\": \"\",\n                  \"updated_at\": \"\",\n                  \"weee_tax_applied\": \"\",\n                  \"weee_tax_applied_amount\": \"\",\n                  \"weee_tax_applied_row_amount\": \"\",\n                  \"weee_tax_disposition\": \"\",\n                  \"weee_tax_row_disposition\": \"\",\n                  \"weight\": \"\"\n                }\n              ],\n              \"shipping\": {\n                \"address\": {},\n                \"extension_attributes\": {\n                  \"collection_point\": {\n                    \"city\": \"\",\n                    \"collection_point_id\": \"\",\n                    \"country\": \"\",\n                    \"name\": \"\",\n                    \"postcode\": \"\",\n                    \"recipient_address_id\": 0,\n                    \"region\": \"\",\n                    \"street\": []\n                  },\n                  \"ext_order_id\": \"\",\n                  \"shipping_experience\": {\n                    \"code\": \"\",\n                    \"cost\": \"\",\n                    \"label\": \"\"\n                  }\n                },\n                \"method\": \"\",\n                \"total\": {\n                  \"base_shipping_amount\": \"\",\n                  \"base_shipping_canceled\": \"\",\n                  \"base_shipping_discount_amount\": \"\",\n                  \"base_shipping_discount_tax_compensation_amnt\": \"\",\n                  \"base_shipping_incl_tax\": \"\",\n                  \"base_shipping_invoiced\": \"\",\n                  \"base_shipping_refunded\": \"\",\n                  \"base_shipping_tax_amount\": \"\",\n                  \"base_shipping_tax_refunded\": \"\",\n                  \"extension_attributes\": {},\n                  \"shipping_amount\": \"\",\n                  \"shipping_canceled\": \"\",\n                  \"shipping_discount_amount\": \"\",\n                  \"shipping_discount_tax_compensation_amount\": \"\",\n                  \"shipping_incl_tax\": \"\",\n                  \"shipping_invoiced\": \"\",\n                  \"shipping_refunded\": \"\",\n                  \"shipping_tax_amount\": \"\",\n                  \"shipping_tax_refunded\": \"\"\n                }\n              },\n              \"stock_id\": 0\n            }\n          ]\n        },\n        \"forced_shipment_with_invoice\": 0,\n        \"global_currency_code\": \"\",\n        \"grand_total\": \"\",\n        \"hold_before_state\": \"\",\n        \"hold_before_status\": \"\",\n        \"increment_id\": \"\",\n        \"is_virtual\": 0,\n        \"items\": [\n          {}\n        ],\n        \"order_currency_code\": \"\",\n        \"original_increment_id\": \"\",\n        \"payment\": {\n          \"account_status\": \"\",\n          \"additional_data\": \"\",\n          \"additional_information\": [],\n          \"address_status\": \"\",\n          \"amount_authorized\": \"\",\n          \"amount_canceled\": \"\",\n          \"amount_ordered\": \"\",\n          \"amount_paid\": \"\",\n          \"amount_refunded\": \"\",\n          \"anet_trans_method\": \"\",\n          \"base_amount_authorized\": \"\",\n          \"base_amount_canceled\": \"\",\n          \"base_amount_ordered\": \"\",\n          \"base_amount_paid\": \"\",\n          \"base_amount_paid_online\": \"\",\n          \"base_amount_refunded\": \"\",\n          \"base_amount_refunded_online\": \"\",\n          \"base_shipping_amount\": \"\",\n          \"base_shipping_captured\": \"\",\n          \"base_shipping_refunded\": \"\",\n          \"cc_approval\": \"\",\n          \"cc_avs_status\": \"\",\n          \"cc_cid_status\": \"\",\n          \"cc_debug_request_body\": \"\",\n          \"cc_debug_response_body\": \"\",\n          \"cc_debug_response_serialized\": \"\",\n          \"cc_exp_month\": \"\",\n          \"cc_exp_year\": \"\",\n          \"cc_last4\": \"\",\n          \"cc_number_enc\": \"\",\n          \"cc_owner\": \"\",\n          \"cc_secure_verify\": \"\",\n          \"cc_ss_issue\": \"\",\n          \"cc_ss_start_month\": \"\",\n          \"cc_ss_start_year\": \"\",\n          \"cc_status\": \"\",\n          \"cc_status_description\": \"\",\n          \"cc_trans_id\": \"\",\n          \"cc_type\": \"\",\n          \"echeck_account_name\": \"\",\n          \"echeck_account_type\": \"\",\n          \"echeck_bank_name\": \"\",\n          \"echeck_routing_number\": \"\",\n          \"echeck_type\": \"\",\n          \"entity_id\": 0,\n          \"extension_attributes\": {\n            \"vault_payment_token\": {\n              \"created_at\": \"\",\n              \"customer_id\": 0,\n              \"entity_id\": 0,\n              \"expires_at\": \"\",\n              \"gateway_token\": \"\",\n              \"is_active\": false,\n              \"is_visible\": false,\n              \"payment_method_code\": \"\",\n              \"public_hash\": \"\",\n              \"token_details\": \"\",\n              \"type\": \"\"\n            }\n          },\n          \"last_trans_id\": \"\",\n          \"method\": \"\",\n          \"parent_id\": 0,\n          \"po_number\": \"\",\n          \"protection_eligibility\": \"\",\n          \"quote_payment_id\": 0,\n          \"shipping_amount\": \"\",\n          \"shipping_captured\": \"\",\n          \"shipping_refunded\": \"\"\n        },\n        \"payment_auth_expiration\": 0,\n        \"payment_authorization_amount\": \"\",\n        \"protect_code\": \"\",\n        \"quote_address_id\": 0,\n        \"quote_id\": 0,\n        \"relation_child_id\": \"\",\n        \"relation_child_real_id\": \"\",\n        \"relation_parent_id\": \"\",\n        \"relation_parent_real_id\": \"\",\n        \"remote_ip\": \"\",\n        \"shipping_amount\": \"\",\n        \"shipping_canceled\": \"\",\n        \"shipping_description\": \"\",\n        \"shipping_discount_amount\": \"\",\n        \"shipping_discount_tax_compensation_amount\": \"\",\n        \"shipping_incl_tax\": \"\",\n        \"shipping_invoiced\": \"\",\n        \"shipping_refunded\": \"\",\n        \"shipping_tax_amount\": \"\",\n        \"shipping_tax_refunded\": \"\",\n        \"state\": \"\",\n        \"status\": \"\",\n        \"status_histories\": [\n          {\n            \"comment\": \"\",\n            \"created_at\": \"\",\n            \"entity_id\": 0,\n            \"entity_name\": \"\",\n            \"extension_attributes\": {},\n            \"is_customer_notified\": 0,\n            \"is_visible_on_front\": 0,\n            \"parent_id\": 0,\n            \"status\": \"\"\n          }\n        ],\n        \"store_currency_code\": \"\",\n        \"store_id\": 0,\n        \"store_name\": \"\",\n        \"store_to_base_rate\": \"\",\n        \"store_to_order_rate\": \"\",\n        \"subtotal\": \"\",\n        \"subtotal_canceled\": \"\",\n        \"subtotal_incl_tax\": \"\",\n        \"subtotal_invoiced\": \"\",\n        \"subtotal_refunded\": \"\",\n        \"tax_amount\": \"\",\n        \"tax_canceled\": \"\",\n        \"tax_invoiced\": \"\",\n        \"tax_refunded\": \"\",\n        \"total_canceled\": \"\",\n        \"total_due\": \"\",\n        \"total_invoiced\": \"\",\n        \"total_item_count\": 0,\n        \"total_offline_refunded\": \"\",\n        \"total_online_refunded\": \"\",\n        \"total_paid\": \"\",\n        \"total_qty_ordered\": \"\",\n        \"total_refunded\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\",\n        \"x_forwarded_for\": \"\"\n      },\n      \"vertex_tax_calculation_shipping_address\": {}\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"is_used_for_refund\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"total_qty\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/invoices/")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/invoices/',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  entity: {
    base_currency_code: '',
    base_discount_amount: '',
    base_discount_tax_compensation_amount: '',
    base_grand_total: '',
    base_shipping_amount: '',
    base_shipping_discount_tax_compensation_amnt: '',
    base_shipping_incl_tax: '',
    base_shipping_tax_amount: '',
    base_subtotal: '',
    base_subtotal_incl_tax: '',
    base_tax_amount: '',
    base_to_global_rate: '',
    base_to_order_rate: '',
    base_total_refunded: '',
    billing_address_id: 0,
    can_void_flag: 0,
    comments: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0
      }
    ],
    created_at: '',
    discount_amount: '',
    discount_description: '',
    discount_tax_compensation_amount: '',
    email_sent: 0,
    entity_id: 0,
    extension_attributes: {
      base_customer_balance_amount: '',
      base_gift_cards_amount: '',
      customer_balance_amount: '',
      gift_cards_amount: '',
      gw_base_price: '',
      gw_base_tax_amount: '',
      gw_card_base_price: '',
      gw_card_base_tax_amount: '',
      gw_card_price: '',
      gw_card_tax_amount: '',
      gw_items_base_price: '',
      gw_items_base_tax_amount: '',
      gw_items_price: '',
      gw_items_tax_amount: '',
      gw_price: '',
      gw_tax_amount: '',
      vertex_tax_calculation_billing_address: {
        address_type: '',
        city: '',
        company: '',
        country_id: '',
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        entity_id: 0,
        extension_attributes: {checkout_fields: [{attribute_code: '', value: ''}]},
        fax: '',
        firstname: '',
        lastname: '',
        middlename: '',
        parent_id: 0,
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: '',
        vat_is_valid: 0,
        vat_request_date: '',
        vat_request_id: '',
        vat_request_success: 0
      },
      vertex_tax_calculation_order: {
        adjustment_negative: '',
        adjustment_positive: '',
        applied_rule_ids: '',
        base_adjustment_negative: '',
        base_adjustment_positive: '',
        base_currency_code: '',
        base_discount_amount: '',
        base_discount_canceled: '',
        base_discount_invoiced: '',
        base_discount_refunded: '',
        base_discount_tax_compensation_amount: '',
        base_discount_tax_compensation_invoiced: '',
        base_discount_tax_compensation_refunded: '',
        base_grand_total: '',
        base_shipping_amount: '',
        base_shipping_canceled: '',
        base_shipping_discount_amount: '',
        base_shipping_discount_tax_compensation_amnt: '',
        base_shipping_incl_tax: '',
        base_shipping_invoiced: '',
        base_shipping_refunded: '',
        base_shipping_tax_amount: '',
        base_shipping_tax_refunded: '',
        base_subtotal: '',
        base_subtotal_canceled: '',
        base_subtotal_incl_tax: '',
        base_subtotal_invoiced: '',
        base_subtotal_refunded: '',
        base_tax_amount: '',
        base_tax_canceled: '',
        base_tax_invoiced: '',
        base_tax_refunded: '',
        base_to_global_rate: '',
        base_to_order_rate: '',
        base_total_canceled: '',
        base_total_due: '',
        base_total_invoiced: '',
        base_total_invoiced_cost: '',
        base_total_offline_refunded: '',
        base_total_online_refunded: '',
        base_total_paid: '',
        base_total_qty_ordered: '',
        base_total_refunded: '',
        billing_address: {},
        billing_address_id: 0,
        can_ship_partially: 0,
        can_ship_partially_item: 0,
        coupon_code: '',
        created_at: '',
        customer_dob: '',
        customer_email: '',
        customer_firstname: '',
        customer_gender: 0,
        customer_group_id: 0,
        customer_id: 0,
        customer_is_guest: 0,
        customer_lastname: '',
        customer_middlename: '',
        customer_note: '',
        customer_note_notify: 0,
        customer_prefix: '',
        customer_suffix: '',
        customer_taxvat: '',
        discount_amount: '',
        discount_canceled: '',
        discount_description: '',
        discount_invoiced: '',
        discount_refunded: '',
        discount_tax_compensation_amount: '',
        discount_tax_compensation_invoiced: '',
        discount_tax_compensation_refunded: '',
        edit_increment: 0,
        email_sent: 0,
        entity_id: 0,
        ext_customer_id: '',
        ext_order_id: '',
        extension_attributes: {
          amazon_order_reference_id: '',
          applied_taxes: [
            {
              amount: '',
              base_amount: '',
              code: '',
              extension_attributes: {rates: [{code: '', extension_attributes: {}, percent: '', title: ''}]},
              percent: '',
              title: ''
            }
          ],
          base_customer_balance_amount: '',
          base_customer_balance_invoiced: '',
          base_customer_balance_refunded: '',
          base_customer_balance_total_refunded: '',
          base_gift_cards_amount: '',
          base_gift_cards_invoiced: '',
          base_gift_cards_refunded: '',
          base_reward_currency_amount: '',
          company_order_attributes: {company_id: 0, company_name: '', extension_attributes: {}, order_id: 0},
          converting_from_quote: false,
          customer_balance_amount: '',
          customer_balance_invoiced: '',
          customer_balance_refunded: '',
          customer_balance_total_refunded: '',
          gift_cards: [{amount: '', base_amount: '', code: '', id: 0}],
          gift_cards_amount: '',
          gift_cards_invoiced: '',
          gift_cards_refunded: '',
          gift_message: {
            customer_id: 0,
            extension_attributes: {
              entity_id: '',
              entity_type: '',
              wrapping_add_printed_card: false,
              wrapping_allow_gift_receipt: false,
              wrapping_id: 0
            },
            gift_message_id: 0,
            message: '',
            recipient: '',
            sender: ''
          },
          gw_add_card: '',
          gw_allow_gift_receipt: '',
          gw_base_price: '',
          gw_base_price_incl_tax: '',
          gw_base_price_invoiced: '',
          gw_base_price_refunded: '',
          gw_base_tax_amount: '',
          gw_base_tax_amount_invoiced: '',
          gw_base_tax_amount_refunded: '',
          gw_card_base_price: '',
          gw_card_base_price_incl_tax: '',
          gw_card_base_price_invoiced: '',
          gw_card_base_price_refunded: '',
          gw_card_base_tax_amount: '',
          gw_card_base_tax_invoiced: '',
          gw_card_base_tax_refunded: '',
          gw_card_price: '',
          gw_card_price_incl_tax: '',
          gw_card_price_invoiced: '',
          gw_card_price_refunded: '',
          gw_card_tax_amount: '',
          gw_card_tax_invoiced: '',
          gw_card_tax_refunded: '',
          gw_id: '',
          gw_items_base_price: '',
          gw_items_base_price_incl_tax: '',
          gw_items_base_price_invoiced: '',
          gw_items_base_price_refunded: '',
          gw_items_base_tax_amount: '',
          gw_items_base_tax_invoiced: '',
          gw_items_base_tax_refunded: '',
          gw_items_price: '',
          gw_items_price_incl_tax: '',
          gw_items_price_invoiced: '',
          gw_items_price_refunded: '',
          gw_items_tax_amount: '',
          gw_items_tax_invoiced: '',
          gw_items_tax_refunded: '',
          gw_price: '',
          gw_price_incl_tax: '',
          gw_price_invoiced: '',
          gw_price_refunded: '',
          gw_tax_amount: '',
          gw_tax_amount_invoiced: '',
          gw_tax_amount_refunded: '',
          item_applied_taxes: [
            {
              applied_taxes: [{}],
              associated_item_id: 0,
              extension_attributes: {},
              item_id: 0,
              type: ''
            }
          ],
          payment_additional_info: [{key: '', value: ''}],
          reward_currency_amount: '',
          reward_points_balance: 0,
          shipping_assignments: [
            {
              extension_attributes: {},
              items: [
                {
                  additional_data: '',
                  amount_refunded: '',
                  applied_rule_ids: '',
                  base_amount_refunded: '',
                  base_cost: '',
                  base_discount_amount: '',
                  base_discount_invoiced: '',
                  base_discount_refunded: '',
                  base_discount_tax_compensation_amount: '',
                  base_discount_tax_compensation_invoiced: '',
                  base_discount_tax_compensation_refunded: '',
                  base_original_price: '',
                  base_price: '',
                  base_price_incl_tax: '',
                  base_row_invoiced: '',
                  base_row_total: '',
                  base_row_total_incl_tax: '',
                  base_tax_amount: '',
                  base_tax_before_discount: '',
                  base_tax_invoiced: '',
                  base_tax_refunded: '',
                  base_weee_tax_applied_amount: '',
                  base_weee_tax_applied_row_amnt: '',
                  base_weee_tax_disposition: '',
                  base_weee_tax_row_disposition: '',
                  created_at: '',
                  description: '',
                  discount_amount: '',
                  discount_invoiced: '',
                  discount_percent: '',
                  discount_refunded: '',
                  discount_tax_compensation_amount: '',
                  discount_tax_compensation_canceled: '',
                  discount_tax_compensation_invoiced: '',
                  discount_tax_compensation_refunded: '',
                  event_id: 0,
                  ext_order_item_id: '',
                  extension_attributes: {
                    gift_message: {},
                    gw_base_price: '',
                    gw_base_price_invoiced: '',
                    gw_base_price_refunded: '',
                    gw_base_tax_amount: '',
                    gw_base_tax_amount_invoiced: '',
                    gw_base_tax_amount_refunded: '',
                    gw_id: '',
                    gw_price: '',
                    gw_price_invoiced: '',
                    gw_price_refunded: '',
                    gw_tax_amount: '',
                    gw_tax_amount_invoiced: '',
                    gw_tax_amount_refunded: '',
                    invoice_text_codes: [],
                    tax_codes: [],
                    vertex_tax_codes: []
                  },
                  free_shipping: 0,
                  gw_base_price: '',
                  gw_base_price_invoiced: '',
                  gw_base_price_refunded: '',
                  gw_base_tax_amount: '',
                  gw_base_tax_amount_invoiced: '',
                  gw_base_tax_amount_refunded: '',
                  gw_id: 0,
                  gw_price: '',
                  gw_price_invoiced: '',
                  gw_price_refunded: '',
                  gw_tax_amount: '',
                  gw_tax_amount_invoiced: '',
                  gw_tax_amount_refunded: '',
                  is_qty_decimal: 0,
                  is_virtual: 0,
                  item_id: 0,
                  locked_do_invoice: 0,
                  locked_do_ship: 0,
                  name: '',
                  no_discount: 0,
                  order_id: 0,
                  original_price: '',
                  parent_item: '',
                  parent_item_id: 0,
                  price: '',
                  price_incl_tax: '',
                  product_id: 0,
                  product_option: {
                    extension_attributes: {
                      bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                      configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                      custom_options: [
                        {
                          extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                          option_id: '',
                          option_value: ''
                        }
                      ],
                      downloadable_option: {downloadable_links: []},
                      giftcard_item_option: {
                        custom_giftcard_amount: '',
                        extension_attributes: {},
                        giftcard_amount: '',
                        giftcard_message: '',
                        giftcard_recipient_email: '',
                        giftcard_recipient_name: '',
                        giftcard_sender_email: '',
                        giftcard_sender_name: ''
                      }
                    }
                  },
                  product_type: '',
                  qty_backordered: '',
                  qty_canceled: '',
                  qty_invoiced: '',
                  qty_ordered: '',
                  qty_refunded: '',
                  qty_returned: '',
                  qty_shipped: '',
                  quote_item_id: 0,
                  row_invoiced: '',
                  row_total: '',
                  row_total_incl_tax: '',
                  row_weight: '',
                  sku: '',
                  store_id: 0,
                  tax_amount: '',
                  tax_before_discount: '',
                  tax_canceled: '',
                  tax_invoiced: '',
                  tax_percent: '',
                  tax_refunded: '',
                  updated_at: '',
                  weee_tax_applied: '',
                  weee_tax_applied_amount: '',
                  weee_tax_applied_row_amount: '',
                  weee_tax_disposition: '',
                  weee_tax_row_disposition: '',
                  weight: ''
                }
              ],
              shipping: {
                address: {},
                extension_attributes: {
                  collection_point: {
                    city: '',
                    collection_point_id: '',
                    country: '',
                    name: '',
                    postcode: '',
                    recipient_address_id: 0,
                    region: '',
                    street: []
                  },
                  ext_order_id: '',
                  shipping_experience: {code: '', cost: '', label: ''}
                },
                method: '',
                total: {
                  base_shipping_amount: '',
                  base_shipping_canceled: '',
                  base_shipping_discount_amount: '',
                  base_shipping_discount_tax_compensation_amnt: '',
                  base_shipping_incl_tax: '',
                  base_shipping_invoiced: '',
                  base_shipping_refunded: '',
                  base_shipping_tax_amount: '',
                  base_shipping_tax_refunded: '',
                  extension_attributes: {},
                  shipping_amount: '',
                  shipping_canceled: '',
                  shipping_discount_amount: '',
                  shipping_discount_tax_compensation_amount: '',
                  shipping_incl_tax: '',
                  shipping_invoiced: '',
                  shipping_refunded: '',
                  shipping_tax_amount: '',
                  shipping_tax_refunded: ''
                }
              },
              stock_id: 0
            }
          ]
        },
        forced_shipment_with_invoice: 0,
        global_currency_code: '',
        grand_total: '',
        hold_before_state: '',
        hold_before_status: '',
        increment_id: '',
        is_virtual: 0,
        items: [{}],
        order_currency_code: '',
        original_increment_id: '',
        payment: {
          account_status: '',
          additional_data: '',
          additional_information: [],
          address_status: '',
          amount_authorized: '',
          amount_canceled: '',
          amount_ordered: '',
          amount_paid: '',
          amount_refunded: '',
          anet_trans_method: '',
          base_amount_authorized: '',
          base_amount_canceled: '',
          base_amount_ordered: '',
          base_amount_paid: '',
          base_amount_paid_online: '',
          base_amount_refunded: '',
          base_amount_refunded_online: '',
          base_shipping_amount: '',
          base_shipping_captured: '',
          base_shipping_refunded: '',
          cc_approval: '',
          cc_avs_status: '',
          cc_cid_status: '',
          cc_debug_request_body: '',
          cc_debug_response_body: '',
          cc_debug_response_serialized: '',
          cc_exp_month: '',
          cc_exp_year: '',
          cc_last4: '',
          cc_number_enc: '',
          cc_owner: '',
          cc_secure_verify: '',
          cc_ss_issue: '',
          cc_ss_start_month: '',
          cc_ss_start_year: '',
          cc_status: '',
          cc_status_description: '',
          cc_trans_id: '',
          cc_type: '',
          echeck_account_name: '',
          echeck_account_type: '',
          echeck_bank_name: '',
          echeck_routing_number: '',
          echeck_type: '',
          entity_id: 0,
          extension_attributes: {
            vault_payment_token: {
              created_at: '',
              customer_id: 0,
              entity_id: 0,
              expires_at: '',
              gateway_token: '',
              is_active: false,
              is_visible: false,
              payment_method_code: '',
              public_hash: '',
              token_details: '',
              type: ''
            }
          },
          last_trans_id: '',
          method: '',
          parent_id: 0,
          po_number: '',
          protection_eligibility: '',
          quote_payment_id: 0,
          shipping_amount: '',
          shipping_captured: '',
          shipping_refunded: ''
        },
        payment_auth_expiration: 0,
        payment_authorization_amount: '',
        protect_code: '',
        quote_address_id: 0,
        quote_id: 0,
        relation_child_id: '',
        relation_child_real_id: '',
        relation_parent_id: '',
        relation_parent_real_id: '',
        remote_ip: '',
        shipping_amount: '',
        shipping_canceled: '',
        shipping_description: '',
        shipping_discount_amount: '',
        shipping_discount_tax_compensation_amount: '',
        shipping_incl_tax: '',
        shipping_invoiced: '',
        shipping_refunded: '',
        shipping_tax_amount: '',
        shipping_tax_refunded: '',
        state: '',
        status: '',
        status_histories: [
          {
            comment: '',
            created_at: '',
            entity_id: 0,
            entity_name: '',
            extension_attributes: {},
            is_customer_notified: 0,
            is_visible_on_front: 0,
            parent_id: 0,
            status: ''
          }
        ],
        store_currency_code: '',
        store_id: 0,
        store_name: '',
        store_to_base_rate: '',
        store_to_order_rate: '',
        subtotal: '',
        subtotal_canceled: '',
        subtotal_incl_tax: '',
        subtotal_invoiced: '',
        subtotal_refunded: '',
        tax_amount: '',
        tax_canceled: '',
        tax_invoiced: '',
        tax_refunded: '',
        total_canceled: '',
        total_due: '',
        total_invoiced: '',
        total_item_count: 0,
        total_offline_refunded: '',
        total_online_refunded: '',
        total_paid: '',
        total_qty_ordered: '',
        total_refunded: '',
        updated_at: '',
        weight: '',
        x_forwarded_for: ''
      },
      vertex_tax_calculation_shipping_address: {}
    },
    global_currency_code: '',
    grand_total: '',
    increment_id: '',
    is_used_for_refund: 0,
    items: [
      {
        additional_data: '',
        base_cost: '',
        base_discount_amount: '',
        base_discount_tax_compensation_amount: '',
        base_price: '',
        base_price_incl_tax: '',
        base_row_total: '',
        base_row_total_incl_tax: '',
        base_tax_amount: '',
        description: '',
        discount_amount: '',
        discount_tax_compensation_amount: '',
        entity_id: 0,
        extension_attributes: {invoice_text_codes: [], tax_codes: [], vertex_tax_codes: []},
        name: '',
        order_item_id: 0,
        parent_id: 0,
        price: '',
        price_incl_tax: '',
        product_id: 0,
        qty: '',
        row_total: '',
        row_total_incl_tax: '',
        sku: '',
        tax_amount: ''
      }
    ],
    order_currency_code: '',
    order_id: 0,
    shipping_address_id: 0,
    shipping_amount: '',
    shipping_discount_tax_compensation_amount: '',
    shipping_incl_tax: '',
    shipping_tax_amount: '',
    state: 0,
    store_currency_code: '',
    store_id: 0,
    store_to_base_rate: '',
    store_to_order_rate: '',
    subtotal: '',
    subtotal_incl_tax: '',
    tax_amount: '',
    total_qty: '',
    transaction_id: '',
    updated_at: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/invoices/',
  headers: {'content-type': 'application/json'},
  body: {
    entity: {
      base_currency_code: '',
      base_discount_amount: '',
      base_discount_tax_compensation_amount: '',
      base_grand_total: '',
      base_shipping_amount: '',
      base_shipping_discount_tax_compensation_amnt: '',
      base_shipping_incl_tax: '',
      base_shipping_tax_amount: '',
      base_subtotal: '',
      base_subtotal_incl_tax: '',
      base_tax_amount: '',
      base_to_global_rate: '',
      base_to_order_rate: '',
      base_total_refunded: '',
      billing_address_id: 0,
      can_void_flag: 0,
      comments: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0
        }
      ],
      created_at: '',
      discount_amount: '',
      discount_description: '',
      discount_tax_compensation_amount: '',
      email_sent: 0,
      entity_id: 0,
      extension_attributes: {
        base_customer_balance_amount: '',
        base_gift_cards_amount: '',
        customer_balance_amount: '',
        gift_cards_amount: '',
        gw_base_price: '',
        gw_base_tax_amount: '',
        gw_card_base_price: '',
        gw_card_base_tax_amount: '',
        gw_card_price: '',
        gw_card_tax_amount: '',
        gw_items_base_price: '',
        gw_items_base_tax_amount: '',
        gw_items_price: '',
        gw_items_tax_amount: '',
        gw_price: '',
        gw_tax_amount: '',
        vertex_tax_calculation_billing_address: {
          address_type: '',
          city: '',
          company: '',
          country_id: '',
          customer_address_id: 0,
          customer_id: 0,
          email: '',
          entity_id: 0,
          extension_attributes: {checkout_fields: [{attribute_code: '', value: ''}]},
          fax: '',
          firstname: '',
          lastname: '',
          middlename: '',
          parent_id: 0,
          postcode: '',
          prefix: '',
          region: '',
          region_code: '',
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: '',
          vat_is_valid: 0,
          vat_request_date: '',
          vat_request_id: '',
          vat_request_success: 0
        },
        vertex_tax_calculation_order: {
          adjustment_negative: '',
          adjustment_positive: '',
          applied_rule_ids: '',
          base_adjustment_negative: '',
          base_adjustment_positive: '',
          base_currency_code: '',
          base_discount_amount: '',
          base_discount_canceled: '',
          base_discount_invoiced: '',
          base_discount_refunded: '',
          base_discount_tax_compensation_amount: '',
          base_discount_tax_compensation_invoiced: '',
          base_discount_tax_compensation_refunded: '',
          base_grand_total: '',
          base_shipping_amount: '',
          base_shipping_canceled: '',
          base_shipping_discount_amount: '',
          base_shipping_discount_tax_compensation_amnt: '',
          base_shipping_incl_tax: '',
          base_shipping_invoiced: '',
          base_shipping_refunded: '',
          base_shipping_tax_amount: '',
          base_shipping_tax_refunded: '',
          base_subtotal: '',
          base_subtotal_canceled: '',
          base_subtotal_incl_tax: '',
          base_subtotal_invoiced: '',
          base_subtotal_refunded: '',
          base_tax_amount: '',
          base_tax_canceled: '',
          base_tax_invoiced: '',
          base_tax_refunded: '',
          base_to_global_rate: '',
          base_to_order_rate: '',
          base_total_canceled: '',
          base_total_due: '',
          base_total_invoiced: '',
          base_total_invoiced_cost: '',
          base_total_offline_refunded: '',
          base_total_online_refunded: '',
          base_total_paid: '',
          base_total_qty_ordered: '',
          base_total_refunded: '',
          billing_address: {},
          billing_address_id: 0,
          can_ship_partially: 0,
          can_ship_partially_item: 0,
          coupon_code: '',
          created_at: '',
          customer_dob: '',
          customer_email: '',
          customer_firstname: '',
          customer_gender: 0,
          customer_group_id: 0,
          customer_id: 0,
          customer_is_guest: 0,
          customer_lastname: '',
          customer_middlename: '',
          customer_note: '',
          customer_note_notify: 0,
          customer_prefix: '',
          customer_suffix: '',
          customer_taxvat: '',
          discount_amount: '',
          discount_canceled: '',
          discount_description: '',
          discount_invoiced: '',
          discount_refunded: '',
          discount_tax_compensation_amount: '',
          discount_tax_compensation_invoiced: '',
          discount_tax_compensation_refunded: '',
          edit_increment: 0,
          email_sent: 0,
          entity_id: 0,
          ext_customer_id: '',
          ext_order_id: '',
          extension_attributes: {
            amazon_order_reference_id: '',
            applied_taxes: [
              {
                amount: '',
                base_amount: '',
                code: '',
                extension_attributes: {rates: [{code: '', extension_attributes: {}, percent: '', title: ''}]},
                percent: '',
                title: ''
              }
            ],
            base_customer_balance_amount: '',
            base_customer_balance_invoiced: '',
            base_customer_balance_refunded: '',
            base_customer_balance_total_refunded: '',
            base_gift_cards_amount: '',
            base_gift_cards_invoiced: '',
            base_gift_cards_refunded: '',
            base_reward_currency_amount: '',
            company_order_attributes: {company_id: 0, company_name: '', extension_attributes: {}, order_id: 0},
            converting_from_quote: false,
            customer_balance_amount: '',
            customer_balance_invoiced: '',
            customer_balance_refunded: '',
            customer_balance_total_refunded: '',
            gift_cards: [{amount: '', base_amount: '', code: '', id: 0}],
            gift_cards_amount: '',
            gift_cards_invoiced: '',
            gift_cards_refunded: '',
            gift_message: {
              customer_id: 0,
              extension_attributes: {
                entity_id: '',
                entity_type: '',
                wrapping_add_printed_card: false,
                wrapping_allow_gift_receipt: false,
                wrapping_id: 0
              },
              gift_message_id: 0,
              message: '',
              recipient: '',
              sender: ''
            },
            gw_add_card: '',
            gw_allow_gift_receipt: '',
            gw_base_price: '',
            gw_base_price_incl_tax: '',
            gw_base_price_invoiced: '',
            gw_base_price_refunded: '',
            gw_base_tax_amount: '',
            gw_base_tax_amount_invoiced: '',
            gw_base_tax_amount_refunded: '',
            gw_card_base_price: '',
            gw_card_base_price_incl_tax: '',
            gw_card_base_price_invoiced: '',
            gw_card_base_price_refunded: '',
            gw_card_base_tax_amount: '',
            gw_card_base_tax_invoiced: '',
            gw_card_base_tax_refunded: '',
            gw_card_price: '',
            gw_card_price_incl_tax: '',
            gw_card_price_invoiced: '',
            gw_card_price_refunded: '',
            gw_card_tax_amount: '',
            gw_card_tax_invoiced: '',
            gw_card_tax_refunded: '',
            gw_id: '',
            gw_items_base_price: '',
            gw_items_base_price_incl_tax: '',
            gw_items_base_price_invoiced: '',
            gw_items_base_price_refunded: '',
            gw_items_base_tax_amount: '',
            gw_items_base_tax_invoiced: '',
            gw_items_base_tax_refunded: '',
            gw_items_price: '',
            gw_items_price_incl_tax: '',
            gw_items_price_invoiced: '',
            gw_items_price_refunded: '',
            gw_items_tax_amount: '',
            gw_items_tax_invoiced: '',
            gw_items_tax_refunded: '',
            gw_price: '',
            gw_price_incl_tax: '',
            gw_price_invoiced: '',
            gw_price_refunded: '',
            gw_tax_amount: '',
            gw_tax_amount_invoiced: '',
            gw_tax_amount_refunded: '',
            item_applied_taxes: [
              {
                applied_taxes: [{}],
                associated_item_id: 0,
                extension_attributes: {},
                item_id: 0,
                type: ''
              }
            ],
            payment_additional_info: [{key: '', value: ''}],
            reward_currency_amount: '',
            reward_points_balance: 0,
            shipping_assignments: [
              {
                extension_attributes: {},
                items: [
                  {
                    additional_data: '',
                    amount_refunded: '',
                    applied_rule_ids: '',
                    base_amount_refunded: '',
                    base_cost: '',
                    base_discount_amount: '',
                    base_discount_invoiced: '',
                    base_discount_refunded: '',
                    base_discount_tax_compensation_amount: '',
                    base_discount_tax_compensation_invoiced: '',
                    base_discount_tax_compensation_refunded: '',
                    base_original_price: '',
                    base_price: '',
                    base_price_incl_tax: '',
                    base_row_invoiced: '',
                    base_row_total: '',
                    base_row_total_incl_tax: '',
                    base_tax_amount: '',
                    base_tax_before_discount: '',
                    base_tax_invoiced: '',
                    base_tax_refunded: '',
                    base_weee_tax_applied_amount: '',
                    base_weee_tax_applied_row_amnt: '',
                    base_weee_tax_disposition: '',
                    base_weee_tax_row_disposition: '',
                    created_at: '',
                    description: '',
                    discount_amount: '',
                    discount_invoiced: '',
                    discount_percent: '',
                    discount_refunded: '',
                    discount_tax_compensation_amount: '',
                    discount_tax_compensation_canceled: '',
                    discount_tax_compensation_invoiced: '',
                    discount_tax_compensation_refunded: '',
                    event_id: 0,
                    ext_order_item_id: '',
                    extension_attributes: {
                      gift_message: {},
                      gw_base_price: '',
                      gw_base_price_invoiced: '',
                      gw_base_price_refunded: '',
                      gw_base_tax_amount: '',
                      gw_base_tax_amount_invoiced: '',
                      gw_base_tax_amount_refunded: '',
                      gw_id: '',
                      gw_price: '',
                      gw_price_invoiced: '',
                      gw_price_refunded: '',
                      gw_tax_amount: '',
                      gw_tax_amount_invoiced: '',
                      gw_tax_amount_refunded: '',
                      invoice_text_codes: [],
                      tax_codes: [],
                      vertex_tax_codes: []
                    },
                    free_shipping: 0,
                    gw_base_price: '',
                    gw_base_price_invoiced: '',
                    gw_base_price_refunded: '',
                    gw_base_tax_amount: '',
                    gw_base_tax_amount_invoiced: '',
                    gw_base_tax_amount_refunded: '',
                    gw_id: 0,
                    gw_price: '',
                    gw_price_invoiced: '',
                    gw_price_refunded: '',
                    gw_tax_amount: '',
                    gw_tax_amount_invoiced: '',
                    gw_tax_amount_refunded: '',
                    is_qty_decimal: 0,
                    is_virtual: 0,
                    item_id: 0,
                    locked_do_invoice: 0,
                    locked_do_ship: 0,
                    name: '',
                    no_discount: 0,
                    order_id: 0,
                    original_price: '',
                    parent_item: '',
                    parent_item_id: 0,
                    price: '',
                    price_incl_tax: '',
                    product_id: 0,
                    product_option: {
                      extension_attributes: {
                        bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                        configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                        custom_options: [
                          {
                            extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                            option_id: '',
                            option_value: ''
                          }
                        ],
                        downloadable_option: {downloadable_links: []},
                        giftcard_item_option: {
                          custom_giftcard_amount: '',
                          extension_attributes: {},
                          giftcard_amount: '',
                          giftcard_message: '',
                          giftcard_recipient_email: '',
                          giftcard_recipient_name: '',
                          giftcard_sender_email: '',
                          giftcard_sender_name: ''
                        }
                      }
                    },
                    product_type: '',
                    qty_backordered: '',
                    qty_canceled: '',
                    qty_invoiced: '',
                    qty_ordered: '',
                    qty_refunded: '',
                    qty_returned: '',
                    qty_shipped: '',
                    quote_item_id: 0,
                    row_invoiced: '',
                    row_total: '',
                    row_total_incl_tax: '',
                    row_weight: '',
                    sku: '',
                    store_id: 0,
                    tax_amount: '',
                    tax_before_discount: '',
                    tax_canceled: '',
                    tax_invoiced: '',
                    tax_percent: '',
                    tax_refunded: '',
                    updated_at: '',
                    weee_tax_applied: '',
                    weee_tax_applied_amount: '',
                    weee_tax_applied_row_amount: '',
                    weee_tax_disposition: '',
                    weee_tax_row_disposition: '',
                    weight: ''
                  }
                ],
                shipping: {
                  address: {},
                  extension_attributes: {
                    collection_point: {
                      city: '',
                      collection_point_id: '',
                      country: '',
                      name: '',
                      postcode: '',
                      recipient_address_id: 0,
                      region: '',
                      street: []
                    },
                    ext_order_id: '',
                    shipping_experience: {code: '', cost: '', label: ''}
                  },
                  method: '',
                  total: {
                    base_shipping_amount: '',
                    base_shipping_canceled: '',
                    base_shipping_discount_amount: '',
                    base_shipping_discount_tax_compensation_amnt: '',
                    base_shipping_incl_tax: '',
                    base_shipping_invoiced: '',
                    base_shipping_refunded: '',
                    base_shipping_tax_amount: '',
                    base_shipping_tax_refunded: '',
                    extension_attributes: {},
                    shipping_amount: '',
                    shipping_canceled: '',
                    shipping_discount_amount: '',
                    shipping_discount_tax_compensation_amount: '',
                    shipping_incl_tax: '',
                    shipping_invoiced: '',
                    shipping_refunded: '',
                    shipping_tax_amount: '',
                    shipping_tax_refunded: ''
                  }
                },
                stock_id: 0
              }
            ]
          },
          forced_shipment_with_invoice: 0,
          global_currency_code: '',
          grand_total: '',
          hold_before_state: '',
          hold_before_status: '',
          increment_id: '',
          is_virtual: 0,
          items: [{}],
          order_currency_code: '',
          original_increment_id: '',
          payment: {
            account_status: '',
            additional_data: '',
            additional_information: [],
            address_status: '',
            amount_authorized: '',
            amount_canceled: '',
            amount_ordered: '',
            amount_paid: '',
            amount_refunded: '',
            anet_trans_method: '',
            base_amount_authorized: '',
            base_amount_canceled: '',
            base_amount_ordered: '',
            base_amount_paid: '',
            base_amount_paid_online: '',
            base_amount_refunded: '',
            base_amount_refunded_online: '',
            base_shipping_amount: '',
            base_shipping_captured: '',
            base_shipping_refunded: '',
            cc_approval: '',
            cc_avs_status: '',
            cc_cid_status: '',
            cc_debug_request_body: '',
            cc_debug_response_body: '',
            cc_debug_response_serialized: '',
            cc_exp_month: '',
            cc_exp_year: '',
            cc_last4: '',
            cc_number_enc: '',
            cc_owner: '',
            cc_secure_verify: '',
            cc_ss_issue: '',
            cc_ss_start_month: '',
            cc_ss_start_year: '',
            cc_status: '',
            cc_status_description: '',
            cc_trans_id: '',
            cc_type: '',
            echeck_account_name: '',
            echeck_account_type: '',
            echeck_bank_name: '',
            echeck_routing_number: '',
            echeck_type: '',
            entity_id: 0,
            extension_attributes: {
              vault_payment_token: {
                created_at: '',
                customer_id: 0,
                entity_id: 0,
                expires_at: '',
                gateway_token: '',
                is_active: false,
                is_visible: false,
                payment_method_code: '',
                public_hash: '',
                token_details: '',
                type: ''
              }
            },
            last_trans_id: '',
            method: '',
            parent_id: 0,
            po_number: '',
            protection_eligibility: '',
            quote_payment_id: 0,
            shipping_amount: '',
            shipping_captured: '',
            shipping_refunded: ''
          },
          payment_auth_expiration: 0,
          payment_authorization_amount: '',
          protect_code: '',
          quote_address_id: 0,
          quote_id: 0,
          relation_child_id: '',
          relation_child_real_id: '',
          relation_parent_id: '',
          relation_parent_real_id: '',
          remote_ip: '',
          shipping_amount: '',
          shipping_canceled: '',
          shipping_description: '',
          shipping_discount_amount: '',
          shipping_discount_tax_compensation_amount: '',
          shipping_incl_tax: '',
          shipping_invoiced: '',
          shipping_refunded: '',
          shipping_tax_amount: '',
          shipping_tax_refunded: '',
          state: '',
          status: '',
          status_histories: [
            {
              comment: '',
              created_at: '',
              entity_id: 0,
              entity_name: '',
              extension_attributes: {},
              is_customer_notified: 0,
              is_visible_on_front: 0,
              parent_id: 0,
              status: ''
            }
          ],
          store_currency_code: '',
          store_id: 0,
          store_name: '',
          store_to_base_rate: '',
          store_to_order_rate: '',
          subtotal: '',
          subtotal_canceled: '',
          subtotal_incl_tax: '',
          subtotal_invoiced: '',
          subtotal_refunded: '',
          tax_amount: '',
          tax_canceled: '',
          tax_invoiced: '',
          tax_refunded: '',
          total_canceled: '',
          total_due: '',
          total_invoiced: '',
          total_item_count: 0,
          total_offline_refunded: '',
          total_online_refunded: '',
          total_paid: '',
          total_qty_ordered: '',
          total_refunded: '',
          updated_at: '',
          weight: '',
          x_forwarded_for: ''
        },
        vertex_tax_calculation_shipping_address: {}
      },
      global_currency_code: '',
      grand_total: '',
      increment_id: '',
      is_used_for_refund: 0,
      items: [
        {
          additional_data: '',
          base_cost: '',
          base_discount_amount: '',
          base_discount_tax_compensation_amount: '',
          base_price: '',
          base_price_incl_tax: '',
          base_row_total: '',
          base_row_total_incl_tax: '',
          base_tax_amount: '',
          description: '',
          discount_amount: '',
          discount_tax_compensation_amount: '',
          entity_id: 0,
          extension_attributes: {invoice_text_codes: [], tax_codes: [], vertex_tax_codes: []},
          name: '',
          order_item_id: 0,
          parent_id: 0,
          price: '',
          price_incl_tax: '',
          product_id: 0,
          qty: '',
          row_total: '',
          row_total_incl_tax: '',
          sku: '',
          tax_amount: ''
        }
      ],
      order_currency_code: '',
      order_id: 0,
      shipping_address_id: 0,
      shipping_amount: '',
      shipping_discount_tax_compensation_amount: '',
      shipping_incl_tax: '',
      shipping_tax_amount: '',
      state: 0,
      store_currency_code: '',
      store_id: 0,
      store_to_base_rate: '',
      store_to_order_rate: '',
      subtotal: '',
      subtotal_incl_tax: '',
      tax_amount: '',
      total_qty: '',
      transaction_id: '',
      updated_at: ''
    }
  },
  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}}/V1/invoices/');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  entity: {
    base_currency_code: '',
    base_discount_amount: '',
    base_discount_tax_compensation_amount: '',
    base_grand_total: '',
    base_shipping_amount: '',
    base_shipping_discount_tax_compensation_amnt: '',
    base_shipping_incl_tax: '',
    base_shipping_tax_amount: '',
    base_subtotal: '',
    base_subtotal_incl_tax: '',
    base_tax_amount: '',
    base_to_global_rate: '',
    base_to_order_rate: '',
    base_total_refunded: '',
    billing_address_id: 0,
    can_void_flag: 0,
    comments: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0
      }
    ],
    created_at: '',
    discount_amount: '',
    discount_description: '',
    discount_tax_compensation_amount: '',
    email_sent: 0,
    entity_id: 0,
    extension_attributes: {
      base_customer_balance_amount: '',
      base_gift_cards_amount: '',
      customer_balance_amount: '',
      gift_cards_amount: '',
      gw_base_price: '',
      gw_base_tax_amount: '',
      gw_card_base_price: '',
      gw_card_base_tax_amount: '',
      gw_card_price: '',
      gw_card_tax_amount: '',
      gw_items_base_price: '',
      gw_items_base_tax_amount: '',
      gw_items_price: '',
      gw_items_tax_amount: '',
      gw_price: '',
      gw_tax_amount: '',
      vertex_tax_calculation_billing_address: {
        address_type: '',
        city: '',
        company: '',
        country_id: '',
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        entity_id: 0,
        extension_attributes: {
          checkout_fields: [
            {
              attribute_code: '',
              value: ''
            }
          ]
        },
        fax: '',
        firstname: '',
        lastname: '',
        middlename: '',
        parent_id: 0,
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: '',
        vat_is_valid: 0,
        vat_request_date: '',
        vat_request_id: '',
        vat_request_success: 0
      },
      vertex_tax_calculation_order: {
        adjustment_negative: '',
        adjustment_positive: '',
        applied_rule_ids: '',
        base_adjustment_negative: '',
        base_adjustment_positive: '',
        base_currency_code: '',
        base_discount_amount: '',
        base_discount_canceled: '',
        base_discount_invoiced: '',
        base_discount_refunded: '',
        base_discount_tax_compensation_amount: '',
        base_discount_tax_compensation_invoiced: '',
        base_discount_tax_compensation_refunded: '',
        base_grand_total: '',
        base_shipping_amount: '',
        base_shipping_canceled: '',
        base_shipping_discount_amount: '',
        base_shipping_discount_tax_compensation_amnt: '',
        base_shipping_incl_tax: '',
        base_shipping_invoiced: '',
        base_shipping_refunded: '',
        base_shipping_tax_amount: '',
        base_shipping_tax_refunded: '',
        base_subtotal: '',
        base_subtotal_canceled: '',
        base_subtotal_incl_tax: '',
        base_subtotal_invoiced: '',
        base_subtotal_refunded: '',
        base_tax_amount: '',
        base_tax_canceled: '',
        base_tax_invoiced: '',
        base_tax_refunded: '',
        base_to_global_rate: '',
        base_to_order_rate: '',
        base_total_canceled: '',
        base_total_due: '',
        base_total_invoiced: '',
        base_total_invoiced_cost: '',
        base_total_offline_refunded: '',
        base_total_online_refunded: '',
        base_total_paid: '',
        base_total_qty_ordered: '',
        base_total_refunded: '',
        billing_address: {},
        billing_address_id: 0,
        can_ship_partially: 0,
        can_ship_partially_item: 0,
        coupon_code: '',
        created_at: '',
        customer_dob: '',
        customer_email: '',
        customer_firstname: '',
        customer_gender: 0,
        customer_group_id: 0,
        customer_id: 0,
        customer_is_guest: 0,
        customer_lastname: '',
        customer_middlename: '',
        customer_note: '',
        customer_note_notify: 0,
        customer_prefix: '',
        customer_suffix: '',
        customer_taxvat: '',
        discount_amount: '',
        discount_canceled: '',
        discount_description: '',
        discount_invoiced: '',
        discount_refunded: '',
        discount_tax_compensation_amount: '',
        discount_tax_compensation_invoiced: '',
        discount_tax_compensation_refunded: '',
        edit_increment: 0,
        email_sent: 0,
        entity_id: 0,
        ext_customer_id: '',
        ext_order_id: '',
        extension_attributes: {
          amazon_order_reference_id: '',
          applied_taxes: [
            {
              amount: '',
              base_amount: '',
              code: '',
              extension_attributes: {
                rates: [
                  {
                    code: '',
                    extension_attributes: {},
                    percent: '',
                    title: ''
                  }
                ]
              },
              percent: '',
              title: ''
            }
          ],
          base_customer_balance_amount: '',
          base_customer_balance_invoiced: '',
          base_customer_balance_refunded: '',
          base_customer_balance_total_refunded: '',
          base_gift_cards_amount: '',
          base_gift_cards_invoiced: '',
          base_gift_cards_refunded: '',
          base_reward_currency_amount: '',
          company_order_attributes: {
            company_id: 0,
            company_name: '',
            extension_attributes: {},
            order_id: 0
          },
          converting_from_quote: false,
          customer_balance_amount: '',
          customer_balance_invoiced: '',
          customer_balance_refunded: '',
          customer_balance_total_refunded: '',
          gift_cards: [
            {
              amount: '',
              base_amount: '',
              code: '',
              id: 0
            }
          ],
          gift_cards_amount: '',
          gift_cards_invoiced: '',
          gift_cards_refunded: '',
          gift_message: {
            customer_id: 0,
            extension_attributes: {
              entity_id: '',
              entity_type: '',
              wrapping_add_printed_card: false,
              wrapping_allow_gift_receipt: false,
              wrapping_id: 0
            },
            gift_message_id: 0,
            message: '',
            recipient: '',
            sender: ''
          },
          gw_add_card: '',
          gw_allow_gift_receipt: '',
          gw_base_price: '',
          gw_base_price_incl_tax: '',
          gw_base_price_invoiced: '',
          gw_base_price_refunded: '',
          gw_base_tax_amount: '',
          gw_base_tax_amount_invoiced: '',
          gw_base_tax_amount_refunded: '',
          gw_card_base_price: '',
          gw_card_base_price_incl_tax: '',
          gw_card_base_price_invoiced: '',
          gw_card_base_price_refunded: '',
          gw_card_base_tax_amount: '',
          gw_card_base_tax_invoiced: '',
          gw_card_base_tax_refunded: '',
          gw_card_price: '',
          gw_card_price_incl_tax: '',
          gw_card_price_invoiced: '',
          gw_card_price_refunded: '',
          gw_card_tax_amount: '',
          gw_card_tax_invoiced: '',
          gw_card_tax_refunded: '',
          gw_id: '',
          gw_items_base_price: '',
          gw_items_base_price_incl_tax: '',
          gw_items_base_price_invoiced: '',
          gw_items_base_price_refunded: '',
          gw_items_base_tax_amount: '',
          gw_items_base_tax_invoiced: '',
          gw_items_base_tax_refunded: '',
          gw_items_price: '',
          gw_items_price_incl_tax: '',
          gw_items_price_invoiced: '',
          gw_items_price_refunded: '',
          gw_items_tax_amount: '',
          gw_items_tax_invoiced: '',
          gw_items_tax_refunded: '',
          gw_price: '',
          gw_price_incl_tax: '',
          gw_price_invoiced: '',
          gw_price_refunded: '',
          gw_tax_amount: '',
          gw_tax_amount_invoiced: '',
          gw_tax_amount_refunded: '',
          item_applied_taxes: [
            {
              applied_taxes: [
                {}
              ],
              associated_item_id: 0,
              extension_attributes: {},
              item_id: 0,
              type: ''
            }
          ],
          payment_additional_info: [
            {
              key: '',
              value: ''
            }
          ],
          reward_currency_amount: '',
          reward_points_balance: 0,
          shipping_assignments: [
            {
              extension_attributes: {},
              items: [
                {
                  additional_data: '',
                  amount_refunded: '',
                  applied_rule_ids: '',
                  base_amount_refunded: '',
                  base_cost: '',
                  base_discount_amount: '',
                  base_discount_invoiced: '',
                  base_discount_refunded: '',
                  base_discount_tax_compensation_amount: '',
                  base_discount_tax_compensation_invoiced: '',
                  base_discount_tax_compensation_refunded: '',
                  base_original_price: '',
                  base_price: '',
                  base_price_incl_tax: '',
                  base_row_invoiced: '',
                  base_row_total: '',
                  base_row_total_incl_tax: '',
                  base_tax_amount: '',
                  base_tax_before_discount: '',
                  base_tax_invoiced: '',
                  base_tax_refunded: '',
                  base_weee_tax_applied_amount: '',
                  base_weee_tax_applied_row_amnt: '',
                  base_weee_tax_disposition: '',
                  base_weee_tax_row_disposition: '',
                  created_at: '',
                  description: '',
                  discount_amount: '',
                  discount_invoiced: '',
                  discount_percent: '',
                  discount_refunded: '',
                  discount_tax_compensation_amount: '',
                  discount_tax_compensation_canceled: '',
                  discount_tax_compensation_invoiced: '',
                  discount_tax_compensation_refunded: '',
                  event_id: 0,
                  ext_order_item_id: '',
                  extension_attributes: {
                    gift_message: {},
                    gw_base_price: '',
                    gw_base_price_invoiced: '',
                    gw_base_price_refunded: '',
                    gw_base_tax_amount: '',
                    gw_base_tax_amount_invoiced: '',
                    gw_base_tax_amount_refunded: '',
                    gw_id: '',
                    gw_price: '',
                    gw_price_invoiced: '',
                    gw_price_refunded: '',
                    gw_tax_amount: '',
                    gw_tax_amount_invoiced: '',
                    gw_tax_amount_refunded: '',
                    invoice_text_codes: [],
                    tax_codes: [],
                    vertex_tax_codes: []
                  },
                  free_shipping: 0,
                  gw_base_price: '',
                  gw_base_price_invoiced: '',
                  gw_base_price_refunded: '',
                  gw_base_tax_amount: '',
                  gw_base_tax_amount_invoiced: '',
                  gw_base_tax_amount_refunded: '',
                  gw_id: 0,
                  gw_price: '',
                  gw_price_invoiced: '',
                  gw_price_refunded: '',
                  gw_tax_amount: '',
                  gw_tax_amount_invoiced: '',
                  gw_tax_amount_refunded: '',
                  is_qty_decimal: 0,
                  is_virtual: 0,
                  item_id: 0,
                  locked_do_invoice: 0,
                  locked_do_ship: 0,
                  name: '',
                  no_discount: 0,
                  order_id: 0,
                  original_price: '',
                  parent_item: '',
                  parent_item_id: 0,
                  price: '',
                  price_incl_tax: '',
                  product_id: 0,
                  product_option: {
                    extension_attributes: {
                      bundle_options: [
                        {
                          extension_attributes: {},
                          option_id: 0,
                          option_qty: 0,
                          option_selections: []
                        }
                      ],
                      configurable_item_options: [
                        {
                          extension_attributes: {},
                          option_id: '',
                          option_value: 0
                        }
                      ],
                      custom_options: [
                        {
                          extension_attributes: {
                            file_info: {
                              base64_encoded_data: '',
                              name: '',
                              type: ''
                            }
                          },
                          option_id: '',
                          option_value: ''
                        }
                      ],
                      downloadable_option: {
                        downloadable_links: []
                      },
                      giftcard_item_option: {
                        custom_giftcard_amount: '',
                        extension_attributes: {},
                        giftcard_amount: '',
                        giftcard_message: '',
                        giftcard_recipient_email: '',
                        giftcard_recipient_name: '',
                        giftcard_sender_email: '',
                        giftcard_sender_name: ''
                      }
                    }
                  },
                  product_type: '',
                  qty_backordered: '',
                  qty_canceled: '',
                  qty_invoiced: '',
                  qty_ordered: '',
                  qty_refunded: '',
                  qty_returned: '',
                  qty_shipped: '',
                  quote_item_id: 0,
                  row_invoiced: '',
                  row_total: '',
                  row_total_incl_tax: '',
                  row_weight: '',
                  sku: '',
                  store_id: 0,
                  tax_amount: '',
                  tax_before_discount: '',
                  tax_canceled: '',
                  tax_invoiced: '',
                  tax_percent: '',
                  tax_refunded: '',
                  updated_at: '',
                  weee_tax_applied: '',
                  weee_tax_applied_amount: '',
                  weee_tax_applied_row_amount: '',
                  weee_tax_disposition: '',
                  weee_tax_row_disposition: '',
                  weight: ''
                }
              ],
              shipping: {
                address: {},
                extension_attributes: {
                  collection_point: {
                    city: '',
                    collection_point_id: '',
                    country: '',
                    name: '',
                    postcode: '',
                    recipient_address_id: 0,
                    region: '',
                    street: []
                  },
                  ext_order_id: '',
                  shipping_experience: {
                    code: '',
                    cost: '',
                    label: ''
                  }
                },
                method: '',
                total: {
                  base_shipping_amount: '',
                  base_shipping_canceled: '',
                  base_shipping_discount_amount: '',
                  base_shipping_discount_tax_compensation_amnt: '',
                  base_shipping_incl_tax: '',
                  base_shipping_invoiced: '',
                  base_shipping_refunded: '',
                  base_shipping_tax_amount: '',
                  base_shipping_tax_refunded: '',
                  extension_attributes: {},
                  shipping_amount: '',
                  shipping_canceled: '',
                  shipping_discount_amount: '',
                  shipping_discount_tax_compensation_amount: '',
                  shipping_incl_tax: '',
                  shipping_invoiced: '',
                  shipping_refunded: '',
                  shipping_tax_amount: '',
                  shipping_tax_refunded: ''
                }
              },
              stock_id: 0
            }
          ]
        },
        forced_shipment_with_invoice: 0,
        global_currency_code: '',
        grand_total: '',
        hold_before_state: '',
        hold_before_status: '',
        increment_id: '',
        is_virtual: 0,
        items: [
          {}
        ],
        order_currency_code: '',
        original_increment_id: '',
        payment: {
          account_status: '',
          additional_data: '',
          additional_information: [],
          address_status: '',
          amount_authorized: '',
          amount_canceled: '',
          amount_ordered: '',
          amount_paid: '',
          amount_refunded: '',
          anet_trans_method: '',
          base_amount_authorized: '',
          base_amount_canceled: '',
          base_amount_ordered: '',
          base_amount_paid: '',
          base_amount_paid_online: '',
          base_amount_refunded: '',
          base_amount_refunded_online: '',
          base_shipping_amount: '',
          base_shipping_captured: '',
          base_shipping_refunded: '',
          cc_approval: '',
          cc_avs_status: '',
          cc_cid_status: '',
          cc_debug_request_body: '',
          cc_debug_response_body: '',
          cc_debug_response_serialized: '',
          cc_exp_month: '',
          cc_exp_year: '',
          cc_last4: '',
          cc_number_enc: '',
          cc_owner: '',
          cc_secure_verify: '',
          cc_ss_issue: '',
          cc_ss_start_month: '',
          cc_ss_start_year: '',
          cc_status: '',
          cc_status_description: '',
          cc_trans_id: '',
          cc_type: '',
          echeck_account_name: '',
          echeck_account_type: '',
          echeck_bank_name: '',
          echeck_routing_number: '',
          echeck_type: '',
          entity_id: 0,
          extension_attributes: {
            vault_payment_token: {
              created_at: '',
              customer_id: 0,
              entity_id: 0,
              expires_at: '',
              gateway_token: '',
              is_active: false,
              is_visible: false,
              payment_method_code: '',
              public_hash: '',
              token_details: '',
              type: ''
            }
          },
          last_trans_id: '',
          method: '',
          parent_id: 0,
          po_number: '',
          protection_eligibility: '',
          quote_payment_id: 0,
          shipping_amount: '',
          shipping_captured: '',
          shipping_refunded: ''
        },
        payment_auth_expiration: 0,
        payment_authorization_amount: '',
        protect_code: '',
        quote_address_id: 0,
        quote_id: 0,
        relation_child_id: '',
        relation_child_real_id: '',
        relation_parent_id: '',
        relation_parent_real_id: '',
        remote_ip: '',
        shipping_amount: '',
        shipping_canceled: '',
        shipping_description: '',
        shipping_discount_amount: '',
        shipping_discount_tax_compensation_amount: '',
        shipping_incl_tax: '',
        shipping_invoiced: '',
        shipping_refunded: '',
        shipping_tax_amount: '',
        shipping_tax_refunded: '',
        state: '',
        status: '',
        status_histories: [
          {
            comment: '',
            created_at: '',
            entity_id: 0,
            entity_name: '',
            extension_attributes: {},
            is_customer_notified: 0,
            is_visible_on_front: 0,
            parent_id: 0,
            status: ''
          }
        ],
        store_currency_code: '',
        store_id: 0,
        store_name: '',
        store_to_base_rate: '',
        store_to_order_rate: '',
        subtotal: '',
        subtotal_canceled: '',
        subtotal_incl_tax: '',
        subtotal_invoiced: '',
        subtotal_refunded: '',
        tax_amount: '',
        tax_canceled: '',
        tax_invoiced: '',
        tax_refunded: '',
        total_canceled: '',
        total_due: '',
        total_invoiced: '',
        total_item_count: 0,
        total_offline_refunded: '',
        total_online_refunded: '',
        total_paid: '',
        total_qty_ordered: '',
        total_refunded: '',
        updated_at: '',
        weight: '',
        x_forwarded_for: ''
      },
      vertex_tax_calculation_shipping_address: {}
    },
    global_currency_code: '',
    grand_total: '',
    increment_id: '',
    is_used_for_refund: 0,
    items: [
      {
        additional_data: '',
        base_cost: '',
        base_discount_amount: '',
        base_discount_tax_compensation_amount: '',
        base_price: '',
        base_price_incl_tax: '',
        base_row_total: '',
        base_row_total_incl_tax: '',
        base_tax_amount: '',
        description: '',
        discount_amount: '',
        discount_tax_compensation_amount: '',
        entity_id: 0,
        extension_attributes: {
          invoice_text_codes: [],
          tax_codes: [],
          vertex_tax_codes: []
        },
        name: '',
        order_item_id: 0,
        parent_id: 0,
        price: '',
        price_incl_tax: '',
        product_id: 0,
        qty: '',
        row_total: '',
        row_total_incl_tax: '',
        sku: '',
        tax_amount: ''
      }
    ],
    order_currency_code: '',
    order_id: 0,
    shipping_address_id: 0,
    shipping_amount: '',
    shipping_discount_tax_compensation_amount: '',
    shipping_incl_tax: '',
    shipping_tax_amount: '',
    state: 0,
    store_currency_code: '',
    store_id: 0,
    store_to_base_rate: '',
    store_to_order_rate: '',
    subtotal: '',
    subtotal_incl_tax: '',
    tax_amount: '',
    total_qty: '',
    transaction_id: '',
    updated_at: ''
  }
});

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}}/V1/invoices/',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      base_currency_code: '',
      base_discount_amount: '',
      base_discount_tax_compensation_amount: '',
      base_grand_total: '',
      base_shipping_amount: '',
      base_shipping_discount_tax_compensation_amnt: '',
      base_shipping_incl_tax: '',
      base_shipping_tax_amount: '',
      base_subtotal: '',
      base_subtotal_incl_tax: '',
      base_tax_amount: '',
      base_to_global_rate: '',
      base_to_order_rate: '',
      base_total_refunded: '',
      billing_address_id: 0,
      can_void_flag: 0,
      comments: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0
        }
      ],
      created_at: '',
      discount_amount: '',
      discount_description: '',
      discount_tax_compensation_amount: '',
      email_sent: 0,
      entity_id: 0,
      extension_attributes: {
        base_customer_balance_amount: '',
        base_gift_cards_amount: '',
        customer_balance_amount: '',
        gift_cards_amount: '',
        gw_base_price: '',
        gw_base_tax_amount: '',
        gw_card_base_price: '',
        gw_card_base_tax_amount: '',
        gw_card_price: '',
        gw_card_tax_amount: '',
        gw_items_base_price: '',
        gw_items_base_tax_amount: '',
        gw_items_price: '',
        gw_items_tax_amount: '',
        gw_price: '',
        gw_tax_amount: '',
        vertex_tax_calculation_billing_address: {
          address_type: '',
          city: '',
          company: '',
          country_id: '',
          customer_address_id: 0,
          customer_id: 0,
          email: '',
          entity_id: 0,
          extension_attributes: {checkout_fields: [{attribute_code: '', value: ''}]},
          fax: '',
          firstname: '',
          lastname: '',
          middlename: '',
          parent_id: 0,
          postcode: '',
          prefix: '',
          region: '',
          region_code: '',
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: '',
          vat_is_valid: 0,
          vat_request_date: '',
          vat_request_id: '',
          vat_request_success: 0
        },
        vertex_tax_calculation_order: {
          adjustment_negative: '',
          adjustment_positive: '',
          applied_rule_ids: '',
          base_adjustment_negative: '',
          base_adjustment_positive: '',
          base_currency_code: '',
          base_discount_amount: '',
          base_discount_canceled: '',
          base_discount_invoiced: '',
          base_discount_refunded: '',
          base_discount_tax_compensation_amount: '',
          base_discount_tax_compensation_invoiced: '',
          base_discount_tax_compensation_refunded: '',
          base_grand_total: '',
          base_shipping_amount: '',
          base_shipping_canceled: '',
          base_shipping_discount_amount: '',
          base_shipping_discount_tax_compensation_amnt: '',
          base_shipping_incl_tax: '',
          base_shipping_invoiced: '',
          base_shipping_refunded: '',
          base_shipping_tax_amount: '',
          base_shipping_tax_refunded: '',
          base_subtotal: '',
          base_subtotal_canceled: '',
          base_subtotal_incl_tax: '',
          base_subtotal_invoiced: '',
          base_subtotal_refunded: '',
          base_tax_amount: '',
          base_tax_canceled: '',
          base_tax_invoiced: '',
          base_tax_refunded: '',
          base_to_global_rate: '',
          base_to_order_rate: '',
          base_total_canceled: '',
          base_total_due: '',
          base_total_invoiced: '',
          base_total_invoiced_cost: '',
          base_total_offline_refunded: '',
          base_total_online_refunded: '',
          base_total_paid: '',
          base_total_qty_ordered: '',
          base_total_refunded: '',
          billing_address: {},
          billing_address_id: 0,
          can_ship_partially: 0,
          can_ship_partially_item: 0,
          coupon_code: '',
          created_at: '',
          customer_dob: '',
          customer_email: '',
          customer_firstname: '',
          customer_gender: 0,
          customer_group_id: 0,
          customer_id: 0,
          customer_is_guest: 0,
          customer_lastname: '',
          customer_middlename: '',
          customer_note: '',
          customer_note_notify: 0,
          customer_prefix: '',
          customer_suffix: '',
          customer_taxvat: '',
          discount_amount: '',
          discount_canceled: '',
          discount_description: '',
          discount_invoiced: '',
          discount_refunded: '',
          discount_tax_compensation_amount: '',
          discount_tax_compensation_invoiced: '',
          discount_tax_compensation_refunded: '',
          edit_increment: 0,
          email_sent: 0,
          entity_id: 0,
          ext_customer_id: '',
          ext_order_id: '',
          extension_attributes: {
            amazon_order_reference_id: '',
            applied_taxes: [
              {
                amount: '',
                base_amount: '',
                code: '',
                extension_attributes: {rates: [{code: '', extension_attributes: {}, percent: '', title: ''}]},
                percent: '',
                title: ''
              }
            ],
            base_customer_balance_amount: '',
            base_customer_balance_invoiced: '',
            base_customer_balance_refunded: '',
            base_customer_balance_total_refunded: '',
            base_gift_cards_amount: '',
            base_gift_cards_invoiced: '',
            base_gift_cards_refunded: '',
            base_reward_currency_amount: '',
            company_order_attributes: {company_id: 0, company_name: '', extension_attributes: {}, order_id: 0},
            converting_from_quote: false,
            customer_balance_amount: '',
            customer_balance_invoiced: '',
            customer_balance_refunded: '',
            customer_balance_total_refunded: '',
            gift_cards: [{amount: '', base_amount: '', code: '', id: 0}],
            gift_cards_amount: '',
            gift_cards_invoiced: '',
            gift_cards_refunded: '',
            gift_message: {
              customer_id: 0,
              extension_attributes: {
                entity_id: '',
                entity_type: '',
                wrapping_add_printed_card: false,
                wrapping_allow_gift_receipt: false,
                wrapping_id: 0
              },
              gift_message_id: 0,
              message: '',
              recipient: '',
              sender: ''
            },
            gw_add_card: '',
            gw_allow_gift_receipt: '',
            gw_base_price: '',
            gw_base_price_incl_tax: '',
            gw_base_price_invoiced: '',
            gw_base_price_refunded: '',
            gw_base_tax_amount: '',
            gw_base_tax_amount_invoiced: '',
            gw_base_tax_amount_refunded: '',
            gw_card_base_price: '',
            gw_card_base_price_incl_tax: '',
            gw_card_base_price_invoiced: '',
            gw_card_base_price_refunded: '',
            gw_card_base_tax_amount: '',
            gw_card_base_tax_invoiced: '',
            gw_card_base_tax_refunded: '',
            gw_card_price: '',
            gw_card_price_incl_tax: '',
            gw_card_price_invoiced: '',
            gw_card_price_refunded: '',
            gw_card_tax_amount: '',
            gw_card_tax_invoiced: '',
            gw_card_tax_refunded: '',
            gw_id: '',
            gw_items_base_price: '',
            gw_items_base_price_incl_tax: '',
            gw_items_base_price_invoiced: '',
            gw_items_base_price_refunded: '',
            gw_items_base_tax_amount: '',
            gw_items_base_tax_invoiced: '',
            gw_items_base_tax_refunded: '',
            gw_items_price: '',
            gw_items_price_incl_tax: '',
            gw_items_price_invoiced: '',
            gw_items_price_refunded: '',
            gw_items_tax_amount: '',
            gw_items_tax_invoiced: '',
            gw_items_tax_refunded: '',
            gw_price: '',
            gw_price_incl_tax: '',
            gw_price_invoiced: '',
            gw_price_refunded: '',
            gw_tax_amount: '',
            gw_tax_amount_invoiced: '',
            gw_tax_amount_refunded: '',
            item_applied_taxes: [
              {
                applied_taxes: [{}],
                associated_item_id: 0,
                extension_attributes: {},
                item_id: 0,
                type: ''
              }
            ],
            payment_additional_info: [{key: '', value: ''}],
            reward_currency_amount: '',
            reward_points_balance: 0,
            shipping_assignments: [
              {
                extension_attributes: {},
                items: [
                  {
                    additional_data: '',
                    amount_refunded: '',
                    applied_rule_ids: '',
                    base_amount_refunded: '',
                    base_cost: '',
                    base_discount_amount: '',
                    base_discount_invoiced: '',
                    base_discount_refunded: '',
                    base_discount_tax_compensation_amount: '',
                    base_discount_tax_compensation_invoiced: '',
                    base_discount_tax_compensation_refunded: '',
                    base_original_price: '',
                    base_price: '',
                    base_price_incl_tax: '',
                    base_row_invoiced: '',
                    base_row_total: '',
                    base_row_total_incl_tax: '',
                    base_tax_amount: '',
                    base_tax_before_discount: '',
                    base_tax_invoiced: '',
                    base_tax_refunded: '',
                    base_weee_tax_applied_amount: '',
                    base_weee_tax_applied_row_amnt: '',
                    base_weee_tax_disposition: '',
                    base_weee_tax_row_disposition: '',
                    created_at: '',
                    description: '',
                    discount_amount: '',
                    discount_invoiced: '',
                    discount_percent: '',
                    discount_refunded: '',
                    discount_tax_compensation_amount: '',
                    discount_tax_compensation_canceled: '',
                    discount_tax_compensation_invoiced: '',
                    discount_tax_compensation_refunded: '',
                    event_id: 0,
                    ext_order_item_id: '',
                    extension_attributes: {
                      gift_message: {},
                      gw_base_price: '',
                      gw_base_price_invoiced: '',
                      gw_base_price_refunded: '',
                      gw_base_tax_amount: '',
                      gw_base_tax_amount_invoiced: '',
                      gw_base_tax_amount_refunded: '',
                      gw_id: '',
                      gw_price: '',
                      gw_price_invoiced: '',
                      gw_price_refunded: '',
                      gw_tax_amount: '',
                      gw_tax_amount_invoiced: '',
                      gw_tax_amount_refunded: '',
                      invoice_text_codes: [],
                      tax_codes: [],
                      vertex_tax_codes: []
                    },
                    free_shipping: 0,
                    gw_base_price: '',
                    gw_base_price_invoiced: '',
                    gw_base_price_refunded: '',
                    gw_base_tax_amount: '',
                    gw_base_tax_amount_invoiced: '',
                    gw_base_tax_amount_refunded: '',
                    gw_id: 0,
                    gw_price: '',
                    gw_price_invoiced: '',
                    gw_price_refunded: '',
                    gw_tax_amount: '',
                    gw_tax_amount_invoiced: '',
                    gw_tax_amount_refunded: '',
                    is_qty_decimal: 0,
                    is_virtual: 0,
                    item_id: 0,
                    locked_do_invoice: 0,
                    locked_do_ship: 0,
                    name: '',
                    no_discount: 0,
                    order_id: 0,
                    original_price: '',
                    parent_item: '',
                    parent_item_id: 0,
                    price: '',
                    price_incl_tax: '',
                    product_id: 0,
                    product_option: {
                      extension_attributes: {
                        bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                        configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                        custom_options: [
                          {
                            extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                            option_id: '',
                            option_value: ''
                          }
                        ],
                        downloadable_option: {downloadable_links: []},
                        giftcard_item_option: {
                          custom_giftcard_amount: '',
                          extension_attributes: {},
                          giftcard_amount: '',
                          giftcard_message: '',
                          giftcard_recipient_email: '',
                          giftcard_recipient_name: '',
                          giftcard_sender_email: '',
                          giftcard_sender_name: ''
                        }
                      }
                    },
                    product_type: '',
                    qty_backordered: '',
                    qty_canceled: '',
                    qty_invoiced: '',
                    qty_ordered: '',
                    qty_refunded: '',
                    qty_returned: '',
                    qty_shipped: '',
                    quote_item_id: 0,
                    row_invoiced: '',
                    row_total: '',
                    row_total_incl_tax: '',
                    row_weight: '',
                    sku: '',
                    store_id: 0,
                    tax_amount: '',
                    tax_before_discount: '',
                    tax_canceled: '',
                    tax_invoiced: '',
                    tax_percent: '',
                    tax_refunded: '',
                    updated_at: '',
                    weee_tax_applied: '',
                    weee_tax_applied_amount: '',
                    weee_tax_applied_row_amount: '',
                    weee_tax_disposition: '',
                    weee_tax_row_disposition: '',
                    weight: ''
                  }
                ],
                shipping: {
                  address: {},
                  extension_attributes: {
                    collection_point: {
                      city: '',
                      collection_point_id: '',
                      country: '',
                      name: '',
                      postcode: '',
                      recipient_address_id: 0,
                      region: '',
                      street: []
                    },
                    ext_order_id: '',
                    shipping_experience: {code: '', cost: '', label: ''}
                  },
                  method: '',
                  total: {
                    base_shipping_amount: '',
                    base_shipping_canceled: '',
                    base_shipping_discount_amount: '',
                    base_shipping_discount_tax_compensation_amnt: '',
                    base_shipping_incl_tax: '',
                    base_shipping_invoiced: '',
                    base_shipping_refunded: '',
                    base_shipping_tax_amount: '',
                    base_shipping_tax_refunded: '',
                    extension_attributes: {},
                    shipping_amount: '',
                    shipping_canceled: '',
                    shipping_discount_amount: '',
                    shipping_discount_tax_compensation_amount: '',
                    shipping_incl_tax: '',
                    shipping_invoiced: '',
                    shipping_refunded: '',
                    shipping_tax_amount: '',
                    shipping_tax_refunded: ''
                  }
                },
                stock_id: 0
              }
            ]
          },
          forced_shipment_with_invoice: 0,
          global_currency_code: '',
          grand_total: '',
          hold_before_state: '',
          hold_before_status: '',
          increment_id: '',
          is_virtual: 0,
          items: [{}],
          order_currency_code: '',
          original_increment_id: '',
          payment: {
            account_status: '',
            additional_data: '',
            additional_information: [],
            address_status: '',
            amount_authorized: '',
            amount_canceled: '',
            amount_ordered: '',
            amount_paid: '',
            amount_refunded: '',
            anet_trans_method: '',
            base_amount_authorized: '',
            base_amount_canceled: '',
            base_amount_ordered: '',
            base_amount_paid: '',
            base_amount_paid_online: '',
            base_amount_refunded: '',
            base_amount_refunded_online: '',
            base_shipping_amount: '',
            base_shipping_captured: '',
            base_shipping_refunded: '',
            cc_approval: '',
            cc_avs_status: '',
            cc_cid_status: '',
            cc_debug_request_body: '',
            cc_debug_response_body: '',
            cc_debug_response_serialized: '',
            cc_exp_month: '',
            cc_exp_year: '',
            cc_last4: '',
            cc_number_enc: '',
            cc_owner: '',
            cc_secure_verify: '',
            cc_ss_issue: '',
            cc_ss_start_month: '',
            cc_ss_start_year: '',
            cc_status: '',
            cc_status_description: '',
            cc_trans_id: '',
            cc_type: '',
            echeck_account_name: '',
            echeck_account_type: '',
            echeck_bank_name: '',
            echeck_routing_number: '',
            echeck_type: '',
            entity_id: 0,
            extension_attributes: {
              vault_payment_token: {
                created_at: '',
                customer_id: 0,
                entity_id: 0,
                expires_at: '',
                gateway_token: '',
                is_active: false,
                is_visible: false,
                payment_method_code: '',
                public_hash: '',
                token_details: '',
                type: ''
              }
            },
            last_trans_id: '',
            method: '',
            parent_id: 0,
            po_number: '',
            protection_eligibility: '',
            quote_payment_id: 0,
            shipping_amount: '',
            shipping_captured: '',
            shipping_refunded: ''
          },
          payment_auth_expiration: 0,
          payment_authorization_amount: '',
          protect_code: '',
          quote_address_id: 0,
          quote_id: 0,
          relation_child_id: '',
          relation_child_real_id: '',
          relation_parent_id: '',
          relation_parent_real_id: '',
          remote_ip: '',
          shipping_amount: '',
          shipping_canceled: '',
          shipping_description: '',
          shipping_discount_amount: '',
          shipping_discount_tax_compensation_amount: '',
          shipping_incl_tax: '',
          shipping_invoiced: '',
          shipping_refunded: '',
          shipping_tax_amount: '',
          shipping_tax_refunded: '',
          state: '',
          status: '',
          status_histories: [
            {
              comment: '',
              created_at: '',
              entity_id: 0,
              entity_name: '',
              extension_attributes: {},
              is_customer_notified: 0,
              is_visible_on_front: 0,
              parent_id: 0,
              status: ''
            }
          ],
          store_currency_code: '',
          store_id: 0,
          store_name: '',
          store_to_base_rate: '',
          store_to_order_rate: '',
          subtotal: '',
          subtotal_canceled: '',
          subtotal_incl_tax: '',
          subtotal_invoiced: '',
          subtotal_refunded: '',
          tax_amount: '',
          tax_canceled: '',
          tax_invoiced: '',
          tax_refunded: '',
          total_canceled: '',
          total_due: '',
          total_invoiced: '',
          total_item_count: 0,
          total_offline_refunded: '',
          total_online_refunded: '',
          total_paid: '',
          total_qty_ordered: '',
          total_refunded: '',
          updated_at: '',
          weight: '',
          x_forwarded_for: ''
        },
        vertex_tax_calculation_shipping_address: {}
      },
      global_currency_code: '',
      grand_total: '',
      increment_id: '',
      is_used_for_refund: 0,
      items: [
        {
          additional_data: '',
          base_cost: '',
          base_discount_amount: '',
          base_discount_tax_compensation_amount: '',
          base_price: '',
          base_price_incl_tax: '',
          base_row_total: '',
          base_row_total_incl_tax: '',
          base_tax_amount: '',
          description: '',
          discount_amount: '',
          discount_tax_compensation_amount: '',
          entity_id: 0,
          extension_attributes: {invoice_text_codes: [], tax_codes: [], vertex_tax_codes: []},
          name: '',
          order_item_id: 0,
          parent_id: 0,
          price: '',
          price_incl_tax: '',
          product_id: 0,
          qty: '',
          row_total: '',
          row_total_incl_tax: '',
          sku: '',
          tax_amount: ''
        }
      ],
      order_currency_code: '',
      order_id: 0,
      shipping_address_id: 0,
      shipping_amount: '',
      shipping_discount_tax_compensation_amount: '',
      shipping_incl_tax: '',
      shipping_tax_amount: '',
      state: 0,
      store_currency_code: '',
      store_id: 0,
      store_to_base_rate: '',
      store_to_order_rate: '',
      subtotal: '',
      subtotal_incl_tax: '',
      tax_amount: '',
      total_qty: '',
      transaction_id: '',
      updated_at: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/invoices/';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"base_currency_code":"","base_discount_amount":"","base_discount_tax_compensation_amount":"","base_grand_total":"","base_shipping_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_tax_amount":"","base_subtotal":"","base_subtotal_incl_tax":"","base_tax_amount":"","base_to_global_rate":"","base_to_order_rate":"","base_total_refunded":"","billing_address_id":0,"can_void_flag":0,"comments":[{"comment":"","created_at":"","entity_id":0,"extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_id":0}],"created_at":"","discount_amount":"","discount_description":"","discount_tax_compensation_amount":"","email_sent":0,"entity_id":0,"extension_attributes":{"base_customer_balance_amount":"","base_gift_cards_amount":"","customer_balance_amount":"","gift_cards_amount":"","gw_base_price":"","gw_base_tax_amount":"","gw_card_base_price":"","gw_card_base_tax_amount":"","gw_card_price":"","gw_card_tax_amount":"","gw_items_base_price":"","gw_items_base_tax_amount":"","gw_items_price":"","gw_items_tax_amount":"","gw_price":"","gw_tax_amount":"","vertex_tax_calculation_billing_address":{"address_type":"","city":"","company":"","country_id":"","customer_address_id":0,"customer_id":0,"email":"","entity_id":0,"extension_attributes":{"checkout_fields":[{"attribute_code":"","value":""}]},"fax":"","firstname":"","lastname":"","middlename":"","parent_id":0,"postcode":"","prefix":"","region":"","region_code":"","region_id":0,"street":[],"suffix":"","telephone":"","vat_id":"","vat_is_valid":0,"vat_request_date":"","vat_request_id":"","vat_request_success":0},"vertex_tax_calculation_order":{"adjustment_negative":"","adjustment_positive":"","applied_rule_ids":"","base_adjustment_negative":"","base_adjustment_positive":"","base_currency_code":"","base_discount_amount":"","base_discount_canceled":"","base_discount_invoiced":"","base_discount_refunded":"","base_discount_tax_compensation_amount":"","base_discount_tax_compensation_invoiced":"","base_discount_tax_compensation_refunded":"","base_grand_total":"","base_shipping_amount":"","base_shipping_canceled":"","base_shipping_discount_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_invoiced":"","base_shipping_refunded":"","base_shipping_tax_amount":"","base_shipping_tax_refunded":"","base_subtotal":"","base_subtotal_canceled":"","base_subtotal_incl_tax":"","base_subtotal_invoiced":"","base_subtotal_refunded":"","base_tax_amount":"","base_tax_canceled":"","base_tax_invoiced":"","base_tax_refunded":"","base_to_global_rate":"","base_to_order_rate":"","base_total_canceled":"","base_total_due":"","base_total_invoiced":"","base_total_invoiced_cost":"","base_total_offline_refunded":"","base_total_online_refunded":"","base_total_paid":"","base_total_qty_ordered":"","base_total_refunded":"","billing_address":{},"billing_address_id":0,"can_ship_partially":0,"can_ship_partially_item":0,"coupon_code":"","created_at":"","customer_dob":"","customer_email":"","customer_firstname":"","customer_gender":0,"customer_group_id":0,"customer_id":0,"customer_is_guest":0,"customer_lastname":"","customer_middlename":"","customer_note":"","customer_note_notify":0,"customer_prefix":"","customer_suffix":"","customer_taxvat":"","discount_amount":"","discount_canceled":"","discount_description":"","discount_invoiced":"","discount_refunded":"","discount_tax_compensation_amount":"","discount_tax_compensation_invoiced":"","discount_tax_compensation_refunded":"","edit_increment":0,"email_sent":0,"entity_id":0,"ext_customer_id":"","ext_order_id":"","extension_attributes":{"amazon_order_reference_id":"","applied_taxes":[{"amount":"","base_amount":"","code":"","extension_attributes":{"rates":[{"code":"","extension_attributes":{},"percent":"","title":""}]},"percent":"","title":""}],"base_customer_balance_amount":"","base_customer_balance_invoiced":"","base_customer_balance_refunded":"","base_customer_balance_total_refunded":"","base_gift_cards_amount":"","base_gift_cards_invoiced":"","base_gift_cards_refunded":"","base_reward_currency_amount":"","company_order_attributes":{"company_id":0,"company_name":"","extension_attributes":{},"order_id":0},"converting_from_quote":false,"customer_balance_amount":"","customer_balance_invoiced":"","customer_balance_refunded":"","customer_balance_total_refunded":"","gift_cards":[{"amount":"","base_amount":"","code":"","id":0}],"gift_cards_amount":"","gift_cards_invoiced":"","gift_cards_refunded":"","gift_message":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""},"gw_add_card":"","gw_allow_gift_receipt":"","gw_base_price":"","gw_base_price_incl_tax":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_card_base_price":"","gw_card_base_price_incl_tax":"","gw_card_base_price_invoiced":"","gw_card_base_price_refunded":"","gw_card_base_tax_amount":"","gw_card_base_tax_invoiced":"","gw_card_base_tax_refunded":"","gw_card_price":"","gw_card_price_incl_tax":"","gw_card_price_invoiced":"","gw_card_price_refunded":"","gw_card_tax_amount":"","gw_card_tax_invoiced":"","gw_card_tax_refunded":"","gw_id":"","gw_items_base_price":"","gw_items_base_price_incl_tax":"","gw_items_base_price_invoiced":"","gw_items_base_price_refunded":"","gw_items_base_tax_amount":"","gw_items_base_tax_invoiced":"","gw_items_base_tax_refunded":"","gw_items_price":"","gw_items_price_incl_tax":"","gw_items_price_invoiced":"","gw_items_price_refunded":"","gw_items_tax_amount":"","gw_items_tax_invoiced":"","gw_items_tax_refunded":"","gw_price":"","gw_price_incl_tax":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","item_applied_taxes":[{"applied_taxes":[{}],"associated_item_id":0,"extension_attributes":{},"item_id":0,"type":""}],"payment_additional_info":[{"key":"","value":""}],"reward_currency_amount":"","reward_points_balance":0,"shipping_assignments":[{"extension_attributes":{},"items":[{"additional_data":"","amount_refunded":"","applied_rule_ids":"","base_amount_refunded":"","base_cost":"","base_discount_amount":"","base_discount_invoiced":"","base_discount_refunded":"","base_discount_tax_compensation_amount":"","base_discount_tax_compensation_invoiced":"","base_discount_tax_compensation_refunded":"","base_original_price":"","base_price":"","base_price_incl_tax":"","base_row_invoiced":"","base_row_total":"","base_row_total_incl_tax":"","base_tax_amount":"","base_tax_before_discount":"","base_tax_invoiced":"","base_tax_refunded":"","base_weee_tax_applied_amount":"","base_weee_tax_applied_row_amnt":"","base_weee_tax_disposition":"","base_weee_tax_row_disposition":"","created_at":"","description":"","discount_amount":"","discount_invoiced":"","discount_percent":"","discount_refunded":"","discount_tax_compensation_amount":"","discount_tax_compensation_canceled":"","discount_tax_compensation_invoiced":"","discount_tax_compensation_refunded":"","event_id":0,"ext_order_item_id":"","extension_attributes":{"gift_message":{},"gw_base_price":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_id":"","gw_price":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","invoice_text_codes":[],"tax_codes":[],"vertex_tax_codes":[]},"free_shipping":0,"gw_base_price":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_id":0,"gw_price":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","is_qty_decimal":0,"is_virtual":0,"item_id":0,"locked_do_invoice":0,"locked_do_ship":0,"name":"","no_discount":0,"order_id":0,"original_price":"","parent_item":"","parent_item_id":0,"price":"","price_incl_tax":"","product_id":0,"product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty_backordered":"","qty_canceled":"","qty_invoiced":"","qty_ordered":"","qty_refunded":"","qty_returned":"","qty_shipped":"","quote_item_id":0,"row_invoiced":"","row_total":"","row_total_incl_tax":"","row_weight":"","sku":"","store_id":0,"tax_amount":"","tax_before_discount":"","tax_canceled":"","tax_invoiced":"","tax_percent":"","tax_refunded":"","updated_at":"","weee_tax_applied":"","weee_tax_applied_amount":"","weee_tax_applied_row_amount":"","weee_tax_disposition":"","weee_tax_row_disposition":"","weight":""}],"shipping":{"address":{},"extension_attributes":{"collection_point":{"city":"","collection_point_id":"","country":"","name":"","postcode":"","recipient_address_id":0,"region":"","street":[]},"ext_order_id":"","shipping_experience":{"code":"","cost":"","label":""}},"method":"","total":{"base_shipping_amount":"","base_shipping_canceled":"","base_shipping_discount_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_invoiced":"","base_shipping_refunded":"","base_shipping_tax_amount":"","base_shipping_tax_refunded":"","extension_attributes":{},"shipping_amount":"","shipping_canceled":"","shipping_discount_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_invoiced":"","shipping_refunded":"","shipping_tax_amount":"","shipping_tax_refunded":""}},"stock_id":0}]},"forced_shipment_with_invoice":0,"global_currency_code":"","grand_total":"","hold_before_state":"","hold_before_status":"","increment_id":"","is_virtual":0,"items":[{}],"order_currency_code":"","original_increment_id":"","payment":{"account_status":"","additional_data":"","additional_information":[],"address_status":"","amount_authorized":"","amount_canceled":"","amount_ordered":"","amount_paid":"","amount_refunded":"","anet_trans_method":"","base_amount_authorized":"","base_amount_canceled":"","base_amount_ordered":"","base_amount_paid":"","base_amount_paid_online":"","base_amount_refunded":"","base_amount_refunded_online":"","base_shipping_amount":"","base_shipping_captured":"","base_shipping_refunded":"","cc_approval":"","cc_avs_status":"","cc_cid_status":"","cc_debug_request_body":"","cc_debug_response_body":"","cc_debug_response_serialized":"","cc_exp_month":"","cc_exp_year":"","cc_last4":"","cc_number_enc":"","cc_owner":"","cc_secure_verify":"","cc_ss_issue":"","cc_ss_start_month":"","cc_ss_start_year":"","cc_status":"","cc_status_description":"","cc_trans_id":"","cc_type":"","echeck_account_name":"","echeck_account_type":"","echeck_bank_name":"","echeck_routing_number":"","echeck_type":"","entity_id":0,"extension_attributes":{"vault_payment_token":{"created_at":"","customer_id":0,"entity_id":0,"expires_at":"","gateway_token":"","is_active":false,"is_visible":false,"payment_method_code":"","public_hash":"","token_details":"","type":""}},"last_trans_id":"","method":"","parent_id":0,"po_number":"","protection_eligibility":"","quote_payment_id":0,"shipping_amount":"","shipping_captured":"","shipping_refunded":""},"payment_auth_expiration":0,"payment_authorization_amount":"","protect_code":"","quote_address_id":0,"quote_id":0,"relation_child_id":"","relation_child_real_id":"","relation_parent_id":"","relation_parent_real_id":"","remote_ip":"","shipping_amount":"","shipping_canceled":"","shipping_description":"","shipping_discount_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_invoiced":"","shipping_refunded":"","shipping_tax_amount":"","shipping_tax_refunded":"","state":"","status":"","status_histories":[{"comment":"","created_at":"","entity_id":0,"entity_name":"","extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_id":0,"status":""}],"store_currency_code":"","store_id":0,"store_name":"","store_to_base_rate":"","store_to_order_rate":"","subtotal":"","subtotal_canceled":"","subtotal_incl_tax":"","subtotal_invoiced":"","subtotal_refunded":"","tax_amount":"","tax_canceled":"","tax_invoiced":"","tax_refunded":"","total_canceled":"","total_due":"","total_invoiced":"","total_item_count":0,"total_offline_refunded":"","total_online_refunded":"","total_paid":"","total_qty_ordered":"","total_refunded":"","updated_at":"","weight":"","x_forwarded_for":""},"vertex_tax_calculation_shipping_address":{}},"global_currency_code":"","grand_total":"","increment_id":"","is_used_for_refund":0,"items":[{"additional_data":"","base_cost":"","base_discount_amount":"","base_discount_tax_compensation_amount":"","base_price":"","base_price_incl_tax":"","base_row_total":"","base_row_total_incl_tax":"","base_tax_amount":"","description":"","discount_amount":"","discount_tax_compensation_amount":"","entity_id":0,"extension_attributes":{"invoice_text_codes":[],"tax_codes":[],"vertex_tax_codes":[]},"name":"","order_item_id":0,"parent_id":0,"price":"","price_incl_tax":"","product_id":0,"qty":"","row_total":"","row_total_incl_tax":"","sku":"","tax_amount":""}],"order_currency_code":"","order_id":0,"shipping_address_id":0,"shipping_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_tax_amount":"","state":0,"store_currency_code":"","store_id":0,"store_to_base_rate":"","store_to_order_rate":"","subtotal":"","subtotal_incl_tax":"","tax_amount":"","total_qty":"","transaction_id":"","updated_at":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"entity": @{ @"base_currency_code": @"", @"base_discount_amount": @"", @"base_discount_tax_compensation_amount": @"", @"base_grand_total": @"", @"base_shipping_amount": @"", @"base_shipping_discount_tax_compensation_amnt": @"", @"base_shipping_incl_tax": @"", @"base_shipping_tax_amount": @"", @"base_subtotal": @"", @"base_subtotal_incl_tax": @"", @"base_tax_amount": @"", @"base_to_global_rate": @"", @"base_to_order_rate": @"", @"base_total_refunded": @"", @"billing_address_id": @0, @"can_void_flag": @0, @"comments": @[ @{ @"comment": @"", @"created_at": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"is_customer_notified": @0, @"is_visible_on_front": @0, @"parent_id": @0 } ], @"created_at": @"", @"discount_amount": @"", @"discount_description": @"", @"discount_tax_compensation_amount": @"", @"email_sent": @0, @"entity_id": @0, @"extension_attributes": @{ @"base_customer_balance_amount": @"", @"base_gift_cards_amount": @"", @"customer_balance_amount": @"", @"gift_cards_amount": @"", @"gw_base_price": @"", @"gw_base_tax_amount": @"", @"gw_card_base_price": @"", @"gw_card_base_tax_amount": @"", @"gw_card_price": @"", @"gw_card_tax_amount": @"", @"gw_items_base_price": @"", @"gw_items_base_tax_amount": @"", @"gw_items_price": @"", @"gw_items_tax_amount": @"", @"gw_price": @"", @"gw_tax_amount": @"", @"vertex_tax_calculation_billing_address": @{ @"address_type": @"", @"city": @"", @"company": @"", @"country_id": @"", @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"entity_id": @0, @"extension_attributes": @{ @"checkout_fields": @[ @{ @"attribute_code": @"", @"value": @"" } ] }, @"fax": @"", @"firstname": @"", @"lastname": @"", @"middlename": @"", @"parent_id": @0, @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"", @"vat_is_valid": @0, @"vat_request_date": @"", @"vat_request_id": @"", @"vat_request_success": @0 }, @"vertex_tax_calculation_order": @{ @"adjustment_negative": @"", @"adjustment_positive": @"", @"applied_rule_ids": @"", @"base_adjustment_negative": @"", @"base_adjustment_positive": @"", @"base_currency_code": @"", @"base_discount_amount": @"", @"base_discount_canceled": @"", @"base_discount_invoiced": @"", @"base_discount_refunded": @"", @"base_discount_tax_compensation_amount": @"", @"base_discount_tax_compensation_invoiced": @"", @"base_discount_tax_compensation_refunded": @"", @"base_grand_total": @"", @"base_shipping_amount": @"", @"base_shipping_canceled": @"", @"base_shipping_discount_amount": @"", @"base_shipping_discount_tax_compensation_amnt": @"", @"base_shipping_incl_tax": @"", @"base_shipping_invoiced": @"", @"base_shipping_refunded": @"", @"base_shipping_tax_amount": @"", @"base_shipping_tax_refunded": @"", @"base_subtotal": @"", @"base_subtotal_canceled": @"", @"base_subtotal_incl_tax": @"", @"base_subtotal_invoiced": @"", @"base_subtotal_refunded": @"", @"base_tax_amount": @"", @"base_tax_canceled": @"", @"base_tax_invoiced": @"", @"base_tax_refunded": @"", @"base_to_global_rate": @"", @"base_to_order_rate": @"", @"base_total_canceled": @"", @"base_total_due": @"", @"base_total_invoiced": @"", @"base_total_invoiced_cost": @"", @"base_total_offline_refunded": @"", @"base_total_online_refunded": @"", @"base_total_paid": @"", @"base_total_qty_ordered": @"", @"base_total_refunded": @"", @"billing_address": @{  }, @"billing_address_id": @0, @"can_ship_partially": @0, @"can_ship_partially_item": @0, @"coupon_code": @"", @"created_at": @"", @"customer_dob": @"", @"customer_email": @"", @"customer_firstname": @"", @"customer_gender": @0, @"customer_group_id": @0, @"customer_id": @0, @"customer_is_guest": @0, @"customer_lastname": @"", @"customer_middlename": @"", @"customer_note": @"", @"customer_note_notify": @0, @"customer_prefix": @"", @"customer_suffix": @"", @"customer_taxvat": @"", @"discount_amount": @"", @"discount_canceled": @"", @"discount_description": @"", @"discount_invoiced": @"", @"discount_refunded": @"", @"discount_tax_compensation_amount": @"", @"discount_tax_compensation_invoiced": @"", @"discount_tax_compensation_refunded": @"", @"edit_increment": @0, @"email_sent": @0, @"entity_id": @0, @"ext_customer_id": @"", @"ext_order_id": @"", @"extension_attributes": @{ @"amazon_order_reference_id": @"", @"applied_taxes": @[ @{ @"amount": @"", @"base_amount": @"", @"code": @"", @"extension_attributes": @{ @"rates": @[ @{ @"code": @"", @"extension_attributes": @{  }, @"percent": @"", @"title": @"" } ] }, @"percent": @"", @"title": @"" } ], @"base_customer_balance_amount": @"", @"base_customer_balance_invoiced": @"", @"base_customer_balance_refunded": @"", @"base_customer_balance_total_refunded": @"", @"base_gift_cards_amount": @"", @"base_gift_cards_invoiced": @"", @"base_gift_cards_refunded": @"", @"base_reward_currency_amount": @"", @"company_order_attributes": @{ @"company_id": @0, @"company_name": @"", @"extension_attributes": @{  }, @"order_id": @0 }, @"converting_from_quote": @NO, @"customer_balance_amount": @"", @"customer_balance_invoiced": @"", @"customer_balance_refunded": @"", @"customer_balance_total_refunded": @"", @"gift_cards": @[ @{ @"amount": @"", @"base_amount": @"", @"code": @"", @"id": @0 } ], @"gift_cards_amount": @"", @"gift_cards_invoiced": @"", @"gift_cards_refunded": @"", @"gift_message": @{ @"customer_id": @0, @"extension_attributes": @{ @"entity_id": @"", @"entity_type": @"", @"wrapping_add_printed_card": @NO, @"wrapping_allow_gift_receipt": @NO, @"wrapping_id": @0 }, @"gift_message_id": @0, @"message": @"", @"recipient": @"", @"sender": @"" }, @"gw_add_card": @"", @"gw_allow_gift_receipt": @"", @"gw_base_price": @"", @"gw_base_price_incl_tax": @"", @"gw_base_price_invoiced": @"", @"gw_base_price_refunded": @"", @"gw_base_tax_amount": @"", @"gw_base_tax_amount_invoiced": @"", @"gw_base_tax_amount_refunded": @"", @"gw_card_base_price": @"", @"gw_card_base_price_incl_tax": @"", @"gw_card_base_price_invoiced": @"", @"gw_card_base_price_refunded": @"", @"gw_card_base_tax_amount": @"", @"gw_card_base_tax_invoiced": @"", @"gw_card_base_tax_refunded": @"", @"gw_card_price": @"", @"gw_card_price_incl_tax": @"", @"gw_card_price_invoiced": @"", @"gw_card_price_refunded": @"", @"gw_card_tax_amount": @"", @"gw_card_tax_invoiced": @"", @"gw_card_tax_refunded": @"", @"gw_id": @"", @"gw_items_base_price": @"", @"gw_items_base_price_incl_tax": @"", @"gw_items_base_price_invoiced": @"", @"gw_items_base_price_refunded": @"", @"gw_items_base_tax_amount": @"", @"gw_items_base_tax_invoiced": @"", @"gw_items_base_tax_refunded": @"", @"gw_items_price": @"", @"gw_items_price_incl_tax": @"", @"gw_items_price_invoiced": @"", @"gw_items_price_refunded": @"", @"gw_items_tax_amount": @"", @"gw_items_tax_invoiced": @"", @"gw_items_tax_refunded": @"", @"gw_price": @"", @"gw_price_incl_tax": @"", @"gw_price_invoiced": @"", @"gw_price_refunded": @"", @"gw_tax_amount": @"", @"gw_tax_amount_invoiced": @"", @"gw_tax_amount_refunded": @"", @"item_applied_taxes": @[ @{ @"applied_taxes": @[ @{  } ], @"associated_item_id": @0, @"extension_attributes": @{  }, @"item_id": @0, @"type": @"" } ], @"payment_additional_info": @[ @{ @"key": @"", @"value": @"" } ], @"reward_currency_amount": @"", @"reward_points_balance": @0, @"shipping_assignments": @[ @{ @"extension_attributes": @{  }, @"items": @[ @{ @"additional_data": @"", @"amount_refunded": @"", @"applied_rule_ids": @"", @"base_amount_refunded": @"", @"base_cost": @"", @"base_discount_amount": @"", @"base_discount_invoiced": @"", @"base_discount_refunded": @"", @"base_discount_tax_compensation_amount": @"", @"base_discount_tax_compensation_invoiced": @"", @"base_discount_tax_compensation_refunded": @"", @"base_original_price": @"", @"base_price": @"", @"base_price_incl_tax": @"", @"base_row_invoiced": @"", @"base_row_total": @"", @"base_row_total_incl_tax": @"", @"base_tax_amount": @"", @"base_tax_before_discount": @"", @"base_tax_invoiced": @"", @"base_tax_refunded": @"", @"base_weee_tax_applied_amount": @"", @"base_weee_tax_applied_row_amnt": @"", @"base_weee_tax_disposition": @"", @"base_weee_tax_row_disposition": @"", @"created_at": @"", @"description": @"", @"discount_amount": @"", @"discount_invoiced": @"", @"discount_percent": @"", @"discount_refunded": @"", @"discount_tax_compensation_amount": @"", @"discount_tax_compensation_canceled": @"", @"discount_tax_compensation_invoiced": @"", @"discount_tax_compensation_refunded": @"", @"event_id": @0, @"ext_order_item_id": @"", @"extension_attributes": @{ @"gift_message": @{  }, @"gw_base_price": @"", @"gw_base_price_invoiced": @"", @"gw_base_price_refunded": @"", @"gw_base_tax_amount": @"", @"gw_base_tax_amount_invoiced": @"", @"gw_base_tax_amount_refunded": @"", @"gw_id": @"", @"gw_price": @"", @"gw_price_invoiced": @"", @"gw_price_refunded": @"", @"gw_tax_amount": @"", @"gw_tax_amount_invoiced": @"", @"gw_tax_amount_refunded": @"", @"invoice_text_codes": @[  ], @"tax_codes": @[  ], @"vertex_tax_codes": @[  ] }, @"free_shipping": @0, @"gw_base_price": @"", @"gw_base_price_invoiced": @"", @"gw_base_price_refunded": @"", @"gw_base_tax_amount": @"", @"gw_base_tax_amount_invoiced": @"", @"gw_base_tax_amount_refunded": @"", @"gw_id": @0, @"gw_price": @"", @"gw_price_invoiced": @"", @"gw_price_refunded": @"", @"gw_tax_amount": @"", @"gw_tax_amount_invoiced": @"", @"gw_tax_amount_refunded": @"", @"is_qty_decimal": @0, @"is_virtual": @0, @"item_id": @0, @"locked_do_invoice": @0, @"locked_do_ship": @0, @"name": @"", @"no_discount": @0, @"order_id": @0, @"original_price": @"", @"parent_item": @"", @"parent_item_id": @0, @"price": @"", @"price_incl_tax": @"", @"product_id": @0, @"product_option": @{ @"extension_attributes": @{ @"bundle_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @0, @"option_qty": @0, @"option_selections": @[  ] } ], @"configurable_item_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @"", @"option_value": @0 } ], @"custom_options": @[ @{ @"extension_attributes": @{ @"file_info": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" } }, @"option_id": @"", @"option_value": @"" } ], @"downloadable_option": @{ @"downloadable_links": @[  ] }, @"giftcard_item_option": @{ @"custom_giftcard_amount": @"", @"extension_attributes": @{  }, @"giftcard_amount": @"", @"giftcard_message": @"", @"giftcard_recipient_email": @"", @"giftcard_recipient_name": @"", @"giftcard_sender_email": @"", @"giftcard_sender_name": @"" } } }, @"product_type": @"", @"qty_backordered": @"", @"qty_canceled": @"", @"qty_invoiced": @"", @"qty_ordered": @"", @"qty_refunded": @"", @"qty_returned": @"", @"qty_shipped": @"", @"quote_item_id": @0, @"row_invoiced": @"", @"row_total": @"", @"row_total_incl_tax": @"", @"row_weight": @"", @"sku": @"", @"store_id": @0, @"tax_amount": @"", @"tax_before_discount": @"", @"tax_canceled": @"", @"tax_invoiced": @"", @"tax_percent": @"", @"tax_refunded": @"", @"updated_at": @"", @"weee_tax_applied": @"", @"weee_tax_applied_amount": @"", @"weee_tax_applied_row_amount": @"", @"weee_tax_disposition": @"", @"weee_tax_row_disposition": @"", @"weight": @"" } ], @"shipping": @{ @"address": @{  }, @"extension_attributes": @{ @"collection_point": @{ @"city": @"", @"collection_point_id": @"", @"country": @"", @"name": @"", @"postcode": @"", @"recipient_address_id": @0, @"region": @"", @"street": @[  ] }, @"ext_order_id": @"", @"shipping_experience": @{ @"code": @"", @"cost": @"", @"label": @"" } }, @"method": @"", @"total": @{ @"base_shipping_amount": @"", @"base_shipping_canceled": @"", @"base_shipping_discount_amount": @"", @"base_shipping_discount_tax_compensation_amnt": @"", @"base_shipping_incl_tax": @"", @"base_shipping_invoiced": @"", @"base_shipping_refunded": @"", @"base_shipping_tax_amount": @"", @"base_shipping_tax_refunded": @"", @"extension_attributes": @{  }, @"shipping_amount": @"", @"shipping_canceled": @"", @"shipping_discount_amount": @"", @"shipping_discount_tax_compensation_amount": @"", @"shipping_incl_tax": @"", @"shipping_invoiced": @"", @"shipping_refunded": @"", @"shipping_tax_amount": @"", @"shipping_tax_refunded": @"" } }, @"stock_id": @0 } ] }, @"forced_shipment_with_invoice": @0, @"global_currency_code": @"", @"grand_total": @"", @"hold_before_state": @"", @"hold_before_status": @"", @"increment_id": @"", @"is_virtual": @0, @"items": @[ @{  } ], @"order_currency_code": @"", @"original_increment_id": @"", @"payment": @{ @"account_status": @"", @"additional_data": @"", @"additional_information": @[  ], @"address_status": @"", @"amount_authorized": @"", @"amount_canceled": @"", @"amount_ordered": @"", @"amount_paid": @"", @"amount_refunded": @"", @"anet_trans_method": @"", @"base_amount_authorized": @"", @"base_amount_canceled": @"", @"base_amount_ordered": @"", @"base_amount_paid": @"", @"base_amount_paid_online": @"", @"base_amount_refunded": @"", @"base_amount_refunded_online": @"", @"base_shipping_amount": @"", @"base_shipping_captured": @"", @"base_shipping_refunded": @"", @"cc_approval": @"", @"cc_avs_status": @"", @"cc_cid_status": @"", @"cc_debug_request_body": @"", @"cc_debug_response_body": @"", @"cc_debug_response_serialized": @"", @"cc_exp_month": @"", @"cc_exp_year": @"", @"cc_last4": @"", @"cc_number_enc": @"", @"cc_owner": @"", @"cc_secure_verify": @"", @"cc_ss_issue": @"", @"cc_ss_start_month": @"", @"cc_ss_start_year": @"", @"cc_status": @"", @"cc_status_description": @"", @"cc_trans_id": @"", @"cc_type": @"", @"echeck_account_name": @"", @"echeck_account_type": @"", @"echeck_bank_name": @"", @"echeck_routing_number": @"", @"echeck_type": @"", @"entity_id": @0, @"extension_attributes": @{ @"vault_payment_token": @{ @"created_at": @"", @"customer_id": @0, @"entity_id": @0, @"expires_at": @"", @"gateway_token": @"", @"is_active": @NO, @"is_visible": @NO, @"payment_method_code": @"", @"public_hash": @"", @"token_details": @"", @"type": @"" } }, @"last_trans_id": @"", @"method": @"", @"parent_id": @0, @"po_number": @"", @"protection_eligibility": @"", @"quote_payment_id": @0, @"shipping_amount": @"", @"shipping_captured": @"", @"shipping_refunded": @"" }, @"payment_auth_expiration": @0, @"payment_authorization_amount": @"", @"protect_code": @"", @"quote_address_id": @0, @"quote_id": @0, @"relation_child_id": @"", @"relation_child_real_id": @"", @"relation_parent_id": @"", @"relation_parent_real_id": @"", @"remote_ip": @"", @"shipping_amount": @"", @"shipping_canceled": @"", @"shipping_description": @"", @"shipping_discount_amount": @"", @"shipping_discount_tax_compensation_amount": @"", @"shipping_incl_tax": @"", @"shipping_invoiced": @"", @"shipping_refunded": @"", @"shipping_tax_amount": @"", @"shipping_tax_refunded": @"", @"state": @"", @"status": @"", @"status_histories": @[ @{ @"comment": @"", @"created_at": @"", @"entity_id": @0, @"entity_name": @"", @"extension_attributes": @{  }, @"is_customer_notified": @0, @"is_visible_on_front": @0, @"parent_id": @0, @"status": @"" } ], @"store_currency_code": @"", @"store_id": @0, @"store_name": @"", @"store_to_base_rate": @"", @"store_to_order_rate": @"", @"subtotal": @"", @"subtotal_canceled": @"", @"subtotal_incl_tax": @"", @"subtotal_invoiced": @"", @"subtotal_refunded": @"", @"tax_amount": @"", @"tax_canceled": @"", @"tax_invoiced": @"", @"tax_refunded": @"", @"total_canceled": @"", @"total_due": @"", @"total_invoiced": @"", @"total_item_count": @0, @"total_offline_refunded": @"", @"total_online_refunded": @"", @"total_paid": @"", @"total_qty_ordered": @"", @"total_refunded": @"", @"updated_at": @"", @"weight": @"", @"x_forwarded_for": @"" }, @"vertex_tax_calculation_shipping_address": @{  } }, @"global_currency_code": @"", @"grand_total": @"", @"increment_id": @"", @"is_used_for_refund": @0, @"items": @[ @{ @"additional_data": @"", @"base_cost": @"", @"base_discount_amount": @"", @"base_discount_tax_compensation_amount": @"", @"base_price": @"", @"base_price_incl_tax": @"", @"base_row_total": @"", @"base_row_total_incl_tax": @"", @"base_tax_amount": @"", @"description": @"", @"discount_amount": @"", @"discount_tax_compensation_amount": @"", @"entity_id": @0, @"extension_attributes": @{ @"invoice_text_codes": @[  ], @"tax_codes": @[  ], @"vertex_tax_codes": @[  ] }, @"name": @"", @"order_item_id": @0, @"parent_id": @0, @"price": @"", @"price_incl_tax": @"", @"product_id": @0, @"qty": @"", @"row_total": @"", @"row_total_incl_tax": @"", @"sku": @"", @"tax_amount": @"" } ], @"order_currency_code": @"", @"order_id": @0, @"shipping_address_id": @0, @"shipping_amount": @"", @"shipping_discount_tax_compensation_amount": @"", @"shipping_incl_tax": @"", @"shipping_tax_amount": @"", @"state": @0, @"store_currency_code": @"", @"store_id": @0, @"store_to_base_rate": @"", @"store_to_order_rate": @"", @"subtotal": @"", @"subtotal_incl_tax": @"", @"tax_amount": @"", @"total_qty": @"", @"transaction_id": @"", @"updated_at": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/invoices/"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/invoices/" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"entity\": {\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address_id\": 0,\n    \"can_void_flag\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"vertex_tax_calculation_billing_address\": {\n        \"address_type\": \"\",\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"customer_address_id\": 0,\n        \"customer_id\": 0,\n        \"email\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"checkout_fields\": [\n            {\n              \"attribute_code\": \"\",\n              \"value\": \"\"\n            }\n          ]\n        },\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"parent_id\": 0,\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": \"\",\n        \"region_code\": \"\",\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\",\n        \"vat_is_valid\": 0,\n        \"vat_request_date\": \"\",\n        \"vat_request_id\": \"\",\n        \"vat_request_success\": 0\n      },\n      \"vertex_tax_calculation_order\": {\n        \"adjustment_negative\": \"\",\n        \"adjustment_positive\": \"\",\n        \"applied_rule_ids\": \"\",\n        \"base_adjustment_negative\": \"\",\n        \"base_adjustment_positive\": \"\",\n        \"base_currency_code\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_canceled\": \"\",\n        \"base_discount_invoiced\": \"\",\n        \"base_discount_refunded\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_discount_tax_compensation_invoiced\": \"\",\n        \"base_discount_tax_compensation_refunded\": \"\",\n        \"base_grand_total\": \"\",\n        \"base_shipping_amount\": \"\",\n        \"base_shipping_canceled\": \"\",\n        \"base_shipping_discount_amount\": \"\",\n        \"base_shipping_discount_tax_compensation_amnt\": \"\",\n        \"base_shipping_incl_tax\": \"\",\n        \"base_shipping_invoiced\": \"\",\n        \"base_shipping_refunded\": \"\",\n        \"base_shipping_tax_amount\": \"\",\n        \"base_shipping_tax_refunded\": \"\",\n        \"base_subtotal\": \"\",\n        \"base_subtotal_canceled\": \"\",\n        \"base_subtotal_incl_tax\": \"\",\n        \"base_subtotal_invoiced\": \"\",\n        \"base_subtotal_refunded\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_tax_canceled\": \"\",\n        \"base_tax_invoiced\": \"\",\n        \"base_tax_refunded\": \"\",\n        \"base_to_global_rate\": \"\",\n        \"base_to_order_rate\": \"\",\n        \"base_total_canceled\": \"\",\n        \"base_total_due\": \"\",\n        \"base_total_invoiced\": \"\",\n        \"base_total_invoiced_cost\": \"\",\n        \"base_total_offline_refunded\": \"\",\n        \"base_total_online_refunded\": \"\",\n        \"base_total_paid\": \"\",\n        \"base_total_qty_ordered\": \"\",\n        \"base_total_refunded\": \"\",\n        \"billing_address\": {},\n        \"billing_address_id\": 0,\n        \"can_ship_partially\": 0,\n        \"can_ship_partially_item\": 0,\n        \"coupon_code\": \"\",\n        \"created_at\": \"\",\n        \"customer_dob\": \"\",\n        \"customer_email\": \"\",\n        \"customer_firstname\": \"\",\n        \"customer_gender\": 0,\n        \"customer_group_id\": 0,\n        \"customer_id\": 0,\n        \"customer_is_guest\": 0,\n        \"customer_lastname\": \"\",\n        \"customer_middlename\": \"\",\n        \"customer_note\": \"\",\n        \"customer_note_notify\": 0,\n        \"customer_prefix\": \"\",\n        \"customer_suffix\": \"\",\n        \"customer_taxvat\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_canceled\": \"\",\n        \"discount_description\": \"\",\n        \"discount_invoiced\": \"\",\n        \"discount_refunded\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"discount_tax_compensation_invoiced\": \"\",\n        \"discount_tax_compensation_refunded\": \"\",\n        \"edit_increment\": 0,\n        \"email_sent\": 0,\n        \"entity_id\": 0,\n        \"ext_customer_id\": \"\",\n        \"ext_order_id\": \"\",\n        \"extension_attributes\": {\n          \"amazon_order_reference_id\": \"\",\n          \"applied_taxes\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"extension_attributes\": {\n                \"rates\": [\n                  {\n                    \"code\": \"\",\n                    \"extension_attributes\": {},\n                    \"percent\": \"\",\n                    \"title\": \"\"\n                  }\n                ]\n              },\n              \"percent\": \"\",\n              \"title\": \"\"\n            }\n          ],\n          \"base_customer_balance_amount\": \"\",\n          \"base_customer_balance_invoiced\": \"\",\n          \"base_customer_balance_refunded\": \"\",\n          \"base_customer_balance_total_refunded\": \"\",\n          \"base_gift_cards_amount\": \"\",\n          \"base_gift_cards_invoiced\": \"\",\n          \"base_gift_cards_refunded\": \"\",\n          \"base_reward_currency_amount\": \"\",\n          \"company_order_attributes\": {\n            \"company_id\": 0,\n            \"company_name\": \"\",\n            \"extension_attributes\": {},\n            \"order_id\": 0\n          },\n          \"converting_from_quote\": false,\n          \"customer_balance_amount\": \"\",\n          \"customer_balance_invoiced\": \"\",\n          \"customer_balance_refunded\": \"\",\n          \"customer_balance_total_refunded\": \"\",\n          \"gift_cards\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"id\": 0\n            }\n          ],\n          \"gift_cards_amount\": \"\",\n          \"gift_cards_invoiced\": \"\",\n          \"gift_cards_refunded\": \"\",\n          \"gift_message\": {\n            \"customer_id\": 0,\n            \"extension_attributes\": {\n              \"entity_id\": \"\",\n              \"entity_type\": \"\",\n              \"wrapping_add_printed_card\": false,\n              \"wrapping_allow_gift_receipt\": false,\n              \"wrapping_id\": 0\n            },\n            \"gift_message_id\": 0,\n            \"message\": \"\",\n            \"recipient\": \"\",\n            \"sender\": \"\"\n          },\n          \"gw_add_card\": \"\",\n          \"gw_allow_gift_receipt\": \"\",\n          \"gw_base_price\": \"\",\n          \"gw_base_price_incl_tax\": \"\",\n          \"gw_base_price_invoiced\": \"\",\n          \"gw_base_price_refunded\": \"\",\n          \"gw_base_tax_amount\": \"\",\n          \"gw_base_tax_amount_invoiced\": \"\",\n          \"gw_base_tax_amount_refunded\": \"\",\n          \"gw_card_base_price\": \"\",\n          \"gw_card_base_price_incl_tax\": \"\",\n          \"gw_card_base_price_invoiced\": \"\",\n          \"gw_card_base_price_refunded\": \"\",\n          \"gw_card_base_tax_amount\": \"\",\n          \"gw_card_base_tax_invoiced\": \"\",\n          \"gw_card_base_tax_refunded\": \"\",\n          \"gw_card_price\": \"\",\n          \"gw_card_price_incl_tax\": \"\",\n          \"gw_card_price_invoiced\": \"\",\n          \"gw_card_price_refunded\": \"\",\n          \"gw_card_tax_amount\": \"\",\n          \"gw_card_tax_invoiced\": \"\",\n          \"gw_card_tax_refunded\": \"\",\n          \"gw_id\": \"\",\n          \"gw_items_base_price\": \"\",\n          \"gw_items_base_price_incl_tax\": \"\",\n          \"gw_items_base_price_invoiced\": \"\",\n          \"gw_items_base_price_refunded\": \"\",\n          \"gw_items_base_tax_amount\": \"\",\n          \"gw_items_base_tax_invoiced\": \"\",\n          \"gw_items_base_tax_refunded\": \"\",\n          \"gw_items_price\": \"\",\n          \"gw_items_price_incl_tax\": \"\",\n          \"gw_items_price_invoiced\": \"\",\n          \"gw_items_price_refunded\": \"\",\n          \"gw_items_tax_amount\": \"\",\n          \"gw_items_tax_invoiced\": \"\",\n          \"gw_items_tax_refunded\": \"\",\n          \"gw_price\": \"\",\n          \"gw_price_incl_tax\": \"\",\n          \"gw_price_invoiced\": \"\",\n          \"gw_price_refunded\": \"\",\n          \"gw_tax_amount\": \"\",\n          \"gw_tax_amount_invoiced\": \"\",\n          \"gw_tax_amount_refunded\": \"\",\n          \"item_applied_taxes\": [\n            {\n              \"applied_taxes\": [\n                {}\n              ],\n              \"associated_item_id\": 0,\n              \"extension_attributes\": {},\n              \"item_id\": 0,\n              \"type\": \"\"\n            }\n          ],\n          \"payment_additional_info\": [\n            {\n              \"key\": \"\",\n              \"value\": \"\"\n            }\n          ],\n          \"reward_currency_amount\": \"\",\n          \"reward_points_balance\": 0,\n          \"shipping_assignments\": [\n            {\n              \"extension_attributes\": {},\n              \"items\": [\n                {\n                  \"additional_data\": \"\",\n                  \"amount_refunded\": \"\",\n                  \"applied_rule_ids\": \"\",\n                  \"base_amount_refunded\": \"\",\n                  \"base_cost\": \"\",\n                  \"base_discount_amount\": \"\",\n                  \"base_discount_invoiced\": \"\",\n                  \"base_discount_refunded\": \"\",\n                  \"base_discount_tax_compensation_amount\": \"\",\n                  \"base_discount_tax_compensation_invoiced\": \"\",\n                  \"base_discount_tax_compensation_refunded\": \"\",\n                  \"base_original_price\": \"\",\n                  \"base_price\": \"\",\n                  \"base_price_incl_tax\": \"\",\n                  \"base_row_invoiced\": \"\",\n                  \"base_row_total\": \"\",\n                  \"base_row_total_incl_tax\": \"\",\n                  \"base_tax_amount\": \"\",\n                  \"base_tax_before_discount\": \"\",\n                  \"base_tax_invoiced\": \"\",\n                  \"base_tax_refunded\": \"\",\n                  \"base_weee_tax_applied_amount\": \"\",\n                  \"base_weee_tax_applied_row_amnt\": \"\",\n                  \"base_weee_tax_disposition\": \"\",\n                  \"base_weee_tax_row_disposition\": \"\",\n                  \"created_at\": \"\",\n                  \"description\": \"\",\n                  \"discount_amount\": \"\",\n                  \"discount_invoiced\": \"\",\n                  \"discount_percent\": \"\",\n                  \"discount_refunded\": \"\",\n                  \"discount_tax_compensation_amount\": \"\",\n                  \"discount_tax_compensation_canceled\": \"\",\n                  \"discount_tax_compensation_invoiced\": \"\",\n                  \"discount_tax_compensation_refunded\": \"\",\n                  \"event_id\": 0,\n                  \"ext_order_item_id\": \"\",\n                  \"extension_attributes\": {\n                    \"gift_message\": {},\n                    \"gw_base_price\": \"\",\n                    \"gw_base_price_invoiced\": \"\",\n                    \"gw_base_price_refunded\": \"\",\n                    \"gw_base_tax_amount\": \"\",\n                    \"gw_base_tax_amount_invoiced\": \"\",\n                    \"gw_base_tax_amount_refunded\": \"\",\n                    \"gw_id\": \"\",\n                    \"gw_price\": \"\",\n                    \"gw_price_invoiced\": \"\",\n                    \"gw_price_refunded\": \"\",\n                    \"gw_tax_amount\": \"\",\n                    \"gw_tax_amount_invoiced\": \"\",\n                    \"gw_tax_amount_refunded\": \"\",\n                    \"invoice_text_codes\": [],\n                    \"tax_codes\": [],\n                    \"vertex_tax_codes\": []\n                  },\n                  \"free_shipping\": 0,\n                  \"gw_base_price\": \"\",\n                  \"gw_base_price_invoiced\": \"\",\n                  \"gw_base_price_refunded\": \"\",\n                  \"gw_base_tax_amount\": \"\",\n                  \"gw_base_tax_amount_invoiced\": \"\",\n                  \"gw_base_tax_amount_refunded\": \"\",\n                  \"gw_id\": 0,\n                  \"gw_price\": \"\",\n                  \"gw_price_invoiced\": \"\",\n                  \"gw_price_refunded\": \"\",\n                  \"gw_tax_amount\": \"\",\n                  \"gw_tax_amount_invoiced\": \"\",\n                  \"gw_tax_amount_refunded\": \"\",\n                  \"is_qty_decimal\": 0,\n                  \"is_virtual\": 0,\n                  \"item_id\": 0,\n                  \"locked_do_invoice\": 0,\n                  \"locked_do_ship\": 0,\n                  \"name\": \"\",\n                  \"no_discount\": 0,\n                  \"order_id\": 0,\n                  \"original_price\": \"\",\n                  \"parent_item\": \"\",\n                  \"parent_item_id\": 0,\n                  \"price\": \"\",\n                  \"price_incl_tax\": \"\",\n                  \"product_id\": 0,\n                  \"product_option\": {\n                    \"extension_attributes\": {\n                      \"bundle_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": 0,\n                          \"option_qty\": 0,\n                          \"option_selections\": []\n                        }\n                      ],\n                      \"configurable_item_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": \"\",\n                          \"option_value\": 0\n                        }\n                      ],\n                      \"custom_options\": [\n                        {\n                          \"extension_attributes\": {\n                            \"file_info\": {\n                              \"base64_encoded_data\": \"\",\n                              \"name\": \"\",\n                              \"type\": \"\"\n                            }\n                          },\n                          \"option_id\": \"\",\n                          \"option_value\": \"\"\n                        }\n                      ],\n                      \"downloadable_option\": {\n                        \"downloadable_links\": []\n                      },\n                      \"giftcard_item_option\": {\n                        \"custom_giftcard_amount\": \"\",\n                        \"extension_attributes\": {},\n                        \"giftcard_amount\": \"\",\n                        \"giftcard_message\": \"\",\n                        \"giftcard_recipient_email\": \"\",\n                        \"giftcard_recipient_name\": \"\",\n                        \"giftcard_sender_email\": \"\",\n                        \"giftcard_sender_name\": \"\"\n                      }\n                    }\n                  },\n                  \"product_type\": \"\",\n                  \"qty_backordered\": \"\",\n                  \"qty_canceled\": \"\",\n                  \"qty_invoiced\": \"\",\n                  \"qty_ordered\": \"\",\n                  \"qty_refunded\": \"\",\n                  \"qty_returned\": \"\",\n                  \"qty_shipped\": \"\",\n                  \"quote_item_id\": 0,\n                  \"row_invoiced\": \"\",\n                  \"row_total\": \"\",\n                  \"row_total_incl_tax\": \"\",\n                  \"row_weight\": \"\",\n                  \"sku\": \"\",\n                  \"store_id\": 0,\n                  \"tax_amount\": \"\",\n                  \"tax_before_discount\": \"\",\n                  \"tax_canceled\": \"\",\n                  \"tax_invoiced\": \"\",\n                  \"tax_percent\": \"\",\n                  \"tax_refunded\": \"\",\n                  \"updated_at\": \"\",\n                  \"weee_tax_applied\": \"\",\n                  \"weee_tax_applied_amount\": \"\",\n                  \"weee_tax_applied_row_amount\": \"\",\n                  \"weee_tax_disposition\": \"\",\n                  \"weee_tax_row_disposition\": \"\",\n                  \"weight\": \"\"\n                }\n              ],\n              \"shipping\": {\n                \"address\": {},\n                \"extension_attributes\": {\n                  \"collection_point\": {\n                    \"city\": \"\",\n                    \"collection_point_id\": \"\",\n                    \"country\": \"\",\n                    \"name\": \"\",\n                    \"postcode\": \"\",\n                    \"recipient_address_id\": 0,\n                    \"region\": \"\",\n                    \"street\": []\n                  },\n                  \"ext_order_id\": \"\",\n                  \"shipping_experience\": {\n                    \"code\": \"\",\n                    \"cost\": \"\",\n                    \"label\": \"\"\n                  }\n                },\n                \"method\": \"\",\n                \"total\": {\n                  \"base_shipping_amount\": \"\",\n                  \"base_shipping_canceled\": \"\",\n                  \"base_shipping_discount_amount\": \"\",\n                  \"base_shipping_discount_tax_compensation_amnt\": \"\",\n                  \"base_shipping_incl_tax\": \"\",\n                  \"base_shipping_invoiced\": \"\",\n                  \"base_shipping_refunded\": \"\",\n                  \"base_shipping_tax_amount\": \"\",\n                  \"base_shipping_tax_refunded\": \"\",\n                  \"extension_attributes\": {},\n                  \"shipping_amount\": \"\",\n                  \"shipping_canceled\": \"\",\n                  \"shipping_discount_amount\": \"\",\n                  \"shipping_discount_tax_compensation_amount\": \"\",\n                  \"shipping_incl_tax\": \"\",\n                  \"shipping_invoiced\": \"\",\n                  \"shipping_refunded\": \"\",\n                  \"shipping_tax_amount\": \"\",\n                  \"shipping_tax_refunded\": \"\"\n                }\n              },\n              \"stock_id\": 0\n            }\n          ]\n        },\n        \"forced_shipment_with_invoice\": 0,\n        \"global_currency_code\": \"\",\n        \"grand_total\": \"\",\n        \"hold_before_state\": \"\",\n        \"hold_before_status\": \"\",\n        \"increment_id\": \"\",\n        \"is_virtual\": 0,\n        \"items\": [\n          {}\n        ],\n        \"order_currency_code\": \"\",\n        \"original_increment_id\": \"\",\n        \"payment\": {\n          \"account_status\": \"\",\n          \"additional_data\": \"\",\n          \"additional_information\": [],\n          \"address_status\": \"\",\n          \"amount_authorized\": \"\",\n          \"amount_canceled\": \"\",\n          \"amount_ordered\": \"\",\n          \"amount_paid\": \"\",\n          \"amount_refunded\": \"\",\n          \"anet_trans_method\": \"\",\n          \"base_amount_authorized\": \"\",\n          \"base_amount_canceled\": \"\",\n          \"base_amount_ordered\": \"\",\n          \"base_amount_paid\": \"\",\n          \"base_amount_paid_online\": \"\",\n          \"base_amount_refunded\": \"\",\n          \"base_amount_refunded_online\": \"\",\n          \"base_shipping_amount\": \"\",\n          \"base_shipping_captured\": \"\",\n          \"base_shipping_refunded\": \"\",\n          \"cc_approval\": \"\",\n          \"cc_avs_status\": \"\",\n          \"cc_cid_status\": \"\",\n          \"cc_debug_request_body\": \"\",\n          \"cc_debug_response_body\": \"\",\n          \"cc_debug_response_serialized\": \"\",\n          \"cc_exp_month\": \"\",\n          \"cc_exp_year\": \"\",\n          \"cc_last4\": \"\",\n          \"cc_number_enc\": \"\",\n          \"cc_owner\": \"\",\n          \"cc_secure_verify\": \"\",\n          \"cc_ss_issue\": \"\",\n          \"cc_ss_start_month\": \"\",\n          \"cc_ss_start_year\": \"\",\n          \"cc_status\": \"\",\n          \"cc_status_description\": \"\",\n          \"cc_trans_id\": \"\",\n          \"cc_type\": \"\",\n          \"echeck_account_name\": \"\",\n          \"echeck_account_type\": \"\",\n          \"echeck_bank_name\": \"\",\n          \"echeck_routing_number\": \"\",\n          \"echeck_type\": \"\",\n          \"entity_id\": 0,\n          \"extension_attributes\": {\n            \"vault_payment_token\": {\n              \"created_at\": \"\",\n              \"customer_id\": 0,\n              \"entity_id\": 0,\n              \"expires_at\": \"\",\n              \"gateway_token\": \"\",\n              \"is_active\": false,\n              \"is_visible\": false,\n              \"payment_method_code\": \"\",\n              \"public_hash\": \"\",\n              \"token_details\": \"\",\n              \"type\": \"\"\n            }\n          },\n          \"last_trans_id\": \"\",\n          \"method\": \"\",\n          \"parent_id\": 0,\n          \"po_number\": \"\",\n          \"protection_eligibility\": \"\",\n          \"quote_payment_id\": 0,\n          \"shipping_amount\": \"\",\n          \"shipping_captured\": \"\",\n          \"shipping_refunded\": \"\"\n        },\n        \"payment_auth_expiration\": 0,\n        \"payment_authorization_amount\": \"\",\n        \"protect_code\": \"\",\n        \"quote_address_id\": 0,\n        \"quote_id\": 0,\n        \"relation_child_id\": \"\",\n        \"relation_child_real_id\": \"\",\n        \"relation_parent_id\": \"\",\n        \"relation_parent_real_id\": \"\",\n        \"remote_ip\": \"\",\n        \"shipping_amount\": \"\",\n        \"shipping_canceled\": \"\",\n        \"shipping_description\": \"\",\n        \"shipping_discount_amount\": \"\",\n        \"shipping_discount_tax_compensation_amount\": \"\",\n        \"shipping_incl_tax\": \"\",\n        \"shipping_invoiced\": \"\",\n        \"shipping_refunded\": \"\",\n        \"shipping_tax_amount\": \"\",\n        \"shipping_tax_refunded\": \"\",\n        \"state\": \"\",\n        \"status\": \"\",\n        \"status_histories\": [\n          {\n            \"comment\": \"\",\n            \"created_at\": \"\",\n            \"entity_id\": 0,\n            \"entity_name\": \"\",\n            \"extension_attributes\": {},\n            \"is_customer_notified\": 0,\n            \"is_visible_on_front\": 0,\n            \"parent_id\": 0,\n            \"status\": \"\"\n          }\n        ],\n        \"store_currency_code\": \"\",\n        \"store_id\": 0,\n        \"store_name\": \"\",\n        \"store_to_base_rate\": \"\",\n        \"store_to_order_rate\": \"\",\n        \"subtotal\": \"\",\n        \"subtotal_canceled\": \"\",\n        \"subtotal_incl_tax\": \"\",\n        \"subtotal_invoiced\": \"\",\n        \"subtotal_refunded\": \"\",\n        \"tax_amount\": \"\",\n        \"tax_canceled\": \"\",\n        \"tax_invoiced\": \"\",\n        \"tax_refunded\": \"\",\n        \"total_canceled\": \"\",\n        \"total_due\": \"\",\n        \"total_invoiced\": \"\",\n        \"total_item_count\": 0,\n        \"total_offline_refunded\": \"\",\n        \"total_online_refunded\": \"\",\n        \"total_paid\": \"\",\n        \"total_qty_ordered\": \"\",\n        \"total_refunded\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\",\n        \"x_forwarded_for\": \"\"\n      },\n      \"vertex_tax_calculation_shipping_address\": {}\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"is_used_for_refund\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"total_qty\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/invoices/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'entity' => [
        'base_currency_code' => '',
        'base_discount_amount' => '',
        'base_discount_tax_compensation_amount' => '',
        'base_grand_total' => '',
        'base_shipping_amount' => '',
        'base_shipping_discount_tax_compensation_amnt' => '',
        'base_shipping_incl_tax' => '',
        'base_shipping_tax_amount' => '',
        'base_subtotal' => '',
        'base_subtotal_incl_tax' => '',
        'base_tax_amount' => '',
        'base_to_global_rate' => '',
        'base_to_order_rate' => '',
        'base_total_refunded' => '',
        'billing_address_id' => 0,
        'can_void_flag' => 0,
        'comments' => [
                [
                                'comment' => '',
                                'created_at' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'is_customer_notified' => 0,
                                'is_visible_on_front' => 0,
                                'parent_id' => 0
                ]
        ],
        'created_at' => '',
        'discount_amount' => '',
        'discount_description' => '',
        'discount_tax_compensation_amount' => '',
        'email_sent' => 0,
        'entity_id' => 0,
        'extension_attributes' => [
                'base_customer_balance_amount' => '',
                'base_gift_cards_amount' => '',
                'customer_balance_amount' => '',
                'gift_cards_amount' => '',
                'gw_base_price' => '',
                'gw_base_tax_amount' => '',
                'gw_card_base_price' => '',
                'gw_card_base_tax_amount' => '',
                'gw_card_price' => '',
                'gw_card_tax_amount' => '',
                'gw_items_base_price' => '',
                'gw_items_base_tax_amount' => '',
                'gw_items_price' => '',
                'gw_items_tax_amount' => '',
                'gw_price' => '',
                'gw_tax_amount' => '',
                'vertex_tax_calculation_billing_address' => [
                                'address_type' => '',
                                'city' => '',
                                'company' => '',
                                'country_id' => '',
                                'customer_address_id' => 0,
                                'customer_id' => 0,
                                'email' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                'checkout_fields' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'attribute_code' => '',
                                                                                                                                                                                                                                                                'value' => ''
                                                                                                                                ]
                                                                ]
                                ],
                                'fax' => '',
                                'firstname' => '',
                                'lastname' => '',
                                'middlename' => '',
                                'parent_id' => 0,
                                'postcode' => '',
                                'prefix' => '',
                                'region' => '',
                                'region_code' => '',
                                'region_id' => 0,
                                'street' => [
                                                                
                                ],
                                'suffix' => '',
                                'telephone' => '',
                                'vat_id' => '',
                                'vat_is_valid' => 0,
                                'vat_request_date' => '',
                                'vat_request_id' => '',
                                'vat_request_success' => 0
                ],
                'vertex_tax_calculation_order' => [
                                'adjustment_negative' => '',
                                'adjustment_positive' => '',
                                'applied_rule_ids' => '',
                                'base_adjustment_negative' => '',
                                'base_adjustment_positive' => '',
                                'base_currency_code' => '',
                                'base_discount_amount' => '',
                                'base_discount_canceled' => '',
                                'base_discount_invoiced' => '',
                                'base_discount_refunded' => '',
                                'base_discount_tax_compensation_amount' => '',
                                'base_discount_tax_compensation_invoiced' => '',
                                'base_discount_tax_compensation_refunded' => '',
                                'base_grand_total' => '',
                                'base_shipping_amount' => '',
                                'base_shipping_canceled' => '',
                                'base_shipping_discount_amount' => '',
                                'base_shipping_discount_tax_compensation_amnt' => '',
                                'base_shipping_incl_tax' => '',
                                'base_shipping_invoiced' => '',
                                'base_shipping_refunded' => '',
                                'base_shipping_tax_amount' => '',
                                'base_shipping_tax_refunded' => '',
                                'base_subtotal' => '',
                                'base_subtotal_canceled' => '',
                                'base_subtotal_incl_tax' => '',
                                'base_subtotal_invoiced' => '',
                                'base_subtotal_refunded' => '',
                                'base_tax_amount' => '',
                                'base_tax_canceled' => '',
                                'base_tax_invoiced' => '',
                                'base_tax_refunded' => '',
                                'base_to_global_rate' => '',
                                'base_to_order_rate' => '',
                                'base_total_canceled' => '',
                                'base_total_due' => '',
                                'base_total_invoiced' => '',
                                'base_total_invoiced_cost' => '',
                                'base_total_offline_refunded' => '',
                                'base_total_online_refunded' => '',
                                'base_total_paid' => '',
                                'base_total_qty_ordered' => '',
                                'base_total_refunded' => '',
                                'billing_address' => [
                                                                
                                ],
                                'billing_address_id' => 0,
                                'can_ship_partially' => 0,
                                'can_ship_partially_item' => 0,
                                'coupon_code' => '',
                                'created_at' => '',
                                'customer_dob' => '',
                                'customer_email' => '',
                                'customer_firstname' => '',
                                'customer_gender' => 0,
                                'customer_group_id' => 0,
                                'customer_id' => 0,
                                'customer_is_guest' => 0,
                                'customer_lastname' => '',
                                'customer_middlename' => '',
                                'customer_note' => '',
                                'customer_note_notify' => 0,
                                'customer_prefix' => '',
                                'customer_suffix' => '',
                                'customer_taxvat' => '',
                                'discount_amount' => '',
                                'discount_canceled' => '',
                                'discount_description' => '',
                                'discount_invoiced' => '',
                                'discount_refunded' => '',
                                'discount_tax_compensation_amount' => '',
                                'discount_tax_compensation_invoiced' => '',
                                'discount_tax_compensation_refunded' => '',
                                'edit_increment' => 0,
                                'email_sent' => 0,
                                'entity_id' => 0,
                                'ext_customer_id' => '',
                                'ext_order_id' => '',
                                'extension_attributes' => [
                                                                'amazon_order_reference_id' => '',
                                                                'applied_taxes' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'amount' => '',
                                                                                                                                                                                                                                                                'base_amount' => '',
                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'rates' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'percent' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'title' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'percent' => '',
                                                                                                                                                                                                                                                                'title' => ''
                                                                                                                                ]
                                                                ],
                                                                'base_customer_balance_amount' => '',
                                                                'base_customer_balance_invoiced' => '',
                                                                'base_customer_balance_refunded' => '',
                                                                'base_customer_balance_total_refunded' => '',
                                                                'base_gift_cards_amount' => '',
                                                                'base_gift_cards_invoiced' => '',
                                                                'base_gift_cards_refunded' => '',
                                                                'base_reward_currency_amount' => '',
                                                                'company_order_attributes' => [
                                                                                                                                'company_id' => 0,
                                                                                                                                'company_name' => '',
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'order_id' => 0
                                                                ],
                                                                'converting_from_quote' => null,
                                                                'customer_balance_amount' => '',
                                                                'customer_balance_invoiced' => '',
                                                                'customer_balance_refunded' => '',
                                                                'customer_balance_total_refunded' => '',
                                                                'gift_cards' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'amount' => '',
                                                                                                                                                                                                                                                                'base_amount' => '',
                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                'id' => 0
                                                                                                                                ]
                                                                ],
                                                                'gift_cards_amount' => '',
                                                                'gift_cards_invoiced' => '',
                                                                'gift_cards_refunded' => '',
                                                                'gift_message' => [
                                                                                                                                'customer_id' => 0,
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'entity_id' => '',
                                                                                                                                                                                                                                                                'entity_type' => '',
                                                                                                                                                                                                                                                                'wrapping_add_printed_card' => null,
                                                                                                                                                                                                                                                                'wrapping_allow_gift_receipt' => null,
                                                                                                                                                                                                                                                                'wrapping_id' => 0
                                                                                                                                ],
                                                                                                                                'gift_message_id' => 0,
                                                                                                                                'message' => '',
                                                                                                                                'recipient' => '',
                                                                                                                                'sender' => ''
                                                                ],
                                                                'gw_add_card' => '',
                                                                'gw_allow_gift_receipt' => '',
                                                                'gw_base_price' => '',
                                                                'gw_base_price_incl_tax' => '',
                                                                'gw_base_price_invoiced' => '',
                                                                'gw_base_price_refunded' => '',
                                                                'gw_base_tax_amount' => '',
                                                                'gw_base_tax_amount_invoiced' => '',
                                                                'gw_base_tax_amount_refunded' => '',
                                                                'gw_card_base_price' => '',
                                                                'gw_card_base_price_incl_tax' => '',
                                                                'gw_card_base_price_invoiced' => '',
                                                                'gw_card_base_price_refunded' => '',
                                                                'gw_card_base_tax_amount' => '',
                                                                'gw_card_base_tax_invoiced' => '',
                                                                'gw_card_base_tax_refunded' => '',
                                                                'gw_card_price' => '',
                                                                'gw_card_price_incl_tax' => '',
                                                                'gw_card_price_invoiced' => '',
                                                                'gw_card_price_refunded' => '',
                                                                'gw_card_tax_amount' => '',
                                                                'gw_card_tax_invoiced' => '',
                                                                'gw_card_tax_refunded' => '',
                                                                'gw_id' => '',
                                                                'gw_items_base_price' => '',
                                                                'gw_items_base_price_incl_tax' => '',
                                                                'gw_items_base_price_invoiced' => '',
                                                                'gw_items_base_price_refunded' => '',
                                                                'gw_items_base_tax_amount' => '',
                                                                'gw_items_base_tax_invoiced' => '',
                                                                'gw_items_base_tax_refunded' => '',
                                                                'gw_items_price' => '',
                                                                'gw_items_price_incl_tax' => '',
                                                                'gw_items_price_invoiced' => '',
                                                                'gw_items_price_refunded' => '',
                                                                'gw_items_tax_amount' => '',
                                                                'gw_items_tax_invoiced' => '',
                                                                'gw_items_tax_refunded' => '',
                                                                'gw_price' => '',
                                                                'gw_price_incl_tax' => '',
                                                                'gw_price_invoiced' => '',
                                                                'gw_price_refunded' => '',
                                                                'gw_tax_amount' => '',
                                                                'gw_tax_amount_invoiced' => '',
                                                                'gw_tax_amount_refunded' => '',
                                                                'item_applied_taxes' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'applied_taxes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'associated_item_id' => 0,
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'item_id' => 0,
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ]
                                                                ],
                                                                'payment_additional_info' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'key' => '',
                                                                                                                                                                                                                                                                'value' => ''
                                                                                                                                ]
                                                                ],
                                                                'reward_currency_amount' => '',
                                                                'reward_points_balance' => 0,
                                                                'shipping_assignments' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'items' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'additional_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'applied_rule_ids' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_cost' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_tax_compensation_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_tax_compensation_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_tax_compensation_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_original_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_price_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_row_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_row_total' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_row_total_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_tax_before_discount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_tax_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_tax_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_weee_tax_applied_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_weee_tax_applied_row_amnt' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_weee_tax_disposition' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_weee_tax_row_disposition' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'created_at' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'description' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_percent' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_tax_compensation_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_tax_compensation_canceled' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_tax_compensation_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_tax_compensation_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'event_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'ext_order_item_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gift_message' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'invoice_text_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'vertex_tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'free_shipping' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'is_qty_decimal' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'is_virtual' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'item_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'locked_do_invoice' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'locked_do_ship' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'no_discount' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'order_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'parent_item' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'parent_item_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'price_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'product_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'product_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'bundle_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_qty' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'configurable_item_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_links' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_item_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_message' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_name' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'product_type' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_backordered' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_canceled' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_ordered' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_returned' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_shipped' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'quote_item_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'row_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'row_total' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'row_total_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'row_weight' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'sku' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'store_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_before_discount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_canceled' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_percent' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'updated_at' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weee_tax_applied' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weee_tax_applied_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weee_tax_applied_row_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weee_tax_disposition' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weee_tax_row_disposition' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weight' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'shipping' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'address' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'collection_point' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'city' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'collection_point_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'country' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'postcode' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'recipient_address_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'region' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'street' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'ext_order_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_experience' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'cost' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'label' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'method' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'total' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_canceled' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_discount_tax_compensation_amnt' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_tax_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_canceled' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_discount_tax_compensation_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_tax_refunded' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'stock_id' => 0
                                                                                                                                ]
                                                                ]
                                ],
                                'forced_shipment_with_invoice' => 0,
                                'global_currency_code' => '',
                                'grand_total' => '',
                                'hold_before_state' => '',
                                'hold_before_status' => '',
                                'increment_id' => '',
                                'is_virtual' => 0,
                                'items' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'order_currency_code' => '',
                                'original_increment_id' => '',
                                'payment' => [
                                                                'account_status' => '',
                                                                'additional_data' => '',
                                                                'additional_information' => [
                                                                                                                                
                                                                ],
                                                                'address_status' => '',
                                                                'amount_authorized' => '',
                                                                'amount_canceled' => '',
                                                                'amount_ordered' => '',
                                                                'amount_paid' => '',
                                                                'amount_refunded' => '',
                                                                'anet_trans_method' => '',
                                                                'base_amount_authorized' => '',
                                                                'base_amount_canceled' => '',
                                                                'base_amount_ordered' => '',
                                                                'base_amount_paid' => '',
                                                                'base_amount_paid_online' => '',
                                                                'base_amount_refunded' => '',
                                                                'base_amount_refunded_online' => '',
                                                                'base_shipping_amount' => '',
                                                                'base_shipping_captured' => '',
                                                                'base_shipping_refunded' => '',
                                                                'cc_approval' => '',
                                                                'cc_avs_status' => '',
                                                                'cc_cid_status' => '',
                                                                'cc_debug_request_body' => '',
                                                                'cc_debug_response_body' => '',
                                                                'cc_debug_response_serialized' => '',
                                                                'cc_exp_month' => '',
                                                                'cc_exp_year' => '',
                                                                'cc_last4' => '',
                                                                'cc_number_enc' => '',
                                                                'cc_owner' => '',
                                                                'cc_secure_verify' => '',
                                                                'cc_ss_issue' => '',
                                                                'cc_ss_start_month' => '',
                                                                'cc_ss_start_year' => '',
                                                                'cc_status' => '',
                                                                'cc_status_description' => '',
                                                                'cc_trans_id' => '',
                                                                'cc_type' => '',
                                                                'echeck_account_name' => '',
                                                                'echeck_account_type' => '',
                                                                'echeck_bank_name' => '',
                                                                'echeck_routing_number' => '',
                                                                'echeck_type' => '',
                                                                'entity_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                'vault_payment_token' => [
                                                                                                                                                                                                                                                                'created_at' => '',
                                                                                                                                                                                                                                                                'customer_id' => 0,
                                                                                                                                                                                                                                                                'entity_id' => 0,
                                                                                                                                                                                                                                                                'expires_at' => '',
                                                                                                                                                                                                                                                                'gateway_token' => '',
                                                                                                                                                                                                                                                                'is_active' => null,
                                                                                                                                                                                                                                                                'is_visible' => null,
                                                                                                                                                                                                                                                                'payment_method_code' => '',
                                                                                                                                                                                                                                                                'public_hash' => '',
                                                                                                                                                                                                                                                                'token_details' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ]
                                                                ],
                                                                'last_trans_id' => '',
                                                                'method' => '',
                                                                'parent_id' => 0,
                                                                'po_number' => '',
                                                                'protection_eligibility' => '',
                                                                'quote_payment_id' => 0,
                                                                'shipping_amount' => '',
                                                                'shipping_captured' => '',
                                                                'shipping_refunded' => ''
                                ],
                                'payment_auth_expiration' => 0,
                                'payment_authorization_amount' => '',
                                'protect_code' => '',
                                'quote_address_id' => 0,
                                'quote_id' => 0,
                                'relation_child_id' => '',
                                'relation_child_real_id' => '',
                                'relation_parent_id' => '',
                                'relation_parent_real_id' => '',
                                'remote_ip' => '',
                                'shipping_amount' => '',
                                'shipping_canceled' => '',
                                'shipping_description' => '',
                                'shipping_discount_amount' => '',
                                'shipping_discount_tax_compensation_amount' => '',
                                'shipping_incl_tax' => '',
                                'shipping_invoiced' => '',
                                'shipping_refunded' => '',
                                'shipping_tax_amount' => '',
                                'shipping_tax_refunded' => '',
                                'state' => '',
                                'status' => '',
                                'status_histories' => [
                                                                [
                                                                                                                                'comment' => '',
                                                                                                                                'created_at' => '',
                                                                                                                                'entity_id' => 0,
                                                                                                                                'entity_name' => '',
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'is_customer_notified' => 0,
                                                                                                                                'is_visible_on_front' => 0,
                                                                                                                                'parent_id' => 0,
                                                                                                                                'status' => ''
                                                                ]
                                ],
                                'store_currency_code' => '',
                                'store_id' => 0,
                                'store_name' => '',
                                'store_to_base_rate' => '',
                                'store_to_order_rate' => '',
                                'subtotal' => '',
                                'subtotal_canceled' => '',
                                'subtotal_incl_tax' => '',
                                'subtotal_invoiced' => '',
                                'subtotal_refunded' => '',
                                'tax_amount' => '',
                                'tax_canceled' => '',
                                'tax_invoiced' => '',
                                'tax_refunded' => '',
                                'total_canceled' => '',
                                'total_due' => '',
                                'total_invoiced' => '',
                                'total_item_count' => 0,
                                'total_offline_refunded' => '',
                                'total_online_refunded' => '',
                                'total_paid' => '',
                                'total_qty_ordered' => '',
                                'total_refunded' => '',
                                'updated_at' => '',
                                'weight' => '',
                                'x_forwarded_for' => ''
                ],
                'vertex_tax_calculation_shipping_address' => [
                                
                ]
        ],
        'global_currency_code' => '',
        'grand_total' => '',
        'increment_id' => '',
        'is_used_for_refund' => 0,
        'items' => [
                [
                                'additional_data' => '',
                                'base_cost' => '',
                                'base_discount_amount' => '',
                                'base_discount_tax_compensation_amount' => '',
                                'base_price' => '',
                                'base_price_incl_tax' => '',
                                'base_row_total' => '',
                                'base_row_total_incl_tax' => '',
                                'base_tax_amount' => '',
                                'description' => '',
                                'discount_amount' => '',
                                'discount_tax_compensation_amount' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                'invoice_text_codes' => [
                                                                                                                                
                                                                ],
                                                                'tax_codes' => [
                                                                                                                                
                                                                ],
                                                                'vertex_tax_codes' => [
                                                                                                                                
                                                                ]
                                ],
                                'name' => '',
                                'order_item_id' => 0,
                                'parent_id' => 0,
                                'price' => '',
                                'price_incl_tax' => '',
                                'product_id' => 0,
                                'qty' => '',
                                'row_total' => '',
                                'row_total_incl_tax' => '',
                                'sku' => '',
                                'tax_amount' => ''
                ]
        ],
        'order_currency_code' => '',
        'order_id' => 0,
        'shipping_address_id' => 0,
        'shipping_amount' => '',
        'shipping_discount_tax_compensation_amount' => '',
        'shipping_incl_tax' => '',
        'shipping_tax_amount' => '',
        'state' => 0,
        'store_currency_code' => '',
        'store_id' => 0,
        'store_to_base_rate' => '',
        'store_to_order_rate' => '',
        'subtotal' => '',
        'subtotal_incl_tax' => '',
        'tax_amount' => '',
        'total_qty' => '',
        'transaction_id' => '',
        'updated_at' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/invoices/', [
  'body' => '{
  "entity": {
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_refunded": "",
    "billing_address_id": 0,
    "can_void_flag": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": "",
      "vertex_tax_calculation_billing_address": {
        "address_type": "",
        "city": "",
        "company": "",
        "country_id": "",
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "entity_id": 0,
        "extension_attributes": {
          "checkout_fields": [
            {
              "attribute_code": "",
              "value": ""
            }
          ]
        },
        "fax": "",
        "firstname": "",
        "lastname": "",
        "middlename": "",
        "parent_id": 0,
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": "",
        "vat_is_valid": 0,
        "vat_request_date": "",
        "vat_request_id": "",
        "vat_request_success": 0
      },
      "vertex_tax_calculation_order": {
        "adjustment_negative": "",
        "adjustment_positive": "",
        "applied_rule_ids": "",
        "base_adjustment_negative": "",
        "base_adjustment_positive": "",
        "base_currency_code": "",
        "base_discount_amount": "",
        "base_discount_canceled": "",
        "base_discount_invoiced": "",
        "base_discount_refunded": "",
        "base_discount_tax_compensation_amount": "",
        "base_discount_tax_compensation_invoiced": "",
        "base_discount_tax_compensation_refunded": "",
        "base_grand_total": "",
        "base_shipping_amount": "",
        "base_shipping_canceled": "",
        "base_shipping_discount_amount": "",
        "base_shipping_discount_tax_compensation_amnt": "",
        "base_shipping_incl_tax": "",
        "base_shipping_invoiced": "",
        "base_shipping_refunded": "",
        "base_shipping_tax_amount": "",
        "base_shipping_tax_refunded": "",
        "base_subtotal": "",
        "base_subtotal_canceled": "",
        "base_subtotal_incl_tax": "",
        "base_subtotal_invoiced": "",
        "base_subtotal_refunded": "",
        "base_tax_amount": "",
        "base_tax_canceled": "",
        "base_tax_invoiced": "",
        "base_tax_refunded": "",
        "base_to_global_rate": "",
        "base_to_order_rate": "",
        "base_total_canceled": "",
        "base_total_due": "",
        "base_total_invoiced": "",
        "base_total_invoiced_cost": "",
        "base_total_offline_refunded": "",
        "base_total_online_refunded": "",
        "base_total_paid": "",
        "base_total_qty_ordered": "",
        "base_total_refunded": "",
        "billing_address": {},
        "billing_address_id": 0,
        "can_ship_partially": 0,
        "can_ship_partially_item": 0,
        "coupon_code": "",
        "created_at": "",
        "customer_dob": "",
        "customer_email": "",
        "customer_firstname": "",
        "customer_gender": 0,
        "customer_group_id": 0,
        "customer_id": 0,
        "customer_is_guest": 0,
        "customer_lastname": "",
        "customer_middlename": "",
        "customer_note": "",
        "customer_note_notify": 0,
        "customer_prefix": "",
        "customer_suffix": "",
        "customer_taxvat": "",
        "discount_amount": "",
        "discount_canceled": "",
        "discount_description": "",
        "discount_invoiced": "",
        "discount_refunded": "",
        "discount_tax_compensation_amount": "",
        "discount_tax_compensation_invoiced": "",
        "discount_tax_compensation_refunded": "",
        "edit_increment": 0,
        "email_sent": 0,
        "entity_id": 0,
        "ext_customer_id": "",
        "ext_order_id": "",
        "extension_attributes": {
          "amazon_order_reference_id": "",
          "applied_taxes": [
            {
              "amount": "",
              "base_amount": "",
              "code": "",
              "extension_attributes": {
                "rates": [
                  {
                    "code": "",
                    "extension_attributes": {},
                    "percent": "",
                    "title": ""
                  }
                ]
              },
              "percent": "",
              "title": ""
            }
          ],
          "base_customer_balance_amount": "",
          "base_customer_balance_invoiced": "",
          "base_customer_balance_refunded": "",
          "base_customer_balance_total_refunded": "",
          "base_gift_cards_amount": "",
          "base_gift_cards_invoiced": "",
          "base_gift_cards_refunded": "",
          "base_reward_currency_amount": "",
          "company_order_attributes": {
            "company_id": 0,
            "company_name": "",
            "extension_attributes": {},
            "order_id": 0
          },
          "converting_from_quote": false,
          "customer_balance_amount": "",
          "customer_balance_invoiced": "",
          "customer_balance_refunded": "",
          "customer_balance_total_refunded": "",
          "gift_cards": [
            {
              "amount": "",
              "base_amount": "",
              "code": "",
              "id": 0
            }
          ],
          "gift_cards_amount": "",
          "gift_cards_invoiced": "",
          "gift_cards_refunded": "",
          "gift_message": {
            "customer_id": 0,
            "extension_attributes": {
              "entity_id": "",
              "entity_type": "",
              "wrapping_add_printed_card": false,
              "wrapping_allow_gift_receipt": false,
              "wrapping_id": 0
            },
            "gift_message_id": 0,
            "message": "",
            "recipient": "",
            "sender": ""
          },
          "gw_add_card": "",
          "gw_allow_gift_receipt": "",
          "gw_base_price": "",
          "gw_base_price_incl_tax": "",
          "gw_base_price_invoiced": "",
          "gw_base_price_refunded": "",
          "gw_base_tax_amount": "",
          "gw_base_tax_amount_invoiced": "",
          "gw_base_tax_amount_refunded": "",
          "gw_card_base_price": "",
          "gw_card_base_price_incl_tax": "",
          "gw_card_base_price_invoiced": "",
          "gw_card_base_price_refunded": "",
          "gw_card_base_tax_amount": "",
          "gw_card_base_tax_invoiced": "",
          "gw_card_base_tax_refunded": "",
          "gw_card_price": "",
          "gw_card_price_incl_tax": "",
          "gw_card_price_invoiced": "",
          "gw_card_price_refunded": "",
          "gw_card_tax_amount": "",
          "gw_card_tax_invoiced": "",
          "gw_card_tax_refunded": "",
          "gw_id": "",
          "gw_items_base_price": "",
          "gw_items_base_price_incl_tax": "",
          "gw_items_base_price_invoiced": "",
          "gw_items_base_price_refunded": "",
          "gw_items_base_tax_amount": "",
          "gw_items_base_tax_invoiced": "",
          "gw_items_base_tax_refunded": "",
          "gw_items_price": "",
          "gw_items_price_incl_tax": "",
          "gw_items_price_invoiced": "",
          "gw_items_price_refunded": "",
          "gw_items_tax_amount": "",
          "gw_items_tax_invoiced": "",
          "gw_items_tax_refunded": "",
          "gw_price": "",
          "gw_price_incl_tax": "",
          "gw_price_invoiced": "",
          "gw_price_refunded": "",
          "gw_tax_amount": "",
          "gw_tax_amount_invoiced": "",
          "gw_tax_amount_refunded": "",
          "item_applied_taxes": [
            {
              "applied_taxes": [
                {}
              ],
              "associated_item_id": 0,
              "extension_attributes": {},
              "item_id": 0,
              "type": ""
            }
          ],
          "payment_additional_info": [
            {
              "key": "",
              "value": ""
            }
          ],
          "reward_currency_amount": "",
          "reward_points_balance": 0,
          "shipping_assignments": [
            {
              "extension_attributes": {},
              "items": [
                {
                  "additional_data": "",
                  "amount_refunded": "",
                  "applied_rule_ids": "",
                  "base_amount_refunded": "",
                  "base_cost": "",
                  "base_discount_amount": "",
                  "base_discount_invoiced": "",
                  "base_discount_refunded": "",
                  "base_discount_tax_compensation_amount": "",
                  "base_discount_tax_compensation_invoiced": "",
                  "base_discount_tax_compensation_refunded": "",
                  "base_original_price": "",
                  "base_price": "",
                  "base_price_incl_tax": "",
                  "base_row_invoiced": "",
                  "base_row_total": "",
                  "base_row_total_incl_tax": "",
                  "base_tax_amount": "",
                  "base_tax_before_discount": "",
                  "base_tax_invoiced": "",
                  "base_tax_refunded": "",
                  "base_weee_tax_applied_amount": "",
                  "base_weee_tax_applied_row_amnt": "",
                  "base_weee_tax_disposition": "",
                  "base_weee_tax_row_disposition": "",
                  "created_at": "",
                  "description": "",
                  "discount_amount": "",
                  "discount_invoiced": "",
                  "discount_percent": "",
                  "discount_refunded": "",
                  "discount_tax_compensation_amount": "",
                  "discount_tax_compensation_canceled": "",
                  "discount_tax_compensation_invoiced": "",
                  "discount_tax_compensation_refunded": "",
                  "event_id": 0,
                  "ext_order_item_id": "",
                  "extension_attributes": {
                    "gift_message": {},
                    "gw_base_price": "",
                    "gw_base_price_invoiced": "",
                    "gw_base_price_refunded": "",
                    "gw_base_tax_amount": "",
                    "gw_base_tax_amount_invoiced": "",
                    "gw_base_tax_amount_refunded": "",
                    "gw_id": "",
                    "gw_price": "",
                    "gw_price_invoiced": "",
                    "gw_price_refunded": "",
                    "gw_tax_amount": "",
                    "gw_tax_amount_invoiced": "",
                    "gw_tax_amount_refunded": "",
                    "invoice_text_codes": [],
                    "tax_codes": [],
                    "vertex_tax_codes": []
                  },
                  "free_shipping": 0,
                  "gw_base_price": "",
                  "gw_base_price_invoiced": "",
                  "gw_base_price_refunded": "",
                  "gw_base_tax_amount": "",
                  "gw_base_tax_amount_invoiced": "",
                  "gw_base_tax_amount_refunded": "",
                  "gw_id": 0,
                  "gw_price": "",
                  "gw_price_invoiced": "",
                  "gw_price_refunded": "",
                  "gw_tax_amount": "",
                  "gw_tax_amount_invoiced": "",
                  "gw_tax_amount_refunded": "",
                  "is_qty_decimal": 0,
                  "is_virtual": 0,
                  "item_id": 0,
                  "locked_do_invoice": 0,
                  "locked_do_ship": 0,
                  "name": "",
                  "no_discount": 0,
                  "order_id": 0,
                  "original_price": "",
                  "parent_item": "",
                  "parent_item_id": 0,
                  "price": "",
                  "price_incl_tax": "",
                  "product_id": 0,
                  "product_option": {
                    "extension_attributes": {
                      "bundle_options": [
                        {
                          "extension_attributes": {},
                          "option_id": 0,
                          "option_qty": 0,
                          "option_selections": []
                        }
                      ],
                      "configurable_item_options": [
                        {
                          "extension_attributes": {},
                          "option_id": "",
                          "option_value": 0
                        }
                      ],
                      "custom_options": [
                        {
                          "extension_attributes": {
                            "file_info": {
                              "base64_encoded_data": "",
                              "name": "",
                              "type": ""
                            }
                          },
                          "option_id": "",
                          "option_value": ""
                        }
                      ],
                      "downloadable_option": {
                        "downloadable_links": []
                      },
                      "giftcard_item_option": {
                        "custom_giftcard_amount": "",
                        "extension_attributes": {},
                        "giftcard_amount": "",
                        "giftcard_message": "",
                        "giftcard_recipient_email": "",
                        "giftcard_recipient_name": "",
                        "giftcard_sender_email": "",
                        "giftcard_sender_name": ""
                      }
                    }
                  },
                  "product_type": "",
                  "qty_backordered": "",
                  "qty_canceled": "",
                  "qty_invoiced": "",
                  "qty_ordered": "",
                  "qty_refunded": "",
                  "qty_returned": "",
                  "qty_shipped": "",
                  "quote_item_id": 0,
                  "row_invoiced": "",
                  "row_total": "",
                  "row_total_incl_tax": "",
                  "row_weight": "",
                  "sku": "",
                  "store_id": 0,
                  "tax_amount": "",
                  "tax_before_discount": "",
                  "tax_canceled": "",
                  "tax_invoiced": "",
                  "tax_percent": "",
                  "tax_refunded": "",
                  "updated_at": "",
                  "weee_tax_applied": "",
                  "weee_tax_applied_amount": "",
                  "weee_tax_applied_row_amount": "",
                  "weee_tax_disposition": "",
                  "weee_tax_row_disposition": "",
                  "weight": ""
                }
              ],
              "shipping": {
                "address": {},
                "extension_attributes": {
                  "collection_point": {
                    "city": "",
                    "collection_point_id": "",
                    "country": "",
                    "name": "",
                    "postcode": "",
                    "recipient_address_id": 0,
                    "region": "",
                    "street": []
                  },
                  "ext_order_id": "",
                  "shipping_experience": {
                    "code": "",
                    "cost": "",
                    "label": ""
                  }
                },
                "method": "",
                "total": {
                  "base_shipping_amount": "",
                  "base_shipping_canceled": "",
                  "base_shipping_discount_amount": "",
                  "base_shipping_discount_tax_compensation_amnt": "",
                  "base_shipping_incl_tax": "",
                  "base_shipping_invoiced": "",
                  "base_shipping_refunded": "",
                  "base_shipping_tax_amount": "",
                  "base_shipping_tax_refunded": "",
                  "extension_attributes": {},
                  "shipping_amount": "",
                  "shipping_canceled": "",
                  "shipping_discount_amount": "",
                  "shipping_discount_tax_compensation_amount": "",
                  "shipping_incl_tax": "",
                  "shipping_invoiced": "",
                  "shipping_refunded": "",
                  "shipping_tax_amount": "",
                  "shipping_tax_refunded": ""
                }
              },
              "stock_id": 0
            }
          ]
        },
        "forced_shipment_with_invoice": 0,
        "global_currency_code": "",
        "grand_total": "",
        "hold_before_state": "",
        "hold_before_status": "",
        "increment_id": "",
        "is_virtual": 0,
        "items": [
          {}
        ],
        "order_currency_code": "",
        "original_increment_id": "",
        "payment": {
          "account_status": "",
          "additional_data": "",
          "additional_information": [],
          "address_status": "",
          "amount_authorized": "",
          "amount_canceled": "",
          "amount_ordered": "",
          "amount_paid": "",
          "amount_refunded": "",
          "anet_trans_method": "",
          "base_amount_authorized": "",
          "base_amount_canceled": "",
          "base_amount_ordered": "",
          "base_amount_paid": "",
          "base_amount_paid_online": "",
          "base_amount_refunded": "",
          "base_amount_refunded_online": "",
          "base_shipping_amount": "",
          "base_shipping_captured": "",
          "base_shipping_refunded": "",
          "cc_approval": "",
          "cc_avs_status": "",
          "cc_cid_status": "",
          "cc_debug_request_body": "",
          "cc_debug_response_body": "",
          "cc_debug_response_serialized": "",
          "cc_exp_month": "",
          "cc_exp_year": "",
          "cc_last4": "",
          "cc_number_enc": "",
          "cc_owner": "",
          "cc_secure_verify": "",
          "cc_ss_issue": "",
          "cc_ss_start_month": "",
          "cc_ss_start_year": "",
          "cc_status": "",
          "cc_status_description": "",
          "cc_trans_id": "",
          "cc_type": "",
          "echeck_account_name": "",
          "echeck_account_type": "",
          "echeck_bank_name": "",
          "echeck_routing_number": "",
          "echeck_type": "",
          "entity_id": 0,
          "extension_attributes": {
            "vault_payment_token": {
              "created_at": "",
              "customer_id": 0,
              "entity_id": 0,
              "expires_at": "",
              "gateway_token": "",
              "is_active": false,
              "is_visible": false,
              "payment_method_code": "",
              "public_hash": "",
              "token_details": "",
              "type": ""
            }
          },
          "last_trans_id": "",
          "method": "",
          "parent_id": 0,
          "po_number": "",
          "protection_eligibility": "",
          "quote_payment_id": 0,
          "shipping_amount": "",
          "shipping_captured": "",
          "shipping_refunded": ""
        },
        "payment_auth_expiration": 0,
        "payment_authorization_amount": "",
        "protect_code": "",
        "quote_address_id": 0,
        "quote_id": 0,
        "relation_child_id": "",
        "relation_child_real_id": "",
        "relation_parent_id": "",
        "relation_parent_real_id": "",
        "remote_ip": "",
        "shipping_amount": "",
        "shipping_canceled": "",
        "shipping_description": "",
        "shipping_discount_amount": "",
        "shipping_discount_tax_compensation_amount": "",
        "shipping_incl_tax": "",
        "shipping_invoiced": "",
        "shipping_refunded": "",
        "shipping_tax_amount": "",
        "shipping_tax_refunded": "",
        "state": "",
        "status": "",
        "status_histories": [
          {
            "comment": "",
            "created_at": "",
            "entity_id": 0,
            "entity_name": "",
            "extension_attributes": {},
            "is_customer_notified": 0,
            "is_visible_on_front": 0,
            "parent_id": 0,
            "status": ""
          }
        ],
        "store_currency_code": "",
        "store_id": 0,
        "store_name": "",
        "store_to_base_rate": "",
        "store_to_order_rate": "",
        "subtotal": "",
        "subtotal_canceled": "",
        "subtotal_incl_tax": "",
        "subtotal_invoiced": "",
        "subtotal_refunded": "",
        "tax_amount": "",
        "tax_canceled": "",
        "tax_invoiced": "",
        "tax_refunded": "",
        "total_canceled": "",
        "total_due": "",
        "total_invoiced": "",
        "total_item_count": 0,
        "total_offline_refunded": "",
        "total_online_refunded": "",
        "total_paid": "",
        "total_qty_ordered": "",
        "total_refunded": "",
        "updated_at": "",
        "weight": "",
        "x_forwarded_for": ""
      },
      "vertex_tax_calculation_shipping_address": {}
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "is_used_for_refund": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "total_qty": "",
    "transaction_id": "",
    "updated_at": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/invoices/');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'entity' => [
    'base_currency_code' => '',
    'base_discount_amount' => '',
    'base_discount_tax_compensation_amount' => '',
    'base_grand_total' => '',
    'base_shipping_amount' => '',
    'base_shipping_discount_tax_compensation_amnt' => '',
    'base_shipping_incl_tax' => '',
    'base_shipping_tax_amount' => '',
    'base_subtotal' => '',
    'base_subtotal_incl_tax' => '',
    'base_tax_amount' => '',
    'base_to_global_rate' => '',
    'base_to_order_rate' => '',
    'base_total_refunded' => '',
    'billing_address_id' => 0,
    'can_void_flag' => 0,
    'comments' => [
        [
                'comment' => '',
                'created_at' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'is_customer_notified' => 0,
                'is_visible_on_front' => 0,
                'parent_id' => 0
        ]
    ],
    'created_at' => '',
    'discount_amount' => '',
    'discount_description' => '',
    'discount_tax_compensation_amount' => '',
    'email_sent' => 0,
    'entity_id' => 0,
    'extension_attributes' => [
        'base_customer_balance_amount' => '',
        'base_gift_cards_amount' => '',
        'customer_balance_amount' => '',
        'gift_cards_amount' => '',
        'gw_base_price' => '',
        'gw_base_tax_amount' => '',
        'gw_card_base_price' => '',
        'gw_card_base_tax_amount' => '',
        'gw_card_price' => '',
        'gw_card_tax_amount' => '',
        'gw_items_base_price' => '',
        'gw_items_base_tax_amount' => '',
        'gw_items_price' => '',
        'gw_items_tax_amount' => '',
        'gw_price' => '',
        'gw_tax_amount' => '',
        'vertex_tax_calculation_billing_address' => [
                'address_type' => '',
                'city' => '',
                'company' => '',
                'country_id' => '',
                'customer_address_id' => 0,
                'customer_id' => 0,
                'email' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                'checkout_fields' => [
                                                                [
                                                                                                                                'attribute_code' => '',
                                                                                                                                'value' => ''
                                                                ]
                                ]
                ],
                'fax' => '',
                'firstname' => '',
                'lastname' => '',
                'middlename' => '',
                'parent_id' => 0,
                'postcode' => '',
                'prefix' => '',
                'region' => '',
                'region_code' => '',
                'region_id' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => '',
                'vat_is_valid' => 0,
                'vat_request_date' => '',
                'vat_request_id' => '',
                'vat_request_success' => 0
        ],
        'vertex_tax_calculation_order' => [
                'adjustment_negative' => '',
                'adjustment_positive' => '',
                'applied_rule_ids' => '',
                'base_adjustment_negative' => '',
                'base_adjustment_positive' => '',
                'base_currency_code' => '',
                'base_discount_amount' => '',
                'base_discount_canceled' => '',
                'base_discount_invoiced' => '',
                'base_discount_refunded' => '',
                'base_discount_tax_compensation_amount' => '',
                'base_discount_tax_compensation_invoiced' => '',
                'base_discount_tax_compensation_refunded' => '',
                'base_grand_total' => '',
                'base_shipping_amount' => '',
                'base_shipping_canceled' => '',
                'base_shipping_discount_amount' => '',
                'base_shipping_discount_tax_compensation_amnt' => '',
                'base_shipping_incl_tax' => '',
                'base_shipping_invoiced' => '',
                'base_shipping_refunded' => '',
                'base_shipping_tax_amount' => '',
                'base_shipping_tax_refunded' => '',
                'base_subtotal' => '',
                'base_subtotal_canceled' => '',
                'base_subtotal_incl_tax' => '',
                'base_subtotal_invoiced' => '',
                'base_subtotal_refunded' => '',
                'base_tax_amount' => '',
                'base_tax_canceled' => '',
                'base_tax_invoiced' => '',
                'base_tax_refunded' => '',
                'base_to_global_rate' => '',
                'base_to_order_rate' => '',
                'base_total_canceled' => '',
                'base_total_due' => '',
                'base_total_invoiced' => '',
                'base_total_invoiced_cost' => '',
                'base_total_offline_refunded' => '',
                'base_total_online_refunded' => '',
                'base_total_paid' => '',
                'base_total_qty_ordered' => '',
                'base_total_refunded' => '',
                'billing_address' => [
                                
                ],
                'billing_address_id' => 0,
                'can_ship_partially' => 0,
                'can_ship_partially_item' => 0,
                'coupon_code' => '',
                'created_at' => '',
                'customer_dob' => '',
                'customer_email' => '',
                'customer_firstname' => '',
                'customer_gender' => 0,
                'customer_group_id' => 0,
                'customer_id' => 0,
                'customer_is_guest' => 0,
                'customer_lastname' => '',
                'customer_middlename' => '',
                'customer_note' => '',
                'customer_note_notify' => 0,
                'customer_prefix' => '',
                'customer_suffix' => '',
                'customer_taxvat' => '',
                'discount_amount' => '',
                'discount_canceled' => '',
                'discount_description' => '',
                'discount_invoiced' => '',
                'discount_refunded' => '',
                'discount_tax_compensation_amount' => '',
                'discount_tax_compensation_invoiced' => '',
                'discount_tax_compensation_refunded' => '',
                'edit_increment' => 0,
                'email_sent' => 0,
                'entity_id' => 0,
                'ext_customer_id' => '',
                'ext_order_id' => '',
                'extension_attributes' => [
                                'amazon_order_reference_id' => '',
                                'applied_taxes' => [
                                                                [
                                                                                                                                'amount' => '',
                                                                                                                                'base_amount' => '',
                                                                                                                                'code' => '',
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'rates' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'percent' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'title' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'percent' => '',
                                                                                                                                'title' => ''
                                                                ]
                                ],
                                'base_customer_balance_amount' => '',
                                'base_customer_balance_invoiced' => '',
                                'base_customer_balance_refunded' => '',
                                'base_customer_balance_total_refunded' => '',
                                'base_gift_cards_amount' => '',
                                'base_gift_cards_invoiced' => '',
                                'base_gift_cards_refunded' => '',
                                'base_reward_currency_amount' => '',
                                'company_order_attributes' => [
                                                                'company_id' => 0,
                                                                'company_name' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'order_id' => 0
                                ],
                                'converting_from_quote' => null,
                                'customer_balance_amount' => '',
                                'customer_balance_invoiced' => '',
                                'customer_balance_refunded' => '',
                                'customer_balance_total_refunded' => '',
                                'gift_cards' => [
                                                                [
                                                                                                                                'amount' => '',
                                                                                                                                'base_amount' => '',
                                                                                                                                'code' => '',
                                                                                                                                'id' => 0
                                                                ]
                                ],
                                'gift_cards_amount' => '',
                                'gift_cards_invoiced' => '',
                                'gift_cards_refunded' => '',
                                'gift_message' => [
                                                                'customer_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                'entity_id' => '',
                                                                                                                                'entity_type' => '',
                                                                                                                                'wrapping_add_printed_card' => null,
                                                                                                                                'wrapping_allow_gift_receipt' => null,
                                                                                                                                'wrapping_id' => 0
                                                                ],
                                                                'gift_message_id' => 0,
                                                                'message' => '',
                                                                'recipient' => '',
                                                                'sender' => ''
                                ],
                                'gw_add_card' => '',
                                'gw_allow_gift_receipt' => '',
                                'gw_base_price' => '',
                                'gw_base_price_incl_tax' => '',
                                'gw_base_price_invoiced' => '',
                                'gw_base_price_refunded' => '',
                                'gw_base_tax_amount' => '',
                                'gw_base_tax_amount_invoiced' => '',
                                'gw_base_tax_amount_refunded' => '',
                                'gw_card_base_price' => '',
                                'gw_card_base_price_incl_tax' => '',
                                'gw_card_base_price_invoiced' => '',
                                'gw_card_base_price_refunded' => '',
                                'gw_card_base_tax_amount' => '',
                                'gw_card_base_tax_invoiced' => '',
                                'gw_card_base_tax_refunded' => '',
                                'gw_card_price' => '',
                                'gw_card_price_incl_tax' => '',
                                'gw_card_price_invoiced' => '',
                                'gw_card_price_refunded' => '',
                                'gw_card_tax_amount' => '',
                                'gw_card_tax_invoiced' => '',
                                'gw_card_tax_refunded' => '',
                                'gw_id' => '',
                                'gw_items_base_price' => '',
                                'gw_items_base_price_incl_tax' => '',
                                'gw_items_base_price_invoiced' => '',
                                'gw_items_base_price_refunded' => '',
                                'gw_items_base_tax_amount' => '',
                                'gw_items_base_tax_invoiced' => '',
                                'gw_items_base_tax_refunded' => '',
                                'gw_items_price' => '',
                                'gw_items_price_incl_tax' => '',
                                'gw_items_price_invoiced' => '',
                                'gw_items_price_refunded' => '',
                                'gw_items_tax_amount' => '',
                                'gw_items_tax_invoiced' => '',
                                'gw_items_tax_refunded' => '',
                                'gw_price' => '',
                                'gw_price_incl_tax' => '',
                                'gw_price_invoiced' => '',
                                'gw_price_refunded' => '',
                                'gw_tax_amount' => '',
                                'gw_tax_amount_invoiced' => '',
                                'gw_tax_amount_refunded' => '',
                                'item_applied_taxes' => [
                                                                [
                                                                                                                                'applied_taxes' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'associated_item_id' => 0,
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'item_id' => 0,
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'payment_additional_info' => [
                                                                [
                                                                                                                                'key' => '',
                                                                                                                                'value' => ''
                                                                ]
                                ],
                                'reward_currency_amount' => '',
                                'reward_points_balance' => 0,
                                'shipping_assignments' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'items' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'additional_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'applied_rule_ids' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_cost' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_tax_compensation_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_tax_compensation_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_tax_compensation_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_original_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_price_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_row_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_row_total' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_row_total_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_tax_before_discount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_tax_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_tax_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_weee_tax_applied_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_weee_tax_applied_row_amnt' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_weee_tax_disposition' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_weee_tax_row_disposition' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'created_at' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'description' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_percent' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_tax_compensation_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_tax_compensation_canceled' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_tax_compensation_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_tax_compensation_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'event_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'ext_order_item_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gift_message' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'invoice_text_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'vertex_tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'free_shipping' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'is_qty_decimal' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'is_virtual' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'item_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'locked_do_invoice' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'locked_do_ship' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'no_discount' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'order_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'parent_item' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'parent_item_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'price_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'product_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'product_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'bundle_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_qty' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'configurable_item_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_links' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_item_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_message' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_name' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'product_type' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_backordered' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_canceled' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_ordered' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_returned' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_shipped' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'quote_item_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'row_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'row_total' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'row_total_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'row_weight' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'sku' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'store_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_before_discount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_canceled' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_percent' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'updated_at' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weee_tax_applied' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weee_tax_applied_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weee_tax_applied_row_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weee_tax_disposition' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weee_tax_row_disposition' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weight' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'shipping' => [
                                                                                                                                                                                                                                                                'address' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'collection_point' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'city' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'collection_point_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'country' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'postcode' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'recipient_address_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'region' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'street' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'ext_order_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_experience' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'cost' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'label' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'method' => '',
                                                                                                                                                                                                                                                                'total' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_canceled' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_discount_tax_compensation_amnt' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_tax_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_canceled' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_discount_tax_compensation_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_tax_refunded' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'stock_id' => 0
                                                                ]
                                ]
                ],
                'forced_shipment_with_invoice' => 0,
                'global_currency_code' => '',
                'grand_total' => '',
                'hold_before_state' => '',
                'hold_before_status' => '',
                'increment_id' => '',
                'is_virtual' => 0,
                'items' => [
                                [
                                                                
                                ]
                ],
                'order_currency_code' => '',
                'original_increment_id' => '',
                'payment' => [
                                'account_status' => '',
                                'additional_data' => '',
                                'additional_information' => [
                                                                
                                ],
                                'address_status' => '',
                                'amount_authorized' => '',
                                'amount_canceled' => '',
                                'amount_ordered' => '',
                                'amount_paid' => '',
                                'amount_refunded' => '',
                                'anet_trans_method' => '',
                                'base_amount_authorized' => '',
                                'base_amount_canceled' => '',
                                'base_amount_ordered' => '',
                                'base_amount_paid' => '',
                                'base_amount_paid_online' => '',
                                'base_amount_refunded' => '',
                                'base_amount_refunded_online' => '',
                                'base_shipping_amount' => '',
                                'base_shipping_captured' => '',
                                'base_shipping_refunded' => '',
                                'cc_approval' => '',
                                'cc_avs_status' => '',
                                'cc_cid_status' => '',
                                'cc_debug_request_body' => '',
                                'cc_debug_response_body' => '',
                                'cc_debug_response_serialized' => '',
                                'cc_exp_month' => '',
                                'cc_exp_year' => '',
                                'cc_last4' => '',
                                'cc_number_enc' => '',
                                'cc_owner' => '',
                                'cc_secure_verify' => '',
                                'cc_ss_issue' => '',
                                'cc_ss_start_month' => '',
                                'cc_ss_start_year' => '',
                                'cc_status' => '',
                                'cc_status_description' => '',
                                'cc_trans_id' => '',
                                'cc_type' => '',
                                'echeck_account_name' => '',
                                'echeck_account_type' => '',
                                'echeck_bank_name' => '',
                                'echeck_routing_number' => '',
                                'echeck_type' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                'vault_payment_token' => [
                                                                                                                                'created_at' => '',
                                                                                                                                'customer_id' => 0,
                                                                                                                                'entity_id' => 0,
                                                                                                                                'expires_at' => '',
                                                                                                                                'gateway_token' => '',
                                                                                                                                'is_active' => null,
                                                                                                                                'is_visible' => null,
                                                                                                                                'payment_method_code' => '',
                                                                                                                                'public_hash' => '',
                                                                                                                                'token_details' => '',
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'last_trans_id' => '',
                                'method' => '',
                                'parent_id' => 0,
                                'po_number' => '',
                                'protection_eligibility' => '',
                                'quote_payment_id' => 0,
                                'shipping_amount' => '',
                                'shipping_captured' => '',
                                'shipping_refunded' => ''
                ],
                'payment_auth_expiration' => 0,
                'payment_authorization_amount' => '',
                'protect_code' => '',
                'quote_address_id' => 0,
                'quote_id' => 0,
                'relation_child_id' => '',
                'relation_child_real_id' => '',
                'relation_parent_id' => '',
                'relation_parent_real_id' => '',
                'remote_ip' => '',
                'shipping_amount' => '',
                'shipping_canceled' => '',
                'shipping_description' => '',
                'shipping_discount_amount' => '',
                'shipping_discount_tax_compensation_amount' => '',
                'shipping_incl_tax' => '',
                'shipping_invoiced' => '',
                'shipping_refunded' => '',
                'shipping_tax_amount' => '',
                'shipping_tax_refunded' => '',
                'state' => '',
                'status' => '',
                'status_histories' => [
                                [
                                                                'comment' => '',
                                                                'created_at' => '',
                                                                'entity_id' => 0,
                                                                'entity_name' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'is_customer_notified' => 0,
                                                                'is_visible_on_front' => 0,
                                                                'parent_id' => 0,
                                                                'status' => ''
                                ]
                ],
                'store_currency_code' => '',
                'store_id' => 0,
                'store_name' => '',
                'store_to_base_rate' => '',
                'store_to_order_rate' => '',
                'subtotal' => '',
                'subtotal_canceled' => '',
                'subtotal_incl_tax' => '',
                'subtotal_invoiced' => '',
                'subtotal_refunded' => '',
                'tax_amount' => '',
                'tax_canceled' => '',
                'tax_invoiced' => '',
                'tax_refunded' => '',
                'total_canceled' => '',
                'total_due' => '',
                'total_invoiced' => '',
                'total_item_count' => 0,
                'total_offline_refunded' => '',
                'total_online_refunded' => '',
                'total_paid' => '',
                'total_qty_ordered' => '',
                'total_refunded' => '',
                'updated_at' => '',
                'weight' => '',
                'x_forwarded_for' => ''
        ],
        'vertex_tax_calculation_shipping_address' => [
                
        ]
    ],
    'global_currency_code' => '',
    'grand_total' => '',
    'increment_id' => '',
    'is_used_for_refund' => 0,
    'items' => [
        [
                'additional_data' => '',
                'base_cost' => '',
                'base_discount_amount' => '',
                'base_discount_tax_compensation_amount' => '',
                'base_price' => '',
                'base_price_incl_tax' => '',
                'base_row_total' => '',
                'base_row_total_incl_tax' => '',
                'base_tax_amount' => '',
                'description' => '',
                'discount_amount' => '',
                'discount_tax_compensation_amount' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                'invoice_text_codes' => [
                                                                
                                ],
                                'tax_codes' => [
                                                                
                                ],
                                'vertex_tax_codes' => [
                                                                
                                ]
                ],
                'name' => '',
                'order_item_id' => 0,
                'parent_id' => 0,
                'price' => '',
                'price_incl_tax' => '',
                'product_id' => 0,
                'qty' => '',
                'row_total' => '',
                'row_total_incl_tax' => '',
                'sku' => '',
                'tax_amount' => ''
        ]
    ],
    'order_currency_code' => '',
    'order_id' => 0,
    'shipping_address_id' => 0,
    'shipping_amount' => '',
    'shipping_discount_tax_compensation_amount' => '',
    'shipping_incl_tax' => '',
    'shipping_tax_amount' => '',
    'state' => 0,
    'store_currency_code' => '',
    'store_id' => 0,
    'store_to_base_rate' => '',
    'store_to_order_rate' => '',
    'subtotal' => '',
    'subtotal_incl_tax' => '',
    'tax_amount' => '',
    'total_qty' => '',
    'transaction_id' => '',
    'updated_at' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'entity' => [
    'base_currency_code' => '',
    'base_discount_amount' => '',
    'base_discount_tax_compensation_amount' => '',
    'base_grand_total' => '',
    'base_shipping_amount' => '',
    'base_shipping_discount_tax_compensation_amnt' => '',
    'base_shipping_incl_tax' => '',
    'base_shipping_tax_amount' => '',
    'base_subtotal' => '',
    'base_subtotal_incl_tax' => '',
    'base_tax_amount' => '',
    'base_to_global_rate' => '',
    'base_to_order_rate' => '',
    'base_total_refunded' => '',
    'billing_address_id' => 0,
    'can_void_flag' => 0,
    'comments' => [
        [
                'comment' => '',
                'created_at' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'is_customer_notified' => 0,
                'is_visible_on_front' => 0,
                'parent_id' => 0
        ]
    ],
    'created_at' => '',
    'discount_amount' => '',
    'discount_description' => '',
    'discount_tax_compensation_amount' => '',
    'email_sent' => 0,
    'entity_id' => 0,
    'extension_attributes' => [
        'base_customer_balance_amount' => '',
        'base_gift_cards_amount' => '',
        'customer_balance_amount' => '',
        'gift_cards_amount' => '',
        'gw_base_price' => '',
        'gw_base_tax_amount' => '',
        'gw_card_base_price' => '',
        'gw_card_base_tax_amount' => '',
        'gw_card_price' => '',
        'gw_card_tax_amount' => '',
        'gw_items_base_price' => '',
        'gw_items_base_tax_amount' => '',
        'gw_items_price' => '',
        'gw_items_tax_amount' => '',
        'gw_price' => '',
        'gw_tax_amount' => '',
        'vertex_tax_calculation_billing_address' => [
                'address_type' => '',
                'city' => '',
                'company' => '',
                'country_id' => '',
                'customer_address_id' => 0,
                'customer_id' => 0,
                'email' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                'checkout_fields' => [
                                                                [
                                                                                                                                'attribute_code' => '',
                                                                                                                                'value' => ''
                                                                ]
                                ]
                ],
                'fax' => '',
                'firstname' => '',
                'lastname' => '',
                'middlename' => '',
                'parent_id' => 0,
                'postcode' => '',
                'prefix' => '',
                'region' => '',
                'region_code' => '',
                'region_id' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => '',
                'vat_is_valid' => 0,
                'vat_request_date' => '',
                'vat_request_id' => '',
                'vat_request_success' => 0
        ],
        'vertex_tax_calculation_order' => [
                'adjustment_negative' => '',
                'adjustment_positive' => '',
                'applied_rule_ids' => '',
                'base_adjustment_negative' => '',
                'base_adjustment_positive' => '',
                'base_currency_code' => '',
                'base_discount_amount' => '',
                'base_discount_canceled' => '',
                'base_discount_invoiced' => '',
                'base_discount_refunded' => '',
                'base_discount_tax_compensation_amount' => '',
                'base_discount_tax_compensation_invoiced' => '',
                'base_discount_tax_compensation_refunded' => '',
                'base_grand_total' => '',
                'base_shipping_amount' => '',
                'base_shipping_canceled' => '',
                'base_shipping_discount_amount' => '',
                'base_shipping_discount_tax_compensation_amnt' => '',
                'base_shipping_incl_tax' => '',
                'base_shipping_invoiced' => '',
                'base_shipping_refunded' => '',
                'base_shipping_tax_amount' => '',
                'base_shipping_tax_refunded' => '',
                'base_subtotal' => '',
                'base_subtotal_canceled' => '',
                'base_subtotal_incl_tax' => '',
                'base_subtotal_invoiced' => '',
                'base_subtotal_refunded' => '',
                'base_tax_amount' => '',
                'base_tax_canceled' => '',
                'base_tax_invoiced' => '',
                'base_tax_refunded' => '',
                'base_to_global_rate' => '',
                'base_to_order_rate' => '',
                'base_total_canceled' => '',
                'base_total_due' => '',
                'base_total_invoiced' => '',
                'base_total_invoiced_cost' => '',
                'base_total_offline_refunded' => '',
                'base_total_online_refunded' => '',
                'base_total_paid' => '',
                'base_total_qty_ordered' => '',
                'base_total_refunded' => '',
                'billing_address' => [
                                
                ],
                'billing_address_id' => 0,
                'can_ship_partially' => 0,
                'can_ship_partially_item' => 0,
                'coupon_code' => '',
                'created_at' => '',
                'customer_dob' => '',
                'customer_email' => '',
                'customer_firstname' => '',
                'customer_gender' => 0,
                'customer_group_id' => 0,
                'customer_id' => 0,
                'customer_is_guest' => 0,
                'customer_lastname' => '',
                'customer_middlename' => '',
                'customer_note' => '',
                'customer_note_notify' => 0,
                'customer_prefix' => '',
                'customer_suffix' => '',
                'customer_taxvat' => '',
                'discount_amount' => '',
                'discount_canceled' => '',
                'discount_description' => '',
                'discount_invoiced' => '',
                'discount_refunded' => '',
                'discount_tax_compensation_amount' => '',
                'discount_tax_compensation_invoiced' => '',
                'discount_tax_compensation_refunded' => '',
                'edit_increment' => 0,
                'email_sent' => 0,
                'entity_id' => 0,
                'ext_customer_id' => '',
                'ext_order_id' => '',
                'extension_attributes' => [
                                'amazon_order_reference_id' => '',
                                'applied_taxes' => [
                                                                [
                                                                                                                                'amount' => '',
                                                                                                                                'base_amount' => '',
                                                                                                                                'code' => '',
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'rates' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'percent' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'title' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'percent' => '',
                                                                                                                                'title' => ''
                                                                ]
                                ],
                                'base_customer_balance_amount' => '',
                                'base_customer_balance_invoiced' => '',
                                'base_customer_balance_refunded' => '',
                                'base_customer_balance_total_refunded' => '',
                                'base_gift_cards_amount' => '',
                                'base_gift_cards_invoiced' => '',
                                'base_gift_cards_refunded' => '',
                                'base_reward_currency_amount' => '',
                                'company_order_attributes' => [
                                                                'company_id' => 0,
                                                                'company_name' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'order_id' => 0
                                ],
                                'converting_from_quote' => null,
                                'customer_balance_amount' => '',
                                'customer_balance_invoiced' => '',
                                'customer_balance_refunded' => '',
                                'customer_balance_total_refunded' => '',
                                'gift_cards' => [
                                                                [
                                                                                                                                'amount' => '',
                                                                                                                                'base_amount' => '',
                                                                                                                                'code' => '',
                                                                                                                                'id' => 0
                                                                ]
                                ],
                                'gift_cards_amount' => '',
                                'gift_cards_invoiced' => '',
                                'gift_cards_refunded' => '',
                                'gift_message' => [
                                                                'customer_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                'entity_id' => '',
                                                                                                                                'entity_type' => '',
                                                                                                                                'wrapping_add_printed_card' => null,
                                                                                                                                'wrapping_allow_gift_receipt' => null,
                                                                                                                                'wrapping_id' => 0
                                                                ],
                                                                'gift_message_id' => 0,
                                                                'message' => '',
                                                                'recipient' => '',
                                                                'sender' => ''
                                ],
                                'gw_add_card' => '',
                                'gw_allow_gift_receipt' => '',
                                'gw_base_price' => '',
                                'gw_base_price_incl_tax' => '',
                                'gw_base_price_invoiced' => '',
                                'gw_base_price_refunded' => '',
                                'gw_base_tax_amount' => '',
                                'gw_base_tax_amount_invoiced' => '',
                                'gw_base_tax_amount_refunded' => '',
                                'gw_card_base_price' => '',
                                'gw_card_base_price_incl_tax' => '',
                                'gw_card_base_price_invoiced' => '',
                                'gw_card_base_price_refunded' => '',
                                'gw_card_base_tax_amount' => '',
                                'gw_card_base_tax_invoiced' => '',
                                'gw_card_base_tax_refunded' => '',
                                'gw_card_price' => '',
                                'gw_card_price_incl_tax' => '',
                                'gw_card_price_invoiced' => '',
                                'gw_card_price_refunded' => '',
                                'gw_card_tax_amount' => '',
                                'gw_card_tax_invoiced' => '',
                                'gw_card_tax_refunded' => '',
                                'gw_id' => '',
                                'gw_items_base_price' => '',
                                'gw_items_base_price_incl_tax' => '',
                                'gw_items_base_price_invoiced' => '',
                                'gw_items_base_price_refunded' => '',
                                'gw_items_base_tax_amount' => '',
                                'gw_items_base_tax_invoiced' => '',
                                'gw_items_base_tax_refunded' => '',
                                'gw_items_price' => '',
                                'gw_items_price_incl_tax' => '',
                                'gw_items_price_invoiced' => '',
                                'gw_items_price_refunded' => '',
                                'gw_items_tax_amount' => '',
                                'gw_items_tax_invoiced' => '',
                                'gw_items_tax_refunded' => '',
                                'gw_price' => '',
                                'gw_price_incl_tax' => '',
                                'gw_price_invoiced' => '',
                                'gw_price_refunded' => '',
                                'gw_tax_amount' => '',
                                'gw_tax_amount_invoiced' => '',
                                'gw_tax_amount_refunded' => '',
                                'item_applied_taxes' => [
                                                                [
                                                                                                                                'applied_taxes' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'associated_item_id' => 0,
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'item_id' => 0,
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'payment_additional_info' => [
                                                                [
                                                                                                                                'key' => '',
                                                                                                                                'value' => ''
                                                                ]
                                ],
                                'reward_currency_amount' => '',
                                'reward_points_balance' => 0,
                                'shipping_assignments' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'items' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'additional_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'applied_rule_ids' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_cost' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_tax_compensation_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_tax_compensation_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_discount_tax_compensation_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_original_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_price_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_row_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_row_total' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_row_total_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_tax_before_discount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_tax_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_tax_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_weee_tax_applied_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_weee_tax_applied_row_amnt' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_weee_tax_disposition' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_weee_tax_row_disposition' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'created_at' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'description' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_percent' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_tax_compensation_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_tax_compensation_canceled' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_tax_compensation_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'discount_tax_compensation_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'event_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'ext_order_item_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gift_message' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'invoice_text_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'vertex_tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'free_shipping' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'is_qty_decimal' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'is_virtual' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'item_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'locked_do_invoice' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'locked_do_ship' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'no_discount' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'order_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'parent_item' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'parent_item_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'price_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'product_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'product_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'bundle_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_qty' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'configurable_item_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_links' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_item_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_message' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_name' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'product_type' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_backordered' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_canceled' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_ordered' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_returned' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty_shipped' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'quote_item_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'row_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'row_total' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'row_total_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'row_weight' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'sku' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'store_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_before_discount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_canceled' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_percent' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'updated_at' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weee_tax_applied' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weee_tax_applied_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weee_tax_applied_row_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weee_tax_disposition' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weee_tax_row_disposition' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'weight' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'shipping' => [
                                                                                                                                                                                                                                                                'address' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'collection_point' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'city' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'collection_point_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'country' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'postcode' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'recipient_address_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'region' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'street' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'ext_order_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_experience' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'cost' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'label' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'method' => '',
                                                                                                                                                                                                                                                                'total' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_canceled' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_discount_tax_compensation_amnt' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base_shipping_tax_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_canceled' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_discount_tax_compensation_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_incl_tax' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'shipping_tax_refunded' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'stock_id' => 0
                                                                ]
                                ]
                ],
                'forced_shipment_with_invoice' => 0,
                'global_currency_code' => '',
                'grand_total' => '',
                'hold_before_state' => '',
                'hold_before_status' => '',
                'increment_id' => '',
                'is_virtual' => 0,
                'items' => [
                                [
                                                                
                                ]
                ],
                'order_currency_code' => '',
                'original_increment_id' => '',
                'payment' => [
                                'account_status' => '',
                                'additional_data' => '',
                                'additional_information' => [
                                                                
                                ],
                                'address_status' => '',
                                'amount_authorized' => '',
                                'amount_canceled' => '',
                                'amount_ordered' => '',
                                'amount_paid' => '',
                                'amount_refunded' => '',
                                'anet_trans_method' => '',
                                'base_amount_authorized' => '',
                                'base_amount_canceled' => '',
                                'base_amount_ordered' => '',
                                'base_amount_paid' => '',
                                'base_amount_paid_online' => '',
                                'base_amount_refunded' => '',
                                'base_amount_refunded_online' => '',
                                'base_shipping_amount' => '',
                                'base_shipping_captured' => '',
                                'base_shipping_refunded' => '',
                                'cc_approval' => '',
                                'cc_avs_status' => '',
                                'cc_cid_status' => '',
                                'cc_debug_request_body' => '',
                                'cc_debug_response_body' => '',
                                'cc_debug_response_serialized' => '',
                                'cc_exp_month' => '',
                                'cc_exp_year' => '',
                                'cc_last4' => '',
                                'cc_number_enc' => '',
                                'cc_owner' => '',
                                'cc_secure_verify' => '',
                                'cc_ss_issue' => '',
                                'cc_ss_start_month' => '',
                                'cc_ss_start_year' => '',
                                'cc_status' => '',
                                'cc_status_description' => '',
                                'cc_trans_id' => '',
                                'cc_type' => '',
                                'echeck_account_name' => '',
                                'echeck_account_type' => '',
                                'echeck_bank_name' => '',
                                'echeck_routing_number' => '',
                                'echeck_type' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                'vault_payment_token' => [
                                                                                                                                'created_at' => '',
                                                                                                                                'customer_id' => 0,
                                                                                                                                'entity_id' => 0,
                                                                                                                                'expires_at' => '',
                                                                                                                                'gateway_token' => '',
                                                                                                                                'is_active' => null,
                                                                                                                                'is_visible' => null,
                                                                                                                                'payment_method_code' => '',
                                                                                                                                'public_hash' => '',
                                                                                                                                'token_details' => '',
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'last_trans_id' => '',
                                'method' => '',
                                'parent_id' => 0,
                                'po_number' => '',
                                'protection_eligibility' => '',
                                'quote_payment_id' => 0,
                                'shipping_amount' => '',
                                'shipping_captured' => '',
                                'shipping_refunded' => ''
                ],
                'payment_auth_expiration' => 0,
                'payment_authorization_amount' => '',
                'protect_code' => '',
                'quote_address_id' => 0,
                'quote_id' => 0,
                'relation_child_id' => '',
                'relation_child_real_id' => '',
                'relation_parent_id' => '',
                'relation_parent_real_id' => '',
                'remote_ip' => '',
                'shipping_amount' => '',
                'shipping_canceled' => '',
                'shipping_description' => '',
                'shipping_discount_amount' => '',
                'shipping_discount_tax_compensation_amount' => '',
                'shipping_incl_tax' => '',
                'shipping_invoiced' => '',
                'shipping_refunded' => '',
                'shipping_tax_amount' => '',
                'shipping_tax_refunded' => '',
                'state' => '',
                'status' => '',
                'status_histories' => [
                                [
                                                                'comment' => '',
                                                                'created_at' => '',
                                                                'entity_id' => 0,
                                                                'entity_name' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'is_customer_notified' => 0,
                                                                'is_visible_on_front' => 0,
                                                                'parent_id' => 0,
                                                                'status' => ''
                                ]
                ],
                'store_currency_code' => '',
                'store_id' => 0,
                'store_name' => '',
                'store_to_base_rate' => '',
                'store_to_order_rate' => '',
                'subtotal' => '',
                'subtotal_canceled' => '',
                'subtotal_incl_tax' => '',
                'subtotal_invoiced' => '',
                'subtotal_refunded' => '',
                'tax_amount' => '',
                'tax_canceled' => '',
                'tax_invoiced' => '',
                'tax_refunded' => '',
                'total_canceled' => '',
                'total_due' => '',
                'total_invoiced' => '',
                'total_item_count' => 0,
                'total_offline_refunded' => '',
                'total_online_refunded' => '',
                'total_paid' => '',
                'total_qty_ordered' => '',
                'total_refunded' => '',
                'updated_at' => '',
                'weight' => '',
                'x_forwarded_for' => ''
        ],
        'vertex_tax_calculation_shipping_address' => [
                
        ]
    ],
    'global_currency_code' => '',
    'grand_total' => '',
    'increment_id' => '',
    'is_used_for_refund' => 0,
    'items' => [
        [
                'additional_data' => '',
                'base_cost' => '',
                'base_discount_amount' => '',
                'base_discount_tax_compensation_amount' => '',
                'base_price' => '',
                'base_price_incl_tax' => '',
                'base_row_total' => '',
                'base_row_total_incl_tax' => '',
                'base_tax_amount' => '',
                'description' => '',
                'discount_amount' => '',
                'discount_tax_compensation_amount' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                'invoice_text_codes' => [
                                                                
                                ],
                                'tax_codes' => [
                                                                
                                ],
                                'vertex_tax_codes' => [
                                                                
                                ]
                ],
                'name' => '',
                'order_item_id' => 0,
                'parent_id' => 0,
                'price' => '',
                'price_incl_tax' => '',
                'product_id' => 0,
                'qty' => '',
                'row_total' => '',
                'row_total_incl_tax' => '',
                'sku' => '',
                'tax_amount' => ''
        ]
    ],
    'order_currency_code' => '',
    'order_id' => 0,
    'shipping_address_id' => 0,
    'shipping_amount' => '',
    'shipping_discount_tax_compensation_amount' => '',
    'shipping_incl_tax' => '',
    'shipping_tax_amount' => '',
    'state' => 0,
    'store_currency_code' => '',
    'store_id' => 0,
    'store_to_base_rate' => '',
    'store_to_order_rate' => '',
    'subtotal' => '',
    'subtotal_incl_tax' => '',
    'tax_amount' => '',
    'total_qty' => '',
    'transaction_id' => '',
    'updated_at' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/invoices/');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/invoices/' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_refunded": "",
    "billing_address_id": 0,
    "can_void_flag": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": "",
      "vertex_tax_calculation_billing_address": {
        "address_type": "",
        "city": "",
        "company": "",
        "country_id": "",
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "entity_id": 0,
        "extension_attributes": {
          "checkout_fields": [
            {
              "attribute_code": "",
              "value": ""
            }
          ]
        },
        "fax": "",
        "firstname": "",
        "lastname": "",
        "middlename": "",
        "parent_id": 0,
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": "",
        "vat_is_valid": 0,
        "vat_request_date": "",
        "vat_request_id": "",
        "vat_request_success": 0
      },
      "vertex_tax_calculation_order": {
        "adjustment_negative": "",
        "adjustment_positive": "",
        "applied_rule_ids": "",
        "base_adjustment_negative": "",
        "base_adjustment_positive": "",
        "base_currency_code": "",
        "base_discount_amount": "",
        "base_discount_canceled": "",
        "base_discount_invoiced": "",
        "base_discount_refunded": "",
        "base_discount_tax_compensation_amount": "",
        "base_discount_tax_compensation_invoiced": "",
        "base_discount_tax_compensation_refunded": "",
        "base_grand_total": "",
        "base_shipping_amount": "",
        "base_shipping_canceled": "",
        "base_shipping_discount_amount": "",
        "base_shipping_discount_tax_compensation_amnt": "",
        "base_shipping_incl_tax": "",
        "base_shipping_invoiced": "",
        "base_shipping_refunded": "",
        "base_shipping_tax_amount": "",
        "base_shipping_tax_refunded": "",
        "base_subtotal": "",
        "base_subtotal_canceled": "",
        "base_subtotal_incl_tax": "",
        "base_subtotal_invoiced": "",
        "base_subtotal_refunded": "",
        "base_tax_amount": "",
        "base_tax_canceled": "",
        "base_tax_invoiced": "",
        "base_tax_refunded": "",
        "base_to_global_rate": "",
        "base_to_order_rate": "",
        "base_total_canceled": "",
        "base_total_due": "",
        "base_total_invoiced": "",
        "base_total_invoiced_cost": "",
        "base_total_offline_refunded": "",
        "base_total_online_refunded": "",
        "base_total_paid": "",
        "base_total_qty_ordered": "",
        "base_total_refunded": "",
        "billing_address": {},
        "billing_address_id": 0,
        "can_ship_partially": 0,
        "can_ship_partially_item": 0,
        "coupon_code": "",
        "created_at": "",
        "customer_dob": "",
        "customer_email": "",
        "customer_firstname": "",
        "customer_gender": 0,
        "customer_group_id": 0,
        "customer_id": 0,
        "customer_is_guest": 0,
        "customer_lastname": "",
        "customer_middlename": "",
        "customer_note": "",
        "customer_note_notify": 0,
        "customer_prefix": "",
        "customer_suffix": "",
        "customer_taxvat": "",
        "discount_amount": "",
        "discount_canceled": "",
        "discount_description": "",
        "discount_invoiced": "",
        "discount_refunded": "",
        "discount_tax_compensation_amount": "",
        "discount_tax_compensation_invoiced": "",
        "discount_tax_compensation_refunded": "",
        "edit_increment": 0,
        "email_sent": 0,
        "entity_id": 0,
        "ext_customer_id": "",
        "ext_order_id": "",
        "extension_attributes": {
          "amazon_order_reference_id": "",
          "applied_taxes": [
            {
              "amount": "",
              "base_amount": "",
              "code": "",
              "extension_attributes": {
                "rates": [
                  {
                    "code": "",
                    "extension_attributes": {},
                    "percent": "",
                    "title": ""
                  }
                ]
              },
              "percent": "",
              "title": ""
            }
          ],
          "base_customer_balance_amount": "",
          "base_customer_balance_invoiced": "",
          "base_customer_balance_refunded": "",
          "base_customer_balance_total_refunded": "",
          "base_gift_cards_amount": "",
          "base_gift_cards_invoiced": "",
          "base_gift_cards_refunded": "",
          "base_reward_currency_amount": "",
          "company_order_attributes": {
            "company_id": 0,
            "company_name": "",
            "extension_attributes": {},
            "order_id": 0
          },
          "converting_from_quote": false,
          "customer_balance_amount": "",
          "customer_balance_invoiced": "",
          "customer_balance_refunded": "",
          "customer_balance_total_refunded": "",
          "gift_cards": [
            {
              "amount": "",
              "base_amount": "",
              "code": "",
              "id": 0
            }
          ],
          "gift_cards_amount": "",
          "gift_cards_invoiced": "",
          "gift_cards_refunded": "",
          "gift_message": {
            "customer_id": 0,
            "extension_attributes": {
              "entity_id": "",
              "entity_type": "",
              "wrapping_add_printed_card": false,
              "wrapping_allow_gift_receipt": false,
              "wrapping_id": 0
            },
            "gift_message_id": 0,
            "message": "",
            "recipient": "",
            "sender": ""
          },
          "gw_add_card": "",
          "gw_allow_gift_receipt": "",
          "gw_base_price": "",
          "gw_base_price_incl_tax": "",
          "gw_base_price_invoiced": "",
          "gw_base_price_refunded": "",
          "gw_base_tax_amount": "",
          "gw_base_tax_amount_invoiced": "",
          "gw_base_tax_amount_refunded": "",
          "gw_card_base_price": "",
          "gw_card_base_price_incl_tax": "",
          "gw_card_base_price_invoiced": "",
          "gw_card_base_price_refunded": "",
          "gw_card_base_tax_amount": "",
          "gw_card_base_tax_invoiced": "",
          "gw_card_base_tax_refunded": "",
          "gw_card_price": "",
          "gw_card_price_incl_tax": "",
          "gw_card_price_invoiced": "",
          "gw_card_price_refunded": "",
          "gw_card_tax_amount": "",
          "gw_card_tax_invoiced": "",
          "gw_card_tax_refunded": "",
          "gw_id": "",
          "gw_items_base_price": "",
          "gw_items_base_price_incl_tax": "",
          "gw_items_base_price_invoiced": "",
          "gw_items_base_price_refunded": "",
          "gw_items_base_tax_amount": "",
          "gw_items_base_tax_invoiced": "",
          "gw_items_base_tax_refunded": "",
          "gw_items_price": "",
          "gw_items_price_incl_tax": "",
          "gw_items_price_invoiced": "",
          "gw_items_price_refunded": "",
          "gw_items_tax_amount": "",
          "gw_items_tax_invoiced": "",
          "gw_items_tax_refunded": "",
          "gw_price": "",
          "gw_price_incl_tax": "",
          "gw_price_invoiced": "",
          "gw_price_refunded": "",
          "gw_tax_amount": "",
          "gw_tax_amount_invoiced": "",
          "gw_tax_amount_refunded": "",
          "item_applied_taxes": [
            {
              "applied_taxes": [
                {}
              ],
              "associated_item_id": 0,
              "extension_attributes": {},
              "item_id": 0,
              "type": ""
            }
          ],
          "payment_additional_info": [
            {
              "key": "",
              "value": ""
            }
          ],
          "reward_currency_amount": "",
          "reward_points_balance": 0,
          "shipping_assignments": [
            {
              "extension_attributes": {},
              "items": [
                {
                  "additional_data": "",
                  "amount_refunded": "",
                  "applied_rule_ids": "",
                  "base_amount_refunded": "",
                  "base_cost": "",
                  "base_discount_amount": "",
                  "base_discount_invoiced": "",
                  "base_discount_refunded": "",
                  "base_discount_tax_compensation_amount": "",
                  "base_discount_tax_compensation_invoiced": "",
                  "base_discount_tax_compensation_refunded": "",
                  "base_original_price": "",
                  "base_price": "",
                  "base_price_incl_tax": "",
                  "base_row_invoiced": "",
                  "base_row_total": "",
                  "base_row_total_incl_tax": "",
                  "base_tax_amount": "",
                  "base_tax_before_discount": "",
                  "base_tax_invoiced": "",
                  "base_tax_refunded": "",
                  "base_weee_tax_applied_amount": "",
                  "base_weee_tax_applied_row_amnt": "",
                  "base_weee_tax_disposition": "",
                  "base_weee_tax_row_disposition": "",
                  "created_at": "",
                  "description": "",
                  "discount_amount": "",
                  "discount_invoiced": "",
                  "discount_percent": "",
                  "discount_refunded": "",
                  "discount_tax_compensation_amount": "",
                  "discount_tax_compensation_canceled": "",
                  "discount_tax_compensation_invoiced": "",
                  "discount_tax_compensation_refunded": "",
                  "event_id": 0,
                  "ext_order_item_id": "",
                  "extension_attributes": {
                    "gift_message": {},
                    "gw_base_price": "",
                    "gw_base_price_invoiced": "",
                    "gw_base_price_refunded": "",
                    "gw_base_tax_amount": "",
                    "gw_base_tax_amount_invoiced": "",
                    "gw_base_tax_amount_refunded": "",
                    "gw_id": "",
                    "gw_price": "",
                    "gw_price_invoiced": "",
                    "gw_price_refunded": "",
                    "gw_tax_amount": "",
                    "gw_tax_amount_invoiced": "",
                    "gw_tax_amount_refunded": "",
                    "invoice_text_codes": [],
                    "tax_codes": [],
                    "vertex_tax_codes": []
                  },
                  "free_shipping": 0,
                  "gw_base_price": "",
                  "gw_base_price_invoiced": "",
                  "gw_base_price_refunded": "",
                  "gw_base_tax_amount": "",
                  "gw_base_tax_amount_invoiced": "",
                  "gw_base_tax_amount_refunded": "",
                  "gw_id": 0,
                  "gw_price": "",
                  "gw_price_invoiced": "",
                  "gw_price_refunded": "",
                  "gw_tax_amount": "",
                  "gw_tax_amount_invoiced": "",
                  "gw_tax_amount_refunded": "",
                  "is_qty_decimal": 0,
                  "is_virtual": 0,
                  "item_id": 0,
                  "locked_do_invoice": 0,
                  "locked_do_ship": 0,
                  "name": "",
                  "no_discount": 0,
                  "order_id": 0,
                  "original_price": "",
                  "parent_item": "",
                  "parent_item_id": 0,
                  "price": "",
                  "price_incl_tax": "",
                  "product_id": 0,
                  "product_option": {
                    "extension_attributes": {
                      "bundle_options": [
                        {
                          "extension_attributes": {},
                          "option_id": 0,
                          "option_qty": 0,
                          "option_selections": []
                        }
                      ],
                      "configurable_item_options": [
                        {
                          "extension_attributes": {},
                          "option_id": "",
                          "option_value": 0
                        }
                      ],
                      "custom_options": [
                        {
                          "extension_attributes": {
                            "file_info": {
                              "base64_encoded_data": "",
                              "name": "",
                              "type": ""
                            }
                          },
                          "option_id": "",
                          "option_value": ""
                        }
                      ],
                      "downloadable_option": {
                        "downloadable_links": []
                      },
                      "giftcard_item_option": {
                        "custom_giftcard_amount": "",
                        "extension_attributes": {},
                        "giftcard_amount": "",
                        "giftcard_message": "",
                        "giftcard_recipient_email": "",
                        "giftcard_recipient_name": "",
                        "giftcard_sender_email": "",
                        "giftcard_sender_name": ""
                      }
                    }
                  },
                  "product_type": "",
                  "qty_backordered": "",
                  "qty_canceled": "",
                  "qty_invoiced": "",
                  "qty_ordered": "",
                  "qty_refunded": "",
                  "qty_returned": "",
                  "qty_shipped": "",
                  "quote_item_id": 0,
                  "row_invoiced": "",
                  "row_total": "",
                  "row_total_incl_tax": "",
                  "row_weight": "",
                  "sku": "",
                  "store_id": 0,
                  "tax_amount": "",
                  "tax_before_discount": "",
                  "tax_canceled": "",
                  "tax_invoiced": "",
                  "tax_percent": "",
                  "tax_refunded": "",
                  "updated_at": "",
                  "weee_tax_applied": "",
                  "weee_tax_applied_amount": "",
                  "weee_tax_applied_row_amount": "",
                  "weee_tax_disposition": "",
                  "weee_tax_row_disposition": "",
                  "weight": ""
                }
              ],
              "shipping": {
                "address": {},
                "extension_attributes": {
                  "collection_point": {
                    "city": "",
                    "collection_point_id": "",
                    "country": "",
                    "name": "",
                    "postcode": "",
                    "recipient_address_id": 0,
                    "region": "",
                    "street": []
                  },
                  "ext_order_id": "",
                  "shipping_experience": {
                    "code": "",
                    "cost": "",
                    "label": ""
                  }
                },
                "method": "",
                "total": {
                  "base_shipping_amount": "",
                  "base_shipping_canceled": "",
                  "base_shipping_discount_amount": "",
                  "base_shipping_discount_tax_compensation_amnt": "",
                  "base_shipping_incl_tax": "",
                  "base_shipping_invoiced": "",
                  "base_shipping_refunded": "",
                  "base_shipping_tax_amount": "",
                  "base_shipping_tax_refunded": "",
                  "extension_attributes": {},
                  "shipping_amount": "",
                  "shipping_canceled": "",
                  "shipping_discount_amount": "",
                  "shipping_discount_tax_compensation_amount": "",
                  "shipping_incl_tax": "",
                  "shipping_invoiced": "",
                  "shipping_refunded": "",
                  "shipping_tax_amount": "",
                  "shipping_tax_refunded": ""
                }
              },
              "stock_id": 0
            }
          ]
        },
        "forced_shipment_with_invoice": 0,
        "global_currency_code": "",
        "grand_total": "",
        "hold_before_state": "",
        "hold_before_status": "",
        "increment_id": "",
        "is_virtual": 0,
        "items": [
          {}
        ],
        "order_currency_code": "",
        "original_increment_id": "",
        "payment": {
          "account_status": "",
          "additional_data": "",
          "additional_information": [],
          "address_status": "",
          "amount_authorized": "",
          "amount_canceled": "",
          "amount_ordered": "",
          "amount_paid": "",
          "amount_refunded": "",
          "anet_trans_method": "",
          "base_amount_authorized": "",
          "base_amount_canceled": "",
          "base_amount_ordered": "",
          "base_amount_paid": "",
          "base_amount_paid_online": "",
          "base_amount_refunded": "",
          "base_amount_refunded_online": "",
          "base_shipping_amount": "",
          "base_shipping_captured": "",
          "base_shipping_refunded": "",
          "cc_approval": "",
          "cc_avs_status": "",
          "cc_cid_status": "",
          "cc_debug_request_body": "",
          "cc_debug_response_body": "",
          "cc_debug_response_serialized": "",
          "cc_exp_month": "",
          "cc_exp_year": "",
          "cc_last4": "",
          "cc_number_enc": "",
          "cc_owner": "",
          "cc_secure_verify": "",
          "cc_ss_issue": "",
          "cc_ss_start_month": "",
          "cc_ss_start_year": "",
          "cc_status": "",
          "cc_status_description": "",
          "cc_trans_id": "",
          "cc_type": "",
          "echeck_account_name": "",
          "echeck_account_type": "",
          "echeck_bank_name": "",
          "echeck_routing_number": "",
          "echeck_type": "",
          "entity_id": 0,
          "extension_attributes": {
            "vault_payment_token": {
              "created_at": "",
              "customer_id": 0,
              "entity_id": 0,
              "expires_at": "",
              "gateway_token": "",
              "is_active": false,
              "is_visible": false,
              "payment_method_code": "",
              "public_hash": "",
              "token_details": "",
              "type": ""
            }
          },
          "last_trans_id": "",
          "method": "",
          "parent_id": 0,
          "po_number": "",
          "protection_eligibility": "",
          "quote_payment_id": 0,
          "shipping_amount": "",
          "shipping_captured": "",
          "shipping_refunded": ""
        },
        "payment_auth_expiration": 0,
        "payment_authorization_amount": "",
        "protect_code": "",
        "quote_address_id": 0,
        "quote_id": 0,
        "relation_child_id": "",
        "relation_child_real_id": "",
        "relation_parent_id": "",
        "relation_parent_real_id": "",
        "remote_ip": "",
        "shipping_amount": "",
        "shipping_canceled": "",
        "shipping_description": "",
        "shipping_discount_amount": "",
        "shipping_discount_tax_compensation_amount": "",
        "shipping_incl_tax": "",
        "shipping_invoiced": "",
        "shipping_refunded": "",
        "shipping_tax_amount": "",
        "shipping_tax_refunded": "",
        "state": "",
        "status": "",
        "status_histories": [
          {
            "comment": "",
            "created_at": "",
            "entity_id": 0,
            "entity_name": "",
            "extension_attributes": {},
            "is_customer_notified": 0,
            "is_visible_on_front": 0,
            "parent_id": 0,
            "status": ""
          }
        ],
        "store_currency_code": "",
        "store_id": 0,
        "store_name": "",
        "store_to_base_rate": "",
        "store_to_order_rate": "",
        "subtotal": "",
        "subtotal_canceled": "",
        "subtotal_incl_tax": "",
        "subtotal_invoiced": "",
        "subtotal_refunded": "",
        "tax_amount": "",
        "tax_canceled": "",
        "tax_invoiced": "",
        "tax_refunded": "",
        "total_canceled": "",
        "total_due": "",
        "total_invoiced": "",
        "total_item_count": 0,
        "total_offline_refunded": "",
        "total_online_refunded": "",
        "total_paid": "",
        "total_qty_ordered": "",
        "total_refunded": "",
        "updated_at": "",
        "weight": "",
        "x_forwarded_for": ""
      },
      "vertex_tax_calculation_shipping_address": {}
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "is_used_for_refund": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "total_qty": "",
    "transaction_id": "",
    "updated_at": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/invoices/' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_refunded": "",
    "billing_address_id": 0,
    "can_void_flag": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": "",
      "vertex_tax_calculation_billing_address": {
        "address_type": "",
        "city": "",
        "company": "",
        "country_id": "",
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "entity_id": 0,
        "extension_attributes": {
          "checkout_fields": [
            {
              "attribute_code": "",
              "value": ""
            }
          ]
        },
        "fax": "",
        "firstname": "",
        "lastname": "",
        "middlename": "",
        "parent_id": 0,
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": "",
        "vat_is_valid": 0,
        "vat_request_date": "",
        "vat_request_id": "",
        "vat_request_success": 0
      },
      "vertex_tax_calculation_order": {
        "adjustment_negative": "",
        "adjustment_positive": "",
        "applied_rule_ids": "",
        "base_adjustment_negative": "",
        "base_adjustment_positive": "",
        "base_currency_code": "",
        "base_discount_amount": "",
        "base_discount_canceled": "",
        "base_discount_invoiced": "",
        "base_discount_refunded": "",
        "base_discount_tax_compensation_amount": "",
        "base_discount_tax_compensation_invoiced": "",
        "base_discount_tax_compensation_refunded": "",
        "base_grand_total": "",
        "base_shipping_amount": "",
        "base_shipping_canceled": "",
        "base_shipping_discount_amount": "",
        "base_shipping_discount_tax_compensation_amnt": "",
        "base_shipping_incl_tax": "",
        "base_shipping_invoiced": "",
        "base_shipping_refunded": "",
        "base_shipping_tax_amount": "",
        "base_shipping_tax_refunded": "",
        "base_subtotal": "",
        "base_subtotal_canceled": "",
        "base_subtotal_incl_tax": "",
        "base_subtotal_invoiced": "",
        "base_subtotal_refunded": "",
        "base_tax_amount": "",
        "base_tax_canceled": "",
        "base_tax_invoiced": "",
        "base_tax_refunded": "",
        "base_to_global_rate": "",
        "base_to_order_rate": "",
        "base_total_canceled": "",
        "base_total_due": "",
        "base_total_invoiced": "",
        "base_total_invoiced_cost": "",
        "base_total_offline_refunded": "",
        "base_total_online_refunded": "",
        "base_total_paid": "",
        "base_total_qty_ordered": "",
        "base_total_refunded": "",
        "billing_address": {},
        "billing_address_id": 0,
        "can_ship_partially": 0,
        "can_ship_partially_item": 0,
        "coupon_code": "",
        "created_at": "",
        "customer_dob": "",
        "customer_email": "",
        "customer_firstname": "",
        "customer_gender": 0,
        "customer_group_id": 0,
        "customer_id": 0,
        "customer_is_guest": 0,
        "customer_lastname": "",
        "customer_middlename": "",
        "customer_note": "",
        "customer_note_notify": 0,
        "customer_prefix": "",
        "customer_suffix": "",
        "customer_taxvat": "",
        "discount_amount": "",
        "discount_canceled": "",
        "discount_description": "",
        "discount_invoiced": "",
        "discount_refunded": "",
        "discount_tax_compensation_amount": "",
        "discount_tax_compensation_invoiced": "",
        "discount_tax_compensation_refunded": "",
        "edit_increment": 0,
        "email_sent": 0,
        "entity_id": 0,
        "ext_customer_id": "",
        "ext_order_id": "",
        "extension_attributes": {
          "amazon_order_reference_id": "",
          "applied_taxes": [
            {
              "amount": "",
              "base_amount": "",
              "code": "",
              "extension_attributes": {
                "rates": [
                  {
                    "code": "",
                    "extension_attributes": {},
                    "percent": "",
                    "title": ""
                  }
                ]
              },
              "percent": "",
              "title": ""
            }
          ],
          "base_customer_balance_amount": "",
          "base_customer_balance_invoiced": "",
          "base_customer_balance_refunded": "",
          "base_customer_balance_total_refunded": "",
          "base_gift_cards_amount": "",
          "base_gift_cards_invoiced": "",
          "base_gift_cards_refunded": "",
          "base_reward_currency_amount": "",
          "company_order_attributes": {
            "company_id": 0,
            "company_name": "",
            "extension_attributes": {},
            "order_id": 0
          },
          "converting_from_quote": false,
          "customer_balance_amount": "",
          "customer_balance_invoiced": "",
          "customer_balance_refunded": "",
          "customer_balance_total_refunded": "",
          "gift_cards": [
            {
              "amount": "",
              "base_amount": "",
              "code": "",
              "id": 0
            }
          ],
          "gift_cards_amount": "",
          "gift_cards_invoiced": "",
          "gift_cards_refunded": "",
          "gift_message": {
            "customer_id": 0,
            "extension_attributes": {
              "entity_id": "",
              "entity_type": "",
              "wrapping_add_printed_card": false,
              "wrapping_allow_gift_receipt": false,
              "wrapping_id": 0
            },
            "gift_message_id": 0,
            "message": "",
            "recipient": "",
            "sender": ""
          },
          "gw_add_card": "",
          "gw_allow_gift_receipt": "",
          "gw_base_price": "",
          "gw_base_price_incl_tax": "",
          "gw_base_price_invoiced": "",
          "gw_base_price_refunded": "",
          "gw_base_tax_amount": "",
          "gw_base_tax_amount_invoiced": "",
          "gw_base_tax_amount_refunded": "",
          "gw_card_base_price": "",
          "gw_card_base_price_incl_tax": "",
          "gw_card_base_price_invoiced": "",
          "gw_card_base_price_refunded": "",
          "gw_card_base_tax_amount": "",
          "gw_card_base_tax_invoiced": "",
          "gw_card_base_tax_refunded": "",
          "gw_card_price": "",
          "gw_card_price_incl_tax": "",
          "gw_card_price_invoiced": "",
          "gw_card_price_refunded": "",
          "gw_card_tax_amount": "",
          "gw_card_tax_invoiced": "",
          "gw_card_tax_refunded": "",
          "gw_id": "",
          "gw_items_base_price": "",
          "gw_items_base_price_incl_tax": "",
          "gw_items_base_price_invoiced": "",
          "gw_items_base_price_refunded": "",
          "gw_items_base_tax_amount": "",
          "gw_items_base_tax_invoiced": "",
          "gw_items_base_tax_refunded": "",
          "gw_items_price": "",
          "gw_items_price_incl_tax": "",
          "gw_items_price_invoiced": "",
          "gw_items_price_refunded": "",
          "gw_items_tax_amount": "",
          "gw_items_tax_invoiced": "",
          "gw_items_tax_refunded": "",
          "gw_price": "",
          "gw_price_incl_tax": "",
          "gw_price_invoiced": "",
          "gw_price_refunded": "",
          "gw_tax_amount": "",
          "gw_tax_amount_invoiced": "",
          "gw_tax_amount_refunded": "",
          "item_applied_taxes": [
            {
              "applied_taxes": [
                {}
              ],
              "associated_item_id": 0,
              "extension_attributes": {},
              "item_id": 0,
              "type": ""
            }
          ],
          "payment_additional_info": [
            {
              "key": "",
              "value": ""
            }
          ],
          "reward_currency_amount": "",
          "reward_points_balance": 0,
          "shipping_assignments": [
            {
              "extension_attributes": {},
              "items": [
                {
                  "additional_data": "",
                  "amount_refunded": "",
                  "applied_rule_ids": "",
                  "base_amount_refunded": "",
                  "base_cost": "",
                  "base_discount_amount": "",
                  "base_discount_invoiced": "",
                  "base_discount_refunded": "",
                  "base_discount_tax_compensation_amount": "",
                  "base_discount_tax_compensation_invoiced": "",
                  "base_discount_tax_compensation_refunded": "",
                  "base_original_price": "",
                  "base_price": "",
                  "base_price_incl_tax": "",
                  "base_row_invoiced": "",
                  "base_row_total": "",
                  "base_row_total_incl_tax": "",
                  "base_tax_amount": "",
                  "base_tax_before_discount": "",
                  "base_tax_invoiced": "",
                  "base_tax_refunded": "",
                  "base_weee_tax_applied_amount": "",
                  "base_weee_tax_applied_row_amnt": "",
                  "base_weee_tax_disposition": "",
                  "base_weee_tax_row_disposition": "",
                  "created_at": "",
                  "description": "",
                  "discount_amount": "",
                  "discount_invoiced": "",
                  "discount_percent": "",
                  "discount_refunded": "",
                  "discount_tax_compensation_amount": "",
                  "discount_tax_compensation_canceled": "",
                  "discount_tax_compensation_invoiced": "",
                  "discount_tax_compensation_refunded": "",
                  "event_id": 0,
                  "ext_order_item_id": "",
                  "extension_attributes": {
                    "gift_message": {},
                    "gw_base_price": "",
                    "gw_base_price_invoiced": "",
                    "gw_base_price_refunded": "",
                    "gw_base_tax_amount": "",
                    "gw_base_tax_amount_invoiced": "",
                    "gw_base_tax_amount_refunded": "",
                    "gw_id": "",
                    "gw_price": "",
                    "gw_price_invoiced": "",
                    "gw_price_refunded": "",
                    "gw_tax_amount": "",
                    "gw_tax_amount_invoiced": "",
                    "gw_tax_amount_refunded": "",
                    "invoice_text_codes": [],
                    "tax_codes": [],
                    "vertex_tax_codes": []
                  },
                  "free_shipping": 0,
                  "gw_base_price": "",
                  "gw_base_price_invoiced": "",
                  "gw_base_price_refunded": "",
                  "gw_base_tax_amount": "",
                  "gw_base_tax_amount_invoiced": "",
                  "gw_base_tax_amount_refunded": "",
                  "gw_id": 0,
                  "gw_price": "",
                  "gw_price_invoiced": "",
                  "gw_price_refunded": "",
                  "gw_tax_amount": "",
                  "gw_tax_amount_invoiced": "",
                  "gw_tax_amount_refunded": "",
                  "is_qty_decimal": 0,
                  "is_virtual": 0,
                  "item_id": 0,
                  "locked_do_invoice": 0,
                  "locked_do_ship": 0,
                  "name": "",
                  "no_discount": 0,
                  "order_id": 0,
                  "original_price": "",
                  "parent_item": "",
                  "parent_item_id": 0,
                  "price": "",
                  "price_incl_tax": "",
                  "product_id": 0,
                  "product_option": {
                    "extension_attributes": {
                      "bundle_options": [
                        {
                          "extension_attributes": {},
                          "option_id": 0,
                          "option_qty": 0,
                          "option_selections": []
                        }
                      ],
                      "configurable_item_options": [
                        {
                          "extension_attributes": {},
                          "option_id": "",
                          "option_value": 0
                        }
                      ],
                      "custom_options": [
                        {
                          "extension_attributes": {
                            "file_info": {
                              "base64_encoded_data": "",
                              "name": "",
                              "type": ""
                            }
                          },
                          "option_id": "",
                          "option_value": ""
                        }
                      ],
                      "downloadable_option": {
                        "downloadable_links": []
                      },
                      "giftcard_item_option": {
                        "custom_giftcard_amount": "",
                        "extension_attributes": {},
                        "giftcard_amount": "",
                        "giftcard_message": "",
                        "giftcard_recipient_email": "",
                        "giftcard_recipient_name": "",
                        "giftcard_sender_email": "",
                        "giftcard_sender_name": ""
                      }
                    }
                  },
                  "product_type": "",
                  "qty_backordered": "",
                  "qty_canceled": "",
                  "qty_invoiced": "",
                  "qty_ordered": "",
                  "qty_refunded": "",
                  "qty_returned": "",
                  "qty_shipped": "",
                  "quote_item_id": 0,
                  "row_invoiced": "",
                  "row_total": "",
                  "row_total_incl_tax": "",
                  "row_weight": "",
                  "sku": "",
                  "store_id": 0,
                  "tax_amount": "",
                  "tax_before_discount": "",
                  "tax_canceled": "",
                  "tax_invoiced": "",
                  "tax_percent": "",
                  "tax_refunded": "",
                  "updated_at": "",
                  "weee_tax_applied": "",
                  "weee_tax_applied_amount": "",
                  "weee_tax_applied_row_amount": "",
                  "weee_tax_disposition": "",
                  "weee_tax_row_disposition": "",
                  "weight": ""
                }
              ],
              "shipping": {
                "address": {},
                "extension_attributes": {
                  "collection_point": {
                    "city": "",
                    "collection_point_id": "",
                    "country": "",
                    "name": "",
                    "postcode": "",
                    "recipient_address_id": 0,
                    "region": "",
                    "street": []
                  },
                  "ext_order_id": "",
                  "shipping_experience": {
                    "code": "",
                    "cost": "",
                    "label": ""
                  }
                },
                "method": "",
                "total": {
                  "base_shipping_amount": "",
                  "base_shipping_canceled": "",
                  "base_shipping_discount_amount": "",
                  "base_shipping_discount_tax_compensation_amnt": "",
                  "base_shipping_incl_tax": "",
                  "base_shipping_invoiced": "",
                  "base_shipping_refunded": "",
                  "base_shipping_tax_amount": "",
                  "base_shipping_tax_refunded": "",
                  "extension_attributes": {},
                  "shipping_amount": "",
                  "shipping_canceled": "",
                  "shipping_discount_amount": "",
                  "shipping_discount_tax_compensation_amount": "",
                  "shipping_incl_tax": "",
                  "shipping_invoiced": "",
                  "shipping_refunded": "",
                  "shipping_tax_amount": "",
                  "shipping_tax_refunded": ""
                }
              },
              "stock_id": 0
            }
          ]
        },
        "forced_shipment_with_invoice": 0,
        "global_currency_code": "",
        "grand_total": "",
        "hold_before_state": "",
        "hold_before_status": "",
        "increment_id": "",
        "is_virtual": 0,
        "items": [
          {}
        ],
        "order_currency_code": "",
        "original_increment_id": "",
        "payment": {
          "account_status": "",
          "additional_data": "",
          "additional_information": [],
          "address_status": "",
          "amount_authorized": "",
          "amount_canceled": "",
          "amount_ordered": "",
          "amount_paid": "",
          "amount_refunded": "",
          "anet_trans_method": "",
          "base_amount_authorized": "",
          "base_amount_canceled": "",
          "base_amount_ordered": "",
          "base_amount_paid": "",
          "base_amount_paid_online": "",
          "base_amount_refunded": "",
          "base_amount_refunded_online": "",
          "base_shipping_amount": "",
          "base_shipping_captured": "",
          "base_shipping_refunded": "",
          "cc_approval": "",
          "cc_avs_status": "",
          "cc_cid_status": "",
          "cc_debug_request_body": "",
          "cc_debug_response_body": "",
          "cc_debug_response_serialized": "",
          "cc_exp_month": "",
          "cc_exp_year": "",
          "cc_last4": "",
          "cc_number_enc": "",
          "cc_owner": "",
          "cc_secure_verify": "",
          "cc_ss_issue": "",
          "cc_ss_start_month": "",
          "cc_ss_start_year": "",
          "cc_status": "",
          "cc_status_description": "",
          "cc_trans_id": "",
          "cc_type": "",
          "echeck_account_name": "",
          "echeck_account_type": "",
          "echeck_bank_name": "",
          "echeck_routing_number": "",
          "echeck_type": "",
          "entity_id": 0,
          "extension_attributes": {
            "vault_payment_token": {
              "created_at": "",
              "customer_id": 0,
              "entity_id": 0,
              "expires_at": "",
              "gateway_token": "",
              "is_active": false,
              "is_visible": false,
              "payment_method_code": "",
              "public_hash": "",
              "token_details": "",
              "type": ""
            }
          },
          "last_trans_id": "",
          "method": "",
          "parent_id": 0,
          "po_number": "",
          "protection_eligibility": "",
          "quote_payment_id": 0,
          "shipping_amount": "",
          "shipping_captured": "",
          "shipping_refunded": ""
        },
        "payment_auth_expiration": 0,
        "payment_authorization_amount": "",
        "protect_code": "",
        "quote_address_id": 0,
        "quote_id": 0,
        "relation_child_id": "",
        "relation_child_real_id": "",
        "relation_parent_id": "",
        "relation_parent_real_id": "",
        "remote_ip": "",
        "shipping_amount": "",
        "shipping_canceled": "",
        "shipping_description": "",
        "shipping_discount_amount": "",
        "shipping_discount_tax_compensation_amount": "",
        "shipping_incl_tax": "",
        "shipping_invoiced": "",
        "shipping_refunded": "",
        "shipping_tax_amount": "",
        "shipping_tax_refunded": "",
        "state": "",
        "status": "",
        "status_histories": [
          {
            "comment": "",
            "created_at": "",
            "entity_id": 0,
            "entity_name": "",
            "extension_attributes": {},
            "is_customer_notified": 0,
            "is_visible_on_front": 0,
            "parent_id": 0,
            "status": ""
          }
        ],
        "store_currency_code": "",
        "store_id": 0,
        "store_name": "",
        "store_to_base_rate": "",
        "store_to_order_rate": "",
        "subtotal": "",
        "subtotal_canceled": "",
        "subtotal_incl_tax": "",
        "subtotal_invoiced": "",
        "subtotal_refunded": "",
        "tax_amount": "",
        "tax_canceled": "",
        "tax_invoiced": "",
        "tax_refunded": "",
        "total_canceled": "",
        "total_due": "",
        "total_invoiced": "",
        "total_item_count": 0,
        "total_offline_refunded": "",
        "total_online_refunded": "",
        "total_paid": "",
        "total_qty_ordered": "",
        "total_refunded": "",
        "updated_at": "",
        "weight": "",
        "x_forwarded_for": ""
      },
      "vertex_tax_calculation_shipping_address": {}
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "is_used_for_refund": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "total_qty": "",
    "transaction_id": "",
    "updated_at": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"entity\": {\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address_id\": 0,\n    \"can_void_flag\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"vertex_tax_calculation_billing_address\": {\n        \"address_type\": \"\",\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"customer_address_id\": 0,\n        \"customer_id\": 0,\n        \"email\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"checkout_fields\": [\n            {\n              \"attribute_code\": \"\",\n              \"value\": \"\"\n            }\n          ]\n        },\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"parent_id\": 0,\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": \"\",\n        \"region_code\": \"\",\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\",\n        \"vat_is_valid\": 0,\n        \"vat_request_date\": \"\",\n        \"vat_request_id\": \"\",\n        \"vat_request_success\": 0\n      },\n      \"vertex_tax_calculation_order\": {\n        \"adjustment_negative\": \"\",\n        \"adjustment_positive\": \"\",\n        \"applied_rule_ids\": \"\",\n        \"base_adjustment_negative\": \"\",\n        \"base_adjustment_positive\": \"\",\n        \"base_currency_code\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_canceled\": \"\",\n        \"base_discount_invoiced\": \"\",\n        \"base_discount_refunded\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_discount_tax_compensation_invoiced\": \"\",\n        \"base_discount_tax_compensation_refunded\": \"\",\n        \"base_grand_total\": \"\",\n        \"base_shipping_amount\": \"\",\n        \"base_shipping_canceled\": \"\",\n        \"base_shipping_discount_amount\": \"\",\n        \"base_shipping_discount_tax_compensation_amnt\": \"\",\n        \"base_shipping_incl_tax\": \"\",\n        \"base_shipping_invoiced\": \"\",\n        \"base_shipping_refunded\": \"\",\n        \"base_shipping_tax_amount\": \"\",\n        \"base_shipping_tax_refunded\": \"\",\n        \"base_subtotal\": \"\",\n        \"base_subtotal_canceled\": \"\",\n        \"base_subtotal_incl_tax\": \"\",\n        \"base_subtotal_invoiced\": \"\",\n        \"base_subtotal_refunded\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_tax_canceled\": \"\",\n        \"base_tax_invoiced\": \"\",\n        \"base_tax_refunded\": \"\",\n        \"base_to_global_rate\": \"\",\n        \"base_to_order_rate\": \"\",\n        \"base_total_canceled\": \"\",\n        \"base_total_due\": \"\",\n        \"base_total_invoiced\": \"\",\n        \"base_total_invoiced_cost\": \"\",\n        \"base_total_offline_refunded\": \"\",\n        \"base_total_online_refunded\": \"\",\n        \"base_total_paid\": \"\",\n        \"base_total_qty_ordered\": \"\",\n        \"base_total_refunded\": \"\",\n        \"billing_address\": {},\n        \"billing_address_id\": 0,\n        \"can_ship_partially\": 0,\n        \"can_ship_partially_item\": 0,\n        \"coupon_code\": \"\",\n        \"created_at\": \"\",\n        \"customer_dob\": \"\",\n        \"customer_email\": \"\",\n        \"customer_firstname\": \"\",\n        \"customer_gender\": 0,\n        \"customer_group_id\": 0,\n        \"customer_id\": 0,\n        \"customer_is_guest\": 0,\n        \"customer_lastname\": \"\",\n        \"customer_middlename\": \"\",\n        \"customer_note\": \"\",\n        \"customer_note_notify\": 0,\n        \"customer_prefix\": \"\",\n        \"customer_suffix\": \"\",\n        \"customer_taxvat\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_canceled\": \"\",\n        \"discount_description\": \"\",\n        \"discount_invoiced\": \"\",\n        \"discount_refunded\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"discount_tax_compensation_invoiced\": \"\",\n        \"discount_tax_compensation_refunded\": \"\",\n        \"edit_increment\": 0,\n        \"email_sent\": 0,\n        \"entity_id\": 0,\n        \"ext_customer_id\": \"\",\n        \"ext_order_id\": \"\",\n        \"extension_attributes\": {\n          \"amazon_order_reference_id\": \"\",\n          \"applied_taxes\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"extension_attributes\": {\n                \"rates\": [\n                  {\n                    \"code\": \"\",\n                    \"extension_attributes\": {},\n                    \"percent\": \"\",\n                    \"title\": \"\"\n                  }\n                ]\n              },\n              \"percent\": \"\",\n              \"title\": \"\"\n            }\n          ],\n          \"base_customer_balance_amount\": \"\",\n          \"base_customer_balance_invoiced\": \"\",\n          \"base_customer_balance_refunded\": \"\",\n          \"base_customer_balance_total_refunded\": \"\",\n          \"base_gift_cards_amount\": \"\",\n          \"base_gift_cards_invoiced\": \"\",\n          \"base_gift_cards_refunded\": \"\",\n          \"base_reward_currency_amount\": \"\",\n          \"company_order_attributes\": {\n            \"company_id\": 0,\n            \"company_name\": \"\",\n            \"extension_attributes\": {},\n            \"order_id\": 0\n          },\n          \"converting_from_quote\": false,\n          \"customer_balance_amount\": \"\",\n          \"customer_balance_invoiced\": \"\",\n          \"customer_balance_refunded\": \"\",\n          \"customer_balance_total_refunded\": \"\",\n          \"gift_cards\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"id\": 0\n            }\n          ],\n          \"gift_cards_amount\": \"\",\n          \"gift_cards_invoiced\": \"\",\n          \"gift_cards_refunded\": \"\",\n          \"gift_message\": {\n            \"customer_id\": 0,\n            \"extension_attributes\": {\n              \"entity_id\": \"\",\n              \"entity_type\": \"\",\n              \"wrapping_add_printed_card\": false,\n              \"wrapping_allow_gift_receipt\": false,\n              \"wrapping_id\": 0\n            },\n            \"gift_message_id\": 0,\n            \"message\": \"\",\n            \"recipient\": \"\",\n            \"sender\": \"\"\n          },\n          \"gw_add_card\": \"\",\n          \"gw_allow_gift_receipt\": \"\",\n          \"gw_base_price\": \"\",\n          \"gw_base_price_incl_tax\": \"\",\n          \"gw_base_price_invoiced\": \"\",\n          \"gw_base_price_refunded\": \"\",\n          \"gw_base_tax_amount\": \"\",\n          \"gw_base_tax_amount_invoiced\": \"\",\n          \"gw_base_tax_amount_refunded\": \"\",\n          \"gw_card_base_price\": \"\",\n          \"gw_card_base_price_incl_tax\": \"\",\n          \"gw_card_base_price_invoiced\": \"\",\n          \"gw_card_base_price_refunded\": \"\",\n          \"gw_card_base_tax_amount\": \"\",\n          \"gw_card_base_tax_invoiced\": \"\",\n          \"gw_card_base_tax_refunded\": \"\",\n          \"gw_card_price\": \"\",\n          \"gw_card_price_incl_tax\": \"\",\n          \"gw_card_price_invoiced\": \"\",\n          \"gw_card_price_refunded\": \"\",\n          \"gw_card_tax_amount\": \"\",\n          \"gw_card_tax_invoiced\": \"\",\n          \"gw_card_tax_refunded\": \"\",\n          \"gw_id\": \"\",\n          \"gw_items_base_price\": \"\",\n          \"gw_items_base_price_incl_tax\": \"\",\n          \"gw_items_base_price_invoiced\": \"\",\n          \"gw_items_base_price_refunded\": \"\",\n          \"gw_items_base_tax_amount\": \"\",\n          \"gw_items_base_tax_invoiced\": \"\",\n          \"gw_items_base_tax_refunded\": \"\",\n          \"gw_items_price\": \"\",\n          \"gw_items_price_incl_tax\": \"\",\n          \"gw_items_price_invoiced\": \"\",\n          \"gw_items_price_refunded\": \"\",\n          \"gw_items_tax_amount\": \"\",\n          \"gw_items_tax_invoiced\": \"\",\n          \"gw_items_tax_refunded\": \"\",\n          \"gw_price\": \"\",\n          \"gw_price_incl_tax\": \"\",\n          \"gw_price_invoiced\": \"\",\n          \"gw_price_refunded\": \"\",\n          \"gw_tax_amount\": \"\",\n          \"gw_tax_amount_invoiced\": \"\",\n          \"gw_tax_amount_refunded\": \"\",\n          \"item_applied_taxes\": [\n            {\n              \"applied_taxes\": [\n                {}\n              ],\n              \"associated_item_id\": 0,\n              \"extension_attributes\": {},\n              \"item_id\": 0,\n              \"type\": \"\"\n            }\n          ],\n          \"payment_additional_info\": [\n            {\n              \"key\": \"\",\n              \"value\": \"\"\n            }\n          ],\n          \"reward_currency_amount\": \"\",\n          \"reward_points_balance\": 0,\n          \"shipping_assignments\": [\n            {\n              \"extension_attributes\": {},\n              \"items\": [\n                {\n                  \"additional_data\": \"\",\n                  \"amount_refunded\": \"\",\n                  \"applied_rule_ids\": \"\",\n                  \"base_amount_refunded\": \"\",\n                  \"base_cost\": \"\",\n                  \"base_discount_amount\": \"\",\n                  \"base_discount_invoiced\": \"\",\n                  \"base_discount_refunded\": \"\",\n                  \"base_discount_tax_compensation_amount\": \"\",\n                  \"base_discount_tax_compensation_invoiced\": \"\",\n                  \"base_discount_tax_compensation_refunded\": \"\",\n                  \"base_original_price\": \"\",\n                  \"base_price\": \"\",\n                  \"base_price_incl_tax\": \"\",\n                  \"base_row_invoiced\": \"\",\n                  \"base_row_total\": \"\",\n                  \"base_row_total_incl_tax\": \"\",\n                  \"base_tax_amount\": \"\",\n                  \"base_tax_before_discount\": \"\",\n                  \"base_tax_invoiced\": \"\",\n                  \"base_tax_refunded\": \"\",\n                  \"base_weee_tax_applied_amount\": \"\",\n                  \"base_weee_tax_applied_row_amnt\": \"\",\n                  \"base_weee_tax_disposition\": \"\",\n                  \"base_weee_tax_row_disposition\": \"\",\n                  \"created_at\": \"\",\n                  \"description\": \"\",\n                  \"discount_amount\": \"\",\n                  \"discount_invoiced\": \"\",\n                  \"discount_percent\": \"\",\n                  \"discount_refunded\": \"\",\n                  \"discount_tax_compensation_amount\": \"\",\n                  \"discount_tax_compensation_canceled\": \"\",\n                  \"discount_tax_compensation_invoiced\": \"\",\n                  \"discount_tax_compensation_refunded\": \"\",\n                  \"event_id\": 0,\n                  \"ext_order_item_id\": \"\",\n                  \"extension_attributes\": {\n                    \"gift_message\": {},\n                    \"gw_base_price\": \"\",\n                    \"gw_base_price_invoiced\": \"\",\n                    \"gw_base_price_refunded\": \"\",\n                    \"gw_base_tax_amount\": \"\",\n                    \"gw_base_tax_amount_invoiced\": \"\",\n                    \"gw_base_tax_amount_refunded\": \"\",\n                    \"gw_id\": \"\",\n                    \"gw_price\": \"\",\n                    \"gw_price_invoiced\": \"\",\n                    \"gw_price_refunded\": \"\",\n                    \"gw_tax_amount\": \"\",\n                    \"gw_tax_amount_invoiced\": \"\",\n                    \"gw_tax_amount_refunded\": \"\",\n                    \"invoice_text_codes\": [],\n                    \"tax_codes\": [],\n                    \"vertex_tax_codes\": []\n                  },\n                  \"free_shipping\": 0,\n                  \"gw_base_price\": \"\",\n                  \"gw_base_price_invoiced\": \"\",\n                  \"gw_base_price_refunded\": \"\",\n                  \"gw_base_tax_amount\": \"\",\n                  \"gw_base_tax_amount_invoiced\": \"\",\n                  \"gw_base_tax_amount_refunded\": \"\",\n                  \"gw_id\": 0,\n                  \"gw_price\": \"\",\n                  \"gw_price_invoiced\": \"\",\n                  \"gw_price_refunded\": \"\",\n                  \"gw_tax_amount\": \"\",\n                  \"gw_tax_amount_invoiced\": \"\",\n                  \"gw_tax_amount_refunded\": \"\",\n                  \"is_qty_decimal\": 0,\n                  \"is_virtual\": 0,\n                  \"item_id\": 0,\n                  \"locked_do_invoice\": 0,\n                  \"locked_do_ship\": 0,\n                  \"name\": \"\",\n                  \"no_discount\": 0,\n                  \"order_id\": 0,\n                  \"original_price\": \"\",\n                  \"parent_item\": \"\",\n                  \"parent_item_id\": 0,\n                  \"price\": \"\",\n                  \"price_incl_tax\": \"\",\n                  \"product_id\": 0,\n                  \"product_option\": {\n                    \"extension_attributes\": {\n                      \"bundle_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": 0,\n                          \"option_qty\": 0,\n                          \"option_selections\": []\n                        }\n                      ],\n                      \"configurable_item_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": \"\",\n                          \"option_value\": 0\n                        }\n                      ],\n                      \"custom_options\": [\n                        {\n                          \"extension_attributes\": {\n                            \"file_info\": {\n                              \"base64_encoded_data\": \"\",\n                              \"name\": \"\",\n                              \"type\": \"\"\n                            }\n                          },\n                          \"option_id\": \"\",\n                          \"option_value\": \"\"\n                        }\n                      ],\n                      \"downloadable_option\": {\n                        \"downloadable_links\": []\n                      },\n                      \"giftcard_item_option\": {\n                        \"custom_giftcard_amount\": \"\",\n                        \"extension_attributes\": {},\n                        \"giftcard_amount\": \"\",\n                        \"giftcard_message\": \"\",\n                        \"giftcard_recipient_email\": \"\",\n                        \"giftcard_recipient_name\": \"\",\n                        \"giftcard_sender_email\": \"\",\n                        \"giftcard_sender_name\": \"\"\n                      }\n                    }\n                  },\n                  \"product_type\": \"\",\n                  \"qty_backordered\": \"\",\n                  \"qty_canceled\": \"\",\n                  \"qty_invoiced\": \"\",\n                  \"qty_ordered\": \"\",\n                  \"qty_refunded\": \"\",\n                  \"qty_returned\": \"\",\n                  \"qty_shipped\": \"\",\n                  \"quote_item_id\": 0,\n                  \"row_invoiced\": \"\",\n                  \"row_total\": \"\",\n                  \"row_total_incl_tax\": \"\",\n                  \"row_weight\": \"\",\n                  \"sku\": \"\",\n                  \"store_id\": 0,\n                  \"tax_amount\": \"\",\n                  \"tax_before_discount\": \"\",\n                  \"tax_canceled\": \"\",\n                  \"tax_invoiced\": \"\",\n                  \"tax_percent\": \"\",\n                  \"tax_refunded\": \"\",\n                  \"updated_at\": \"\",\n                  \"weee_tax_applied\": \"\",\n                  \"weee_tax_applied_amount\": \"\",\n                  \"weee_tax_applied_row_amount\": \"\",\n                  \"weee_tax_disposition\": \"\",\n                  \"weee_tax_row_disposition\": \"\",\n                  \"weight\": \"\"\n                }\n              ],\n              \"shipping\": {\n                \"address\": {},\n                \"extension_attributes\": {\n                  \"collection_point\": {\n                    \"city\": \"\",\n                    \"collection_point_id\": \"\",\n                    \"country\": \"\",\n                    \"name\": \"\",\n                    \"postcode\": \"\",\n                    \"recipient_address_id\": 0,\n                    \"region\": \"\",\n                    \"street\": []\n                  },\n                  \"ext_order_id\": \"\",\n                  \"shipping_experience\": {\n                    \"code\": \"\",\n                    \"cost\": \"\",\n                    \"label\": \"\"\n                  }\n                },\n                \"method\": \"\",\n                \"total\": {\n                  \"base_shipping_amount\": \"\",\n                  \"base_shipping_canceled\": \"\",\n                  \"base_shipping_discount_amount\": \"\",\n                  \"base_shipping_discount_tax_compensation_amnt\": \"\",\n                  \"base_shipping_incl_tax\": \"\",\n                  \"base_shipping_invoiced\": \"\",\n                  \"base_shipping_refunded\": \"\",\n                  \"base_shipping_tax_amount\": \"\",\n                  \"base_shipping_tax_refunded\": \"\",\n                  \"extension_attributes\": {},\n                  \"shipping_amount\": \"\",\n                  \"shipping_canceled\": \"\",\n                  \"shipping_discount_amount\": \"\",\n                  \"shipping_discount_tax_compensation_amount\": \"\",\n                  \"shipping_incl_tax\": \"\",\n                  \"shipping_invoiced\": \"\",\n                  \"shipping_refunded\": \"\",\n                  \"shipping_tax_amount\": \"\",\n                  \"shipping_tax_refunded\": \"\"\n                }\n              },\n              \"stock_id\": 0\n            }\n          ]\n        },\n        \"forced_shipment_with_invoice\": 0,\n        \"global_currency_code\": \"\",\n        \"grand_total\": \"\",\n        \"hold_before_state\": \"\",\n        \"hold_before_status\": \"\",\n        \"increment_id\": \"\",\n        \"is_virtual\": 0,\n        \"items\": [\n          {}\n        ],\n        \"order_currency_code\": \"\",\n        \"original_increment_id\": \"\",\n        \"payment\": {\n          \"account_status\": \"\",\n          \"additional_data\": \"\",\n          \"additional_information\": [],\n          \"address_status\": \"\",\n          \"amount_authorized\": \"\",\n          \"amount_canceled\": \"\",\n          \"amount_ordered\": \"\",\n          \"amount_paid\": \"\",\n          \"amount_refunded\": \"\",\n          \"anet_trans_method\": \"\",\n          \"base_amount_authorized\": \"\",\n          \"base_amount_canceled\": \"\",\n          \"base_amount_ordered\": \"\",\n          \"base_amount_paid\": \"\",\n          \"base_amount_paid_online\": \"\",\n          \"base_amount_refunded\": \"\",\n          \"base_amount_refunded_online\": \"\",\n          \"base_shipping_amount\": \"\",\n          \"base_shipping_captured\": \"\",\n          \"base_shipping_refunded\": \"\",\n          \"cc_approval\": \"\",\n          \"cc_avs_status\": \"\",\n          \"cc_cid_status\": \"\",\n          \"cc_debug_request_body\": \"\",\n          \"cc_debug_response_body\": \"\",\n          \"cc_debug_response_serialized\": \"\",\n          \"cc_exp_month\": \"\",\n          \"cc_exp_year\": \"\",\n          \"cc_last4\": \"\",\n          \"cc_number_enc\": \"\",\n          \"cc_owner\": \"\",\n          \"cc_secure_verify\": \"\",\n          \"cc_ss_issue\": \"\",\n          \"cc_ss_start_month\": \"\",\n          \"cc_ss_start_year\": \"\",\n          \"cc_status\": \"\",\n          \"cc_status_description\": \"\",\n          \"cc_trans_id\": \"\",\n          \"cc_type\": \"\",\n          \"echeck_account_name\": \"\",\n          \"echeck_account_type\": \"\",\n          \"echeck_bank_name\": \"\",\n          \"echeck_routing_number\": \"\",\n          \"echeck_type\": \"\",\n          \"entity_id\": 0,\n          \"extension_attributes\": {\n            \"vault_payment_token\": {\n              \"created_at\": \"\",\n              \"customer_id\": 0,\n              \"entity_id\": 0,\n              \"expires_at\": \"\",\n              \"gateway_token\": \"\",\n              \"is_active\": false,\n              \"is_visible\": false,\n              \"payment_method_code\": \"\",\n              \"public_hash\": \"\",\n              \"token_details\": \"\",\n              \"type\": \"\"\n            }\n          },\n          \"last_trans_id\": \"\",\n          \"method\": \"\",\n          \"parent_id\": 0,\n          \"po_number\": \"\",\n          \"protection_eligibility\": \"\",\n          \"quote_payment_id\": 0,\n          \"shipping_amount\": \"\",\n          \"shipping_captured\": \"\",\n          \"shipping_refunded\": \"\"\n        },\n        \"payment_auth_expiration\": 0,\n        \"payment_authorization_amount\": \"\",\n        \"protect_code\": \"\",\n        \"quote_address_id\": 0,\n        \"quote_id\": 0,\n        \"relation_child_id\": \"\",\n        \"relation_child_real_id\": \"\",\n        \"relation_parent_id\": \"\",\n        \"relation_parent_real_id\": \"\",\n        \"remote_ip\": \"\",\n        \"shipping_amount\": \"\",\n        \"shipping_canceled\": \"\",\n        \"shipping_description\": \"\",\n        \"shipping_discount_amount\": \"\",\n        \"shipping_discount_tax_compensation_amount\": \"\",\n        \"shipping_incl_tax\": \"\",\n        \"shipping_invoiced\": \"\",\n        \"shipping_refunded\": \"\",\n        \"shipping_tax_amount\": \"\",\n        \"shipping_tax_refunded\": \"\",\n        \"state\": \"\",\n        \"status\": \"\",\n        \"status_histories\": [\n          {\n            \"comment\": \"\",\n            \"created_at\": \"\",\n            \"entity_id\": 0,\n            \"entity_name\": \"\",\n            \"extension_attributes\": {},\n            \"is_customer_notified\": 0,\n            \"is_visible_on_front\": 0,\n            \"parent_id\": 0,\n            \"status\": \"\"\n          }\n        ],\n        \"store_currency_code\": \"\",\n        \"store_id\": 0,\n        \"store_name\": \"\",\n        \"store_to_base_rate\": \"\",\n        \"store_to_order_rate\": \"\",\n        \"subtotal\": \"\",\n        \"subtotal_canceled\": \"\",\n        \"subtotal_incl_tax\": \"\",\n        \"subtotal_invoiced\": \"\",\n        \"subtotal_refunded\": \"\",\n        \"tax_amount\": \"\",\n        \"tax_canceled\": \"\",\n        \"tax_invoiced\": \"\",\n        \"tax_refunded\": \"\",\n        \"total_canceled\": \"\",\n        \"total_due\": \"\",\n        \"total_invoiced\": \"\",\n        \"total_item_count\": 0,\n        \"total_offline_refunded\": \"\",\n        \"total_online_refunded\": \"\",\n        \"total_paid\": \"\",\n        \"total_qty_ordered\": \"\",\n        \"total_refunded\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\",\n        \"x_forwarded_for\": \"\"\n      },\n      \"vertex_tax_calculation_shipping_address\": {}\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"is_used_for_refund\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"total_qty\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/invoices/", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/invoices/"

payload = { "entity": {
        "base_currency_code": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_grand_total": "",
        "base_shipping_amount": "",
        "base_shipping_discount_tax_compensation_amnt": "",
        "base_shipping_incl_tax": "",
        "base_shipping_tax_amount": "",
        "base_subtotal": "",
        "base_subtotal_incl_tax": "",
        "base_tax_amount": "",
        "base_to_global_rate": "",
        "base_to_order_rate": "",
        "base_total_refunded": "",
        "billing_address_id": 0,
        "can_void_flag": 0,
        "comments": [
            {
                "comment": "",
                "created_at": "",
                "entity_id": 0,
                "extension_attributes": {},
                "is_customer_notified": 0,
                "is_visible_on_front": 0,
                "parent_id": 0
            }
        ],
        "created_at": "",
        "discount_amount": "",
        "discount_description": "",
        "discount_tax_compensation_amount": "",
        "email_sent": 0,
        "entity_id": 0,
        "extension_attributes": {
            "base_customer_balance_amount": "",
            "base_gift_cards_amount": "",
            "customer_balance_amount": "",
            "gift_cards_amount": "",
            "gw_base_price": "",
            "gw_base_tax_amount": "",
            "gw_card_base_price": "",
            "gw_card_base_tax_amount": "",
            "gw_card_price": "",
            "gw_card_tax_amount": "",
            "gw_items_base_price": "",
            "gw_items_base_tax_amount": "",
            "gw_items_price": "",
            "gw_items_tax_amount": "",
            "gw_price": "",
            "gw_tax_amount": "",
            "vertex_tax_calculation_billing_address": {
                "address_type": "",
                "city": "",
                "company": "",
                "country_id": "",
                "customer_address_id": 0,
                "customer_id": 0,
                "email": "",
                "entity_id": 0,
                "extension_attributes": { "checkout_fields": [
                        {
                            "attribute_code": "",
                            "value": ""
                        }
                    ] },
                "fax": "",
                "firstname": "",
                "lastname": "",
                "middlename": "",
                "parent_id": 0,
                "postcode": "",
                "prefix": "",
                "region": "",
                "region_code": "",
                "region_id": 0,
                "street": [],
                "suffix": "",
                "telephone": "",
                "vat_id": "",
                "vat_is_valid": 0,
                "vat_request_date": "",
                "vat_request_id": "",
                "vat_request_success": 0
            },
            "vertex_tax_calculation_order": {
                "adjustment_negative": "",
                "adjustment_positive": "",
                "applied_rule_ids": "",
                "base_adjustment_negative": "",
                "base_adjustment_positive": "",
                "base_currency_code": "",
                "base_discount_amount": "",
                "base_discount_canceled": "",
                "base_discount_invoiced": "",
                "base_discount_refunded": "",
                "base_discount_tax_compensation_amount": "",
                "base_discount_tax_compensation_invoiced": "",
                "base_discount_tax_compensation_refunded": "",
                "base_grand_total": "",
                "base_shipping_amount": "",
                "base_shipping_canceled": "",
                "base_shipping_discount_amount": "",
                "base_shipping_discount_tax_compensation_amnt": "",
                "base_shipping_incl_tax": "",
                "base_shipping_invoiced": "",
                "base_shipping_refunded": "",
                "base_shipping_tax_amount": "",
                "base_shipping_tax_refunded": "",
                "base_subtotal": "",
                "base_subtotal_canceled": "",
                "base_subtotal_incl_tax": "",
                "base_subtotal_invoiced": "",
                "base_subtotal_refunded": "",
                "base_tax_amount": "",
                "base_tax_canceled": "",
                "base_tax_invoiced": "",
                "base_tax_refunded": "",
                "base_to_global_rate": "",
                "base_to_order_rate": "",
                "base_total_canceled": "",
                "base_total_due": "",
                "base_total_invoiced": "",
                "base_total_invoiced_cost": "",
                "base_total_offline_refunded": "",
                "base_total_online_refunded": "",
                "base_total_paid": "",
                "base_total_qty_ordered": "",
                "base_total_refunded": "",
                "billing_address": {},
                "billing_address_id": 0,
                "can_ship_partially": 0,
                "can_ship_partially_item": 0,
                "coupon_code": "",
                "created_at": "",
                "customer_dob": "",
                "customer_email": "",
                "customer_firstname": "",
                "customer_gender": 0,
                "customer_group_id": 0,
                "customer_id": 0,
                "customer_is_guest": 0,
                "customer_lastname": "",
                "customer_middlename": "",
                "customer_note": "",
                "customer_note_notify": 0,
                "customer_prefix": "",
                "customer_suffix": "",
                "customer_taxvat": "",
                "discount_amount": "",
                "discount_canceled": "",
                "discount_description": "",
                "discount_invoiced": "",
                "discount_refunded": "",
                "discount_tax_compensation_amount": "",
                "discount_tax_compensation_invoiced": "",
                "discount_tax_compensation_refunded": "",
                "edit_increment": 0,
                "email_sent": 0,
                "entity_id": 0,
                "ext_customer_id": "",
                "ext_order_id": "",
                "extension_attributes": {
                    "amazon_order_reference_id": "",
                    "applied_taxes": [
                        {
                            "amount": "",
                            "base_amount": "",
                            "code": "",
                            "extension_attributes": { "rates": [
                                    {
                                        "code": "",
                                        "extension_attributes": {},
                                        "percent": "",
                                        "title": ""
                                    }
                                ] },
                            "percent": "",
                            "title": ""
                        }
                    ],
                    "base_customer_balance_amount": "",
                    "base_customer_balance_invoiced": "",
                    "base_customer_balance_refunded": "",
                    "base_customer_balance_total_refunded": "",
                    "base_gift_cards_amount": "",
                    "base_gift_cards_invoiced": "",
                    "base_gift_cards_refunded": "",
                    "base_reward_currency_amount": "",
                    "company_order_attributes": {
                        "company_id": 0,
                        "company_name": "",
                        "extension_attributes": {},
                        "order_id": 0
                    },
                    "converting_from_quote": False,
                    "customer_balance_amount": "",
                    "customer_balance_invoiced": "",
                    "customer_balance_refunded": "",
                    "customer_balance_total_refunded": "",
                    "gift_cards": [
                        {
                            "amount": "",
                            "base_amount": "",
                            "code": "",
                            "id": 0
                        }
                    ],
                    "gift_cards_amount": "",
                    "gift_cards_invoiced": "",
                    "gift_cards_refunded": "",
                    "gift_message": {
                        "customer_id": 0,
                        "extension_attributes": {
                            "entity_id": "",
                            "entity_type": "",
                            "wrapping_add_printed_card": False,
                            "wrapping_allow_gift_receipt": False,
                            "wrapping_id": 0
                        },
                        "gift_message_id": 0,
                        "message": "",
                        "recipient": "",
                        "sender": ""
                    },
                    "gw_add_card": "",
                    "gw_allow_gift_receipt": "",
                    "gw_base_price": "",
                    "gw_base_price_incl_tax": "",
                    "gw_base_price_invoiced": "",
                    "gw_base_price_refunded": "",
                    "gw_base_tax_amount": "",
                    "gw_base_tax_amount_invoiced": "",
                    "gw_base_tax_amount_refunded": "",
                    "gw_card_base_price": "",
                    "gw_card_base_price_incl_tax": "",
                    "gw_card_base_price_invoiced": "",
                    "gw_card_base_price_refunded": "",
                    "gw_card_base_tax_amount": "",
                    "gw_card_base_tax_invoiced": "",
                    "gw_card_base_tax_refunded": "",
                    "gw_card_price": "",
                    "gw_card_price_incl_tax": "",
                    "gw_card_price_invoiced": "",
                    "gw_card_price_refunded": "",
                    "gw_card_tax_amount": "",
                    "gw_card_tax_invoiced": "",
                    "gw_card_tax_refunded": "",
                    "gw_id": "",
                    "gw_items_base_price": "",
                    "gw_items_base_price_incl_tax": "",
                    "gw_items_base_price_invoiced": "",
                    "gw_items_base_price_refunded": "",
                    "gw_items_base_tax_amount": "",
                    "gw_items_base_tax_invoiced": "",
                    "gw_items_base_tax_refunded": "",
                    "gw_items_price": "",
                    "gw_items_price_incl_tax": "",
                    "gw_items_price_invoiced": "",
                    "gw_items_price_refunded": "",
                    "gw_items_tax_amount": "",
                    "gw_items_tax_invoiced": "",
                    "gw_items_tax_refunded": "",
                    "gw_price": "",
                    "gw_price_incl_tax": "",
                    "gw_price_invoiced": "",
                    "gw_price_refunded": "",
                    "gw_tax_amount": "",
                    "gw_tax_amount_invoiced": "",
                    "gw_tax_amount_refunded": "",
                    "item_applied_taxes": [
                        {
                            "applied_taxes": [{}],
                            "associated_item_id": 0,
                            "extension_attributes": {},
                            "item_id": 0,
                            "type": ""
                        }
                    ],
                    "payment_additional_info": [
                        {
                            "key": "",
                            "value": ""
                        }
                    ],
                    "reward_currency_amount": "",
                    "reward_points_balance": 0,
                    "shipping_assignments": [
                        {
                            "extension_attributes": {},
                            "items": [
                                {
                                    "additional_data": "",
                                    "amount_refunded": "",
                                    "applied_rule_ids": "",
                                    "base_amount_refunded": "",
                                    "base_cost": "",
                                    "base_discount_amount": "",
                                    "base_discount_invoiced": "",
                                    "base_discount_refunded": "",
                                    "base_discount_tax_compensation_amount": "",
                                    "base_discount_tax_compensation_invoiced": "",
                                    "base_discount_tax_compensation_refunded": "",
                                    "base_original_price": "",
                                    "base_price": "",
                                    "base_price_incl_tax": "",
                                    "base_row_invoiced": "",
                                    "base_row_total": "",
                                    "base_row_total_incl_tax": "",
                                    "base_tax_amount": "",
                                    "base_tax_before_discount": "",
                                    "base_tax_invoiced": "",
                                    "base_tax_refunded": "",
                                    "base_weee_tax_applied_amount": "",
                                    "base_weee_tax_applied_row_amnt": "",
                                    "base_weee_tax_disposition": "",
                                    "base_weee_tax_row_disposition": "",
                                    "created_at": "",
                                    "description": "",
                                    "discount_amount": "",
                                    "discount_invoiced": "",
                                    "discount_percent": "",
                                    "discount_refunded": "",
                                    "discount_tax_compensation_amount": "",
                                    "discount_tax_compensation_canceled": "",
                                    "discount_tax_compensation_invoiced": "",
                                    "discount_tax_compensation_refunded": "",
                                    "event_id": 0,
                                    "ext_order_item_id": "",
                                    "extension_attributes": {
                                        "gift_message": {},
                                        "gw_base_price": "",
                                        "gw_base_price_invoiced": "",
                                        "gw_base_price_refunded": "",
                                        "gw_base_tax_amount": "",
                                        "gw_base_tax_amount_invoiced": "",
                                        "gw_base_tax_amount_refunded": "",
                                        "gw_id": "",
                                        "gw_price": "",
                                        "gw_price_invoiced": "",
                                        "gw_price_refunded": "",
                                        "gw_tax_amount": "",
                                        "gw_tax_amount_invoiced": "",
                                        "gw_tax_amount_refunded": "",
                                        "invoice_text_codes": [],
                                        "tax_codes": [],
                                        "vertex_tax_codes": []
                                    },
                                    "free_shipping": 0,
                                    "gw_base_price": "",
                                    "gw_base_price_invoiced": "",
                                    "gw_base_price_refunded": "",
                                    "gw_base_tax_amount": "",
                                    "gw_base_tax_amount_invoiced": "",
                                    "gw_base_tax_amount_refunded": "",
                                    "gw_id": 0,
                                    "gw_price": "",
                                    "gw_price_invoiced": "",
                                    "gw_price_refunded": "",
                                    "gw_tax_amount": "",
                                    "gw_tax_amount_invoiced": "",
                                    "gw_tax_amount_refunded": "",
                                    "is_qty_decimal": 0,
                                    "is_virtual": 0,
                                    "item_id": 0,
                                    "locked_do_invoice": 0,
                                    "locked_do_ship": 0,
                                    "name": "",
                                    "no_discount": 0,
                                    "order_id": 0,
                                    "original_price": "",
                                    "parent_item": "",
                                    "parent_item_id": 0,
                                    "price": "",
                                    "price_incl_tax": "",
                                    "product_id": 0,
                                    "product_option": { "extension_attributes": {
                                            "bundle_options": [
                                                {
                                                    "extension_attributes": {},
                                                    "option_id": 0,
                                                    "option_qty": 0,
                                                    "option_selections": []
                                                }
                                            ],
                                            "configurable_item_options": [
                                                {
                                                    "extension_attributes": {},
                                                    "option_id": "",
                                                    "option_value": 0
                                                }
                                            ],
                                            "custom_options": [
                                                {
                                                    "extension_attributes": { "file_info": {
                                                            "base64_encoded_data": "",
                                                            "name": "",
                                                            "type": ""
                                                        } },
                                                    "option_id": "",
                                                    "option_value": ""
                                                }
                                            ],
                                            "downloadable_option": { "downloadable_links": [] },
                                            "giftcard_item_option": {
                                                "custom_giftcard_amount": "",
                                                "extension_attributes": {},
                                                "giftcard_amount": "",
                                                "giftcard_message": "",
                                                "giftcard_recipient_email": "",
                                                "giftcard_recipient_name": "",
                                                "giftcard_sender_email": "",
                                                "giftcard_sender_name": ""
                                            }
                                        } },
                                    "product_type": "",
                                    "qty_backordered": "",
                                    "qty_canceled": "",
                                    "qty_invoiced": "",
                                    "qty_ordered": "",
                                    "qty_refunded": "",
                                    "qty_returned": "",
                                    "qty_shipped": "",
                                    "quote_item_id": 0,
                                    "row_invoiced": "",
                                    "row_total": "",
                                    "row_total_incl_tax": "",
                                    "row_weight": "",
                                    "sku": "",
                                    "store_id": 0,
                                    "tax_amount": "",
                                    "tax_before_discount": "",
                                    "tax_canceled": "",
                                    "tax_invoiced": "",
                                    "tax_percent": "",
                                    "tax_refunded": "",
                                    "updated_at": "",
                                    "weee_tax_applied": "",
                                    "weee_tax_applied_amount": "",
                                    "weee_tax_applied_row_amount": "",
                                    "weee_tax_disposition": "",
                                    "weee_tax_row_disposition": "",
                                    "weight": ""
                                }
                            ],
                            "shipping": {
                                "address": {},
                                "extension_attributes": {
                                    "collection_point": {
                                        "city": "",
                                        "collection_point_id": "",
                                        "country": "",
                                        "name": "",
                                        "postcode": "",
                                        "recipient_address_id": 0,
                                        "region": "",
                                        "street": []
                                    },
                                    "ext_order_id": "",
                                    "shipping_experience": {
                                        "code": "",
                                        "cost": "",
                                        "label": ""
                                    }
                                },
                                "method": "",
                                "total": {
                                    "base_shipping_amount": "",
                                    "base_shipping_canceled": "",
                                    "base_shipping_discount_amount": "",
                                    "base_shipping_discount_tax_compensation_amnt": "",
                                    "base_shipping_incl_tax": "",
                                    "base_shipping_invoiced": "",
                                    "base_shipping_refunded": "",
                                    "base_shipping_tax_amount": "",
                                    "base_shipping_tax_refunded": "",
                                    "extension_attributes": {},
                                    "shipping_amount": "",
                                    "shipping_canceled": "",
                                    "shipping_discount_amount": "",
                                    "shipping_discount_tax_compensation_amount": "",
                                    "shipping_incl_tax": "",
                                    "shipping_invoiced": "",
                                    "shipping_refunded": "",
                                    "shipping_tax_amount": "",
                                    "shipping_tax_refunded": ""
                                }
                            },
                            "stock_id": 0
                        }
                    ]
                },
                "forced_shipment_with_invoice": 0,
                "global_currency_code": "",
                "grand_total": "",
                "hold_before_state": "",
                "hold_before_status": "",
                "increment_id": "",
                "is_virtual": 0,
                "items": [{}],
                "order_currency_code": "",
                "original_increment_id": "",
                "payment": {
                    "account_status": "",
                    "additional_data": "",
                    "additional_information": [],
                    "address_status": "",
                    "amount_authorized": "",
                    "amount_canceled": "",
                    "amount_ordered": "",
                    "amount_paid": "",
                    "amount_refunded": "",
                    "anet_trans_method": "",
                    "base_amount_authorized": "",
                    "base_amount_canceled": "",
                    "base_amount_ordered": "",
                    "base_amount_paid": "",
                    "base_amount_paid_online": "",
                    "base_amount_refunded": "",
                    "base_amount_refunded_online": "",
                    "base_shipping_amount": "",
                    "base_shipping_captured": "",
                    "base_shipping_refunded": "",
                    "cc_approval": "",
                    "cc_avs_status": "",
                    "cc_cid_status": "",
                    "cc_debug_request_body": "",
                    "cc_debug_response_body": "",
                    "cc_debug_response_serialized": "",
                    "cc_exp_month": "",
                    "cc_exp_year": "",
                    "cc_last4": "",
                    "cc_number_enc": "",
                    "cc_owner": "",
                    "cc_secure_verify": "",
                    "cc_ss_issue": "",
                    "cc_ss_start_month": "",
                    "cc_ss_start_year": "",
                    "cc_status": "",
                    "cc_status_description": "",
                    "cc_trans_id": "",
                    "cc_type": "",
                    "echeck_account_name": "",
                    "echeck_account_type": "",
                    "echeck_bank_name": "",
                    "echeck_routing_number": "",
                    "echeck_type": "",
                    "entity_id": 0,
                    "extension_attributes": { "vault_payment_token": {
                            "created_at": "",
                            "customer_id": 0,
                            "entity_id": 0,
                            "expires_at": "",
                            "gateway_token": "",
                            "is_active": False,
                            "is_visible": False,
                            "payment_method_code": "",
                            "public_hash": "",
                            "token_details": "",
                            "type": ""
                        } },
                    "last_trans_id": "",
                    "method": "",
                    "parent_id": 0,
                    "po_number": "",
                    "protection_eligibility": "",
                    "quote_payment_id": 0,
                    "shipping_amount": "",
                    "shipping_captured": "",
                    "shipping_refunded": ""
                },
                "payment_auth_expiration": 0,
                "payment_authorization_amount": "",
                "protect_code": "",
                "quote_address_id": 0,
                "quote_id": 0,
                "relation_child_id": "",
                "relation_child_real_id": "",
                "relation_parent_id": "",
                "relation_parent_real_id": "",
                "remote_ip": "",
                "shipping_amount": "",
                "shipping_canceled": "",
                "shipping_description": "",
                "shipping_discount_amount": "",
                "shipping_discount_tax_compensation_amount": "",
                "shipping_incl_tax": "",
                "shipping_invoiced": "",
                "shipping_refunded": "",
                "shipping_tax_amount": "",
                "shipping_tax_refunded": "",
                "state": "",
                "status": "",
                "status_histories": [
                    {
                        "comment": "",
                        "created_at": "",
                        "entity_id": 0,
                        "entity_name": "",
                        "extension_attributes": {},
                        "is_customer_notified": 0,
                        "is_visible_on_front": 0,
                        "parent_id": 0,
                        "status": ""
                    }
                ],
                "store_currency_code": "",
                "store_id": 0,
                "store_name": "",
                "store_to_base_rate": "",
                "store_to_order_rate": "",
                "subtotal": "",
                "subtotal_canceled": "",
                "subtotal_incl_tax": "",
                "subtotal_invoiced": "",
                "subtotal_refunded": "",
                "tax_amount": "",
                "tax_canceled": "",
                "tax_invoiced": "",
                "tax_refunded": "",
                "total_canceled": "",
                "total_due": "",
                "total_invoiced": "",
                "total_item_count": 0,
                "total_offline_refunded": "",
                "total_online_refunded": "",
                "total_paid": "",
                "total_qty_ordered": "",
                "total_refunded": "",
                "updated_at": "",
                "weight": "",
                "x_forwarded_for": ""
            },
            "vertex_tax_calculation_shipping_address": {}
        },
        "global_currency_code": "",
        "grand_total": "",
        "increment_id": "",
        "is_used_for_refund": 0,
        "items": [
            {
                "additional_data": "",
                "base_cost": "",
                "base_discount_amount": "",
                "base_discount_tax_compensation_amount": "",
                "base_price": "",
                "base_price_incl_tax": "",
                "base_row_total": "",
                "base_row_total_incl_tax": "",
                "base_tax_amount": "",
                "description": "",
                "discount_amount": "",
                "discount_tax_compensation_amount": "",
                "entity_id": 0,
                "extension_attributes": {
                    "invoice_text_codes": [],
                    "tax_codes": [],
                    "vertex_tax_codes": []
                },
                "name": "",
                "order_item_id": 0,
                "parent_id": 0,
                "price": "",
                "price_incl_tax": "",
                "product_id": 0,
                "qty": "",
                "row_total": "",
                "row_total_incl_tax": "",
                "sku": "",
                "tax_amount": ""
            }
        ],
        "order_currency_code": "",
        "order_id": 0,
        "shipping_address_id": 0,
        "shipping_amount": "",
        "shipping_discount_tax_compensation_amount": "",
        "shipping_incl_tax": "",
        "shipping_tax_amount": "",
        "state": 0,
        "store_currency_code": "",
        "store_id": 0,
        "store_to_base_rate": "",
        "store_to_order_rate": "",
        "subtotal": "",
        "subtotal_incl_tax": "",
        "tax_amount": "",
        "total_qty": "",
        "transaction_id": "",
        "updated_at": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/invoices/"

payload <- "{\n  \"entity\": {\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address_id\": 0,\n    \"can_void_flag\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"vertex_tax_calculation_billing_address\": {\n        \"address_type\": \"\",\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"customer_address_id\": 0,\n        \"customer_id\": 0,\n        \"email\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"checkout_fields\": [\n            {\n              \"attribute_code\": \"\",\n              \"value\": \"\"\n            }\n          ]\n        },\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"parent_id\": 0,\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": \"\",\n        \"region_code\": \"\",\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\",\n        \"vat_is_valid\": 0,\n        \"vat_request_date\": \"\",\n        \"vat_request_id\": \"\",\n        \"vat_request_success\": 0\n      },\n      \"vertex_tax_calculation_order\": {\n        \"adjustment_negative\": \"\",\n        \"adjustment_positive\": \"\",\n        \"applied_rule_ids\": \"\",\n        \"base_adjustment_negative\": \"\",\n        \"base_adjustment_positive\": \"\",\n        \"base_currency_code\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_canceled\": \"\",\n        \"base_discount_invoiced\": \"\",\n        \"base_discount_refunded\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_discount_tax_compensation_invoiced\": \"\",\n        \"base_discount_tax_compensation_refunded\": \"\",\n        \"base_grand_total\": \"\",\n        \"base_shipping_amount\": \"\",\n        \"base_shipping_canceled\": \"\",\n        \"base_shipping_discount_amount\": \"\",\n        \"base_shipping_discount_tax_compensation_amnt\": \"\",\n        \"base_shipping_incl_tax\": \"\",\n        \"base_shipping_invoiced\": \"\",\n        \"base_shipping_refunded\": \"\",\n        \"base_shipping_tax_amount\": \"\",\n        \"base_shipping_tax_refunded\": \"\",\n        \"base_subtotal\": \"\",\n        \"base_subtotal_canceled\": \"\",\n        \"base_subtotal_incl_tax\": \"\",\n        \"base_subtotal_invoiced\": \"\",\n        \"base_subtotal_refunded\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_tax_canceled\": \"\",\n        \"base_tax_invoiced\": \"\",\n        \"base_tax_refunded\": \"\",\n        \"base_to_global_rate\": \"\",\n        \"base_to_order_rate\": \"\",\n        \"base_total_canceled\": \"\",\n        \"base_total_due\": \"\",\n        \"base_total_invoiced\": \"\",\n        \"base_total_invoiced_cost\": \"\",\n        \"base_total_offline_refunded\": \"\",\n        \"base_total_online_refunded\": \"\",\n        \"base_total_paid\": \"\",\n        \"base_total_qty_ordered\": \"\",\n        \"base_total_refunded\": \"\",\n        \"billing_address\": {},\n        \"billing_address_id\": 0,\n        \"can_ship_partially\": 0,\n        \"can_ship_partially_item\": 0,\n        \"coupon_code\": \"\",\n        \"created_at\": \"\",\n        \"customer_dob\": \"\",\n        \"customer_email\": \"\",\n        \"customer_firstname\": \"\",\n        \"customer_gender\": 0,\n        \"customer_group_id\": 0,\n        \"customer_id\": 0,\n        \"customer_is_guest\": 0,\n        \"customer_lastname\": \"\",\n        \"customer_middlename\": \"\",\n        \"customer_note\": \"\",\n        \"customer_note_notify\": 0,\n        \"customer_prefix\": \"\",\n        \"customer_suffix\": \"\",\n        \"customer_taxvat\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_canceled\": \"\",\n        \"discount_description\": \"\",\n        \"discount_invoiced\": \"\",\n        \"discount_refunded\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"discount_tax_compensation_invoiced\": \"\",\n        \"discount_tax_compensation_refunded\": \"\",\n        \"edit_increment\": 0,\n        \"email_sent\": 0,\n        \"entity_id\": 0,\n        \"ext_customer_id\": \"\",\n        \"ext_order_id\": \"\",\n        \"extension_attributes\": {\n          \"amazon_order_reference_id\": \"\",\n          \"applied_taxes\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"extension_attributes\": {\n                \"rates\": [\n                  {\n                    \"code\": \"\",\n                    \"extension_attributes\": {},\n                    \"percent\": \"\",\n                    \"title\": \"\"\n                  }\n                ]\n              },\n              \"percent\": \"\",\n              \"title\": \"\"\n            }\n          ],\n          \"base_customer_balance_amount\": \"\",\n          \"base_customer_balance_invoiced\": \"\",\n          \"base_customer_balance_refunded\": \"\",\n          \"base_customer_balance_total_refunded\": \"\",\n          \"base_gift_cards_amount\": \"\",\n          \"base_gift_cards_invoiced\": \"\",\n          \"base_gift_cards_refunded\": \"\",\n          \"base_reward_currency_amount\": \"\",\n          \"company_order_attributes\": {\n            \"company_id\": 0,\n            \"company_name\": \"\",\n            \"extension_attributes\": {},\n            \"order_id\": 0\n          },\n          \"converting_from_quote\": false,\n          \"customer_balance_amount\": \"\",\n          \"customer_balance_invoiced\": \"\",\n          \"customer_balance_refunded\": \"\",\n          \"customer_balance_total_refunded\": \"\",\n          \"gift_cards\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"id\": 0\n            }\n          ],\n          \"gift_cards_amount\": \"\",\n          \"gift_cards_invoiced\": \"\",\n          \"gift_cards_refunded\": \"\",\n          \"gift_message\": {\n            \"customer_id\": 0,\n            \"extension_attributes\": {\n              \"entity_id\": \"\",\n              \"entity_type\": \"\",\n              \"wrapping_add_printed_card\": false,\n              \"wrapping_allow_gift_receipt\": false,\n              \"wrapping_id\": 0\n            },\n            \"gift_message_id\": 0,\n            \"message\": \"\",\n            \"recipient\": \"\",\n            \"sender\": \"\"\n          },\n          \"gw_add_card\": \"\",\n          \"gw_allow_gift_receipt\": \"\",\n          \"gw_base_price\": \"\",\n          \"gw_base_price_incl_tax\": \"\",\n          \"gw_base_price_invoiced\": \"\",\n          \"gw_base_price_refunded\": \"\",\n          \"gw_base_tax_amount\": \"\",\n          \"gw_base_tax_amount_invoiced\": \"\",\n          \"gw_base_tax_amount_refunded\": \"\",\n          \"gw_card_base_price\": \"\",\n          \"gw_card_base_price_incl_tax\": \"\",\n          \"gw_card_base_price_invoiced\": \"\",\n          \"gw_card_base_price_refunded\": \"\",\n          \"gw_card_base_tax_amount\": \"\",\n          \"gw_card_base_tax_invoiced\": \"\",\n          \"gw_card_base_tax_refunded\": \"\",\n          \"gw_card_price\": \"\",\n          \"gw_card_price_incl_tax\": \"\",\n          \"gw_card_price_invoiced\": \"\",\n          \"gw_card_price_refunded\": \"\",\n          \"gw_card_tax_amount\": \"\",\n          \"gw_card_tax_invoiced\": \"\",\n          \"gw_card_tax_refunded\": \"\",\n          \"gw_id\": \"\",\n          \"gw_items_base_price\": \"\",\n          \"gw_items_base_price_incl_tax\": \"\",\n          \"gw_items_base_price_invoiced\": \"\",\n          \"gw_items_base_price_refunded\": \"\",\n          \"gw_items_base_tax_amount\": \"\",\n          \"gw_items_base_tax_invoiced\": \"\",\n          \"gw_items_base_tax_refunded\": \"\",\n          \"gw_items_price\": \"\",\n          \"gw_items_price_incl_tax\": \"\",\n          \"gw_items_price_invoiced\": \"\",\n          \"gw_items_price_refunded\": \"\",\n          \"gw_items_tax_amount\": \"\",\n          \"gw_items_tax_invoiced\": \"\",\n          \"gw_items_tax_refunded\": \"\",\n          \"gw_price\": \"\",\n          \"gw_price_incl_tax\": \"\",\n          \"gw_price_invoiced\": \"\",\n          \"gw_price_refunded\": \"\",\n          \"gw_tax_amount\": \"\",\n          \"gw_tax_amount_invoiced\": \"\",\n          \"gw_tax_amount_refunded\": \"\",\n          \"item_applied_taxes\": [\n            {\n              \"applied_taxes\": [\n                {}\n              ],\n              \"associated_item_id\": 0,\n              \"extension_attributes\": {},\n              \"item_id\": 0,\n              \"type\": \"\"\n            }\n          ],\n          \"payment_additional_info\": [\n            {\n              \"key\": \"\",\n              \"value\": \"\"\n            }\n          ],\n          \"reward_currency_amount\": \"\",\n          \"reward_points_balance\": 0,\n          \"shipping_assignments\": [\n            {\n              \"extension_attributes\": {},\n              \"items\": [\n                {\n                  \"additional_data\": \"\",\n                  \"amount_refunded\": \"\",\n                  \"applied_rule_ids\": \"\",\n                  \"base_amount_refunded\": \"\",\n                  \"base_cost\": \"\",\n                  \"base_discount_amount\": \"\",\n                  \"base_discount_invoiced\": \"\",\n                  \"base_discount_refunded\": \"\",\n                  \"base_discount_tax_compensation_amount\": \"\",\n                  \"base_discount_tax_compensation_invoiced\": \"\",\n                  \"base_discount_tax_compensation_refunded\": \"\",\n                  \"base_original_price\": \"\",\n                  \"base_price\": \"\",\n                  \"base_price_incl_tax\": \"\",\n                  \"base_row_invoiced\": \"\",\n                  \"base_row_total\": \"\",\n                  \"base_row_total_incl_tax\": \"\",\n                  \"base_tax_amount\": \"\",\n                  \"base_tax_before_discount\": \"\",\n                  \"base_tax_invoiced\": \"\",\n                  \"base_tax_refunded\": \"\",\n                  \"base_weee_tax_applied_amount\": \"\",\n                  \"base_weee_tax_applied_row_amnt\": \"\",\n                  \"base_weee_tax_disposition\": \"\",\n                  \"base_weee_tax_row_disposition\": \"\",\n                  \"created_at\": \"\",\n                  \"description\": \"\",\n                  \"discount_amount\": \"\",\n                  \"discount_invoiced\": \"\",\n                  \"discount_percent\": \"\",\n                  \"discount_refunded\": \"\",\n                  \"discount_tax_compensation_amount\": \"\",\n                  \"discount_tax_compensation_canceled\": \"\",\n                  \"discount_tax_compensation_invoiced\": \"\",\n                  \"discount_tax_compensation_refunded\": \"\",\n                  \"event_id\": 0,\n                  \"ext_order_item_id\": \"\",\n                  \"extension_attributes\": {\n                    \"gift_message\": {},\n                    \"gw_base_price\": \"\",\n                    \"gw_base_price_invoiced\": \"\",\n                    \"gw_base_price_refunded\": \"\",\n                    \"gw_base_tax_amount\": \"\",\n                    \"gw_base_tax_amount_invoiced\": \"\",\n                    \"gw_base_tax_amount_refunded\": \"\",\n                    \"gw_id\": \"\",\n                    \"gw_price\": \"\",\n                    \"gw_price_invoiced\": \"\",\n                    \"gw_price_refunded\": \"\",\n                    \"gw_tax_amount\": \"\",\n                    \"gw_tax_amount_invoiced\": \"\",\n                    \"gw_tax_amount_refunded\": \"\",\n                    \"invoice_text_codes\": [],\n                    \"tax_codes\": [],\n                    \"vertex_tax_codes\": []\n                  },\n                  \"free_shipping\": 0,\n                  \"gw_base_price\": \"\",\n                  \"gw_base_price_invoiced\": \"\",\n                  \"gw_base_price_refunded\": \"\",\n                  \"gw_base_tax_amount\": \"\",\n                  \"gw_base_tax_amount_invoiced\": \"\",\n                  \"gw_base_tax_amount_refunded\": \"\",\n                  \"gw_id\": 0,\n                  \"gw_price\": \"\",\n                  \"gw_price_invoiced\": \"\",\n                  \"gw_price_refunded\": \"\",\n                  \"gw_tax_amount\": \"\",\n                  \"gw_tax_amount_invoiced\": \"\",\n                  \"gw_tax_amount_refunded\": \"\",\n                  \"is_qty_decimal\": 0,\n                  \"is_virtual\": 0,\n                  \"item_id\": 0,\n                  \"locked_do_invoice\": 0,\n                  \"locked_do_ship\": 0,\n                  \"name\": \"\",\n                  \"no_discount\": 0,\n                  \"order_id\": 0,\n                  \"original_price\": \"\",\n                  \"parent_item\": \"\",\n                  \"parent_item_id\": 0,\n                  \"price\": \"\",\n                  \"price_incl_tax\": \"\",\n                  \"product_id\": 0,\n                  \"product_option\": {\n                    \"extension_attributes\": {\n                      \"bundle_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": 0,\n                          \"option_qty\": 0,\n                          \"option_selections\": []\n                        }\n                      ],\n                      \"configurable_item_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": \"\",\n                          \"option_value\": 0\n                        }\n                      ],\n                      \"custom_options\": [\n                        {\n                          \"extension_attributes\": {\n                            \"file_info\": {\n                              \"base64_encoded_data\": \"\",\n                              \"name\": \"\",\n                              \"type\": \"\"\n                            }\n                          },\n                          \"option_id\": \"\",\n                          \"option_value\": \"\"\n                        }\n                      ],\n                      \"downloadable_option\": {\n                        \"downloadable_links\": []\n                      },\n                      \"giftcard_item_option\": {\n                        \"custom_giftcard_amount\": \"\",\n                        \"extension_attributes\": {},\n                        \"giftcard_amount\": \"\",\n                        \"giftcard_message\": \"\",\n                        \"giftcard_recipient_email\": \"\",\n                        \"giftcard_recipient_name\": \"\",\n                        \"giftcard_sender_email\": \"\",\n                        \"giftcard_sender_name\": \"\"\n                      }\n                    }\n                  },\n                  \"product_type\": \"\",\n                  \"qty_backordered\": \"\",\n                  \"qty_canceled\": \"\",\n                  \"qty_invoiced\": \"\",\n                  \"qty_ordered\": \"\",\n                  \"qty_refunded\": \"\",\n                  \"qty_returned\": \"\",\n                  \"qty_shipped\": \"\",\n                  \"quote_item_id\": 0,\n                  \"row_invoiced\": \"\",\n                  \"row_total\": \"\",\n                  \"row_total_incl_tax\": \"\",\n                  \"row_weight\": \"\",\n                  \"sku\": \"\",\n                  \"store_id\": 0,\n                  \"tax_amount\": \"\",\n                  \"tax_before_discount\": \"\",\n                  \"tax_canceled\": \"\",\n                  \"tax_invoiced\": \"\",\n                  \"tax_percent\": \"\",\n                  \"tax_refunded\": \"\",\n                  \"updated_at\": \"\",\n                  \"weee_tax_applied\": \"\",\n                  \"weee_tax_applied_amount\": \"\",\n                  \"weee_tax_applied_row_amount\": \"\",\n                  \"weee_tax_disposition\": \"\",\n                  \"weee_tax_row_disposition\": \"\",\n                  \"weight\": \"\"\n                }\n              ],\n              \"shipping\": {\n                \"address\": {},\n                \"extension_attributes\": {\n                  \"collection_point\": {\n                    \"city\": \"\",\n                    \"collection_point_id\": \"\",\n                    \"country\": \"\",\n                    \"name\": \"\",\n                    \"postcode\": \"\",\n                    \"recipient_address_id\": 0,\n                    \"region\": \"\",\n                    \"street\": []\n                  },\n                  \"ext_order_id\": \"\",\n                  \"shipping_experience\": {\n                    \"code\": \"\",\n                    \"cost\": \"\",\n                    \"label\": \"\"\n                  }\n                },\n                \"method\": \"\",\n                \"total\": {\n                  \"base_shipping_amount\": \"\",\n                  \"base_shipping_canceled\": \"\",\n                  \"base_shipping_discount_amount\": \"\",\n                  \"base_shipping_discount_tax_compensation_amnt\": \"\",\n                  \"base_shipping_incl_tax\": \"\",\n                  \"base_shipping_invoiced\": \"\",\n                  \"base_shipping_refunded\": \"\",\n                  \"base_shipping_tax_amount\": \"\",\n                  \"base_shipping_tax_refunded\": \"\",\n                  \"extension_attributes\": {},\n                  \"shipping_amount\": \"\",\n                  \"shipping_canceled\": \"\",\n                  \"shipping_discount_amount\": \"\",\n                  \"shipping_discount_tax_compensation_amount\": \"\",\n                  \"shipping_incl_tax\": \"\",\n                  \"shipping_invoiced\": \"\",\n                  \"shipping_refunded\": \"\",\n                  \"shipping_tax_amount\": \"\",\n                  \"shipping_tax_refunded\": \"\"\n                }\n              },\n              \"stock_id\": 0\n            }\n          ]\n        },\n        \"forced_shipment_with_invoice\": 0,\n        \"global_currency_code\": \"\",\n        \"grand_total\": \"\",\n        \"hold_before_state\": \"\",\n        \"hold_before_status\": \"\",\n        \"increment_id\": \"\",\n        \"is_virtual\": 0,\n        \"items\": [\n          {}\n        ],\n        \"order_currency_code\": \"\",\n        \"original_increment_id\": \"\",\n        \"payment\": {\n          \"account_status\": \"\",\n          \"additional_data\": \"\",\n          \"additional_information\": [],\n          \"address_status\": \"\",\n          \"amount_authorized\": \"\",\n          \"amount_canceled\": \"\",\n          \"amount_ordered\": \"\",\n          \"amount_paid\": \"\",\n          \"amount_refunded\": \"\",\n          \"anet_trans_method\": \"\",\n          \"base_amount_authorized\": \"\",\n          \"base_amount_canceled\": \"\",\n          \"base_amount_ordered\": \"\",\n          \"base_amount_paid\": \"\",\n          \"base_amount_paid_online\": \"\",\n          \"base_amount_refunded\": \"\",\n          \"base_amount_refunded_online\": \"\",\n          \"base_shipping_amount\": \"\",\n          \"base_shipping_captured\": \"\",\n          \"base_shipping_refunded\": \"\",\n          \"cc_approval\": \"\",\n          \"cc_avs_status\": \"\",\n          \"cc_cid_status\": \"\",\n          \"cc_debug_request_body\": \"\",\n          \"cc_debug_response_body\": \"\",\n          \"cc_debug_response_serialized\": \"\",\n          \"cc_exp_month\": \"\",\n          \"cc_exp_year\": \"\",\n          \"cc_last4\": \"\",\n          \"cc_number_enc\": \"\",\n          \"cc_owner\": \"\",\n          \"cc_secure_verify\": \"\",\n          \"cc_ss_issue\": \"\",\n          \"cc_ss_start_month\": \"\",\n          \"cc_ss_start_year\": \"\",\n          \"cc_status\": \"\",\n          \"cc_status_description\": \"\",\n          \"cc_trans_id\": \"\",\n          \"cc_type\": \"\",\n          \"echeck_account_name\": \"\",\n          \"echeck_account_type\": \"\",\n          \"echeck_bank_name\": \"\",\n          \"echeck_routing_number\": \"\",\n          \"echeck_type\": \"\",\n          \"entity_id\": 0,\n          \"extension_attributes\": {\n            \"vault_payment_token\": {\n              \"created_at\": \"\",\n              \"customer_id\": 0,\n              \"entity_id\": 0,\n              \"expires_at\": \"\",\n              \"gateway_token\": \"\",\n              \"is_active\": false,\n              \"is_visible\": false,\n              \"payment_method_code\": \"\",\n              \"public_hash\": \"\",\n              \"token_details\": \"\",\n              \"type\": \"\"\n            }\n          },\n          \"last_trans_id\": \"\",\n          \"method\": \"\",\n          \"parent_id\": 0,\n          \"po_number\": \"\",\n          \"protection_eligibility\": \"\",\n          \"quote_payment_id\": 0,\n          \"shipping_amount\": \"\",\n          \"shipping_captured\": \"\",\n          \"shipping_refunded\": \"\"\n        },\n        \"payment_auth_expiration\": 0,\n        \"payment_authorization_amount\": \"\",\n        \"protect_code\": \"\",\n        \"quote_address_id\": 0,\n        \"quote_id\": 0,\n        \"relation_child_id\": \"\",\n        \"relation_child_real_id\": \"\",\n        \"relation_parent_id\": \"\",\n        \"relation_parent_real_id\": \"\",\n        \"remote_ip\": \"\",\n        \"shipping_amount\": \"\",\n        \"shipping_canceled\": \"\",\n        \"shipping_description\": \"\",\n        \"shipping_discount_amount\": \"\",\n        \"shipping_discount_tax_compensation_amount\": \"\",\n        \"shipping_incl_tax\": \"\",\n        \"shipping_invoiced\": \"\",\n        \"shipping_refunded\": \"\",\n        \"shipping_tax_amount\": \"\",\n        \"shipping_tax_refunded\": \"\",\n        \"state\": \"\",\n        \"status\": \"\",\n        \"status_histories\": [\n          {\n            \"comment\": \"\",\n            \"created_at\": \"\",\n            \"entity_id\": 0,\n            \"entity_name\": \"\",\n            \"extension_attributes\": {},\n            \"is_customer_notified\": 0,\n            \"is_visible_on_front\": 0,\n            \"parent_id\": 0,\n            \"status\": \"\"\n          }\n        ],\n        \"store_currency_code\": \"\",\n        \"store_id\": 0,\n        \"store_name\": \"\",\n        \"store_to_base_rate\": \"\",\n        \"store_to_order_rate\": \"\",\n        \"subtotal\": \"\",\n        \"subtotal_canceled\": \"\",\n        \"subtotal_incl_tax\": \"\",\n        \"subtotal_invoiced\": \"\",\n        \"subtotal_refunded\": \"\",\n        \"tax_amount\": \"\",\n        \"tax_canceled\": \"\",\n        \"tax_invoiced\": \"\",\n        \"tax_refunded\": \"\",\n        \"total_canceled\": \"\",\n        \"total_due\": \"\",\n        \"total_invoiced\": \"\",\n        \"total_item_count\": 0,\n        \"total_offline_refunded\": \"\",\n        \"total_online_refunded\": \"\",\n        \"total_paid\": \"\",\n        \"total_qty_ordered\": \"\",\n        \"total_refunded\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\",\n        \"x_forwarded_for\": \"\"\n      },\n      \"vertex_tax_calculation_shipping_address\": {}\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"is_used_for_refund\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"total_qty\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/invoices/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"entity\": {\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address_id\": 0,\n    \"can_void_flag\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"vertex_tax_calculation_billing_address\": {\n        \"address_type\": \"\",\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"customer_address_id\": 0,\n        \"customer_id\": 0,\n        \"email\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"checkout_fields\": [\n            {\n              \"attribute_code\": \"\",\n              \"value\": \"\"\n            }\n          ]\n        },\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"parent_id\": 0,\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": \"\",\n        \"region_code\": \"\",\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\",\n        \"vat_is_valid\": 0,\n        \"vat_request_date\": \"\",\n        \"vat_request_id\": \"\",\n        \"vat_request_success\": 0\n      },\n      \"vertex_tax_calculation_order\": {\n        \"adjustment_negative\": \"\",\n        \"adjustment_positive\": \"\",\n        \"applied_rule_ids\": \"\",\n        \"base_adjustment_negative\": \"\",\n        \"base_adjustment_positive\": \"\",\n        \"base_currency_code\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_canceled\": \"\",\n        \"base_discount_invoiced\": \"\",\n        \"base_discount_refunded\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_discount_tax_compensation_invoiced\": \"\",\n        \"base_discount_tax_compensation_refunded\": \"\",\n        \"base_grand_total\": \"\",\n        \"base_shipping_amount\": \"\",\n        \"base_shipping_canceled\": \"\",\n        \"base_shipping_discount_amount\": \"\",\n        \"base_shipping_discount_tax_compensation_amnt\": \"\",\n        \"base_shipping_incl_tax\": \"\",\n        \"base_shipping_invoiced\": \"\",\n        \"base_shipping_refunded\": \"\",\n        \"base_shipping_tax_amount\": \"\",\n        \"base_shipping_tax_refunded\": \"\",\n        \"base_subtotal\": \"\",\n        \"base_subtotal_canceled\": \"\",\n        \"base_subtotal_incl_tax\": \"\",\n        \"base_subtotal_invoiced\": \"\",\n        \"base_subtotal_refunded\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_tax_canceled\": \"\",\n        \"base_tax_invoiced\": \"\",\n        \"base_tax_refunded\": \"\",\n        \"base_to_global_rate\": \"\",\n        \"base_to_order_rate\": \"\",\n        \"base_total_canceled\": \"\",\n        \"base_total_due\": \"\",\n        \"base_total_invoiced\": \"\",\n        \"base_total_invoiced_cost\": \"\",\n        \"base_total_offline_refunded\": \"\",\n        \"base_total_online_refunded\": \"\",\n        \"base_total_paid\": \"\",\n        \"base_total_qty_ordered\": \"\",\n        \"base_total_refunded\": \"\",\n        \"billing_address\": {},\n        \"billing_address_id\": 0,\n        \"can_ship_partially\": 0,\n        \"can_ship_partially_item\": 0,\n        \"coupon_code\": \"\",\n        \"created_at\": \"\",\n        \"customer_dob\": \"\",\n        \"customer_email\": \"\",\n        \"customer_firstname\": \"\",\n        \"customer_gender\": 0,\n        \"customer_group_id\": 0,\n        \"customer_id\": 0,\n        \"customer_is_guest\": 0,\n        \"customer_lastname\": \"\",\n        \"customer_middlename\": \"\",\n        \"customer_note\": \"\",\n        \"customer_note_notify\": 0,\n        \"customer_prefix\": \"\",\n        \"customer_suffix\": \"\",\n        \"customer_taxvat\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_canceled\": \"\",\n        \"discount_description\": \"\",\n        \"discount_invoiced\": \"\",\n        \"discount_refunded\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"discount_tax_compensation_invoiced\": \"\",\n        \"discount_tax_compensation_refunded\": \"\",\n        \"edit_increment\": 0,\n        \"email_sent\": 0,\n        \"entity_id\": 0,\n        \"ext_customer_id\": \"\",\n        \"ext_order_id\": \"\",\n        \"extension_attributes\": {\n          \"amazon_order_reference_id\": \"\",\n          \"applied_taxes\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"extension_attributes\": {\n                \"rates\": [\n                  {\n                    \"code\": \"\",\n                    \"extension_attributes\": {},\n                    \"percent\": \"\",\n                    \"title\": \"\"\n                  }\n                ]\n              },\n              \"percent\": \"\",\n              \"title\": \"\"\n            }\n          ],\n          \"base_customer_balance_amount\": \"\",\n          \"base_customer_balance_invoiced\": \"\",\n          \"base_customer_balance_refunded\": \"\",\n          \"base_customer_balance_total_refunded\": \"\",\n          \"base_gift_cards_amount\": \"\",\n          \"base_gift_cards_invoiced\": \"\",\n          \"base_gift_cards_refunded\": \"\",\n          \"base_reward_currency_amount\": \"\",\n          \"company_order_attributes\": {\n            \"company_id\": 0,\n            \"company_name\": \"\",\n            \"extension_attributes\": {},\n            \"order_id\": 0\n          },\n          \"converting_from_quote\": false,\n          \"customer_balance_amount\": \"\",\n          \"customer_balance_invoiced\": \"\",\n          \"customer_balance_refunded\": \"\",\n          \"customer_balance_total_refunded\": \"\",\n          \"gift_cards\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"id\": 0\n            }\n          ],\n          \"gift_cards_amount\": \"\",\n          \"gift_cards_invoiced\": \"\",\n          \"gift_cards_refunded\": \"\",\n          \"gift_message\": {\n            \"customer_id\": 0,\n            \"extension_attributes\": {\n              \"entity_id\": \"\",\n              \"entity_type\": \"\",\n              \"wrapping_add_printed_card\": false,\n              \"wrapping_allow_gift_receipt\": false,\n              \"wrapping_id\": 0\n            },\n            \"gift_message_id\": 0,\n            \"message\": \"\",\n            \"recipient\": \"\",\n            \"sender\": \"\"\n          },\n          \"gw_add_card\": \"\",\n          \"gw_allow_gift_receipt\": \"\",\n          \"gw_base_price\": \"\",\n          \"gw_base_price_incl_tax\": \"\",\n          \"gw_base_price_invoiced\": \"\",\n          \"gw_base_price_refunded\": \"\",\n          \"gw_base_tax_amount\": \"\",\n          \"gw_base_tax_amount_invoiced\": \"\",\n          \"gw_base_tax_amount_refunded\": \"\",\n          \"gw_card_base_price\": \"\",\n          \"gw_card_base_price_incl_tax\": \"\",\n          \"gw_card_base_price_invoiced\": \"\",\n          \"gw_card_base_price_refunded\": \"\",\n          \"gw_card_base_tax_amount\": \"\",\n          \"gw_card_base_tax_invoiced\": \"\",\n          \"gw_card_base_tax_refunded\": \"\",\n          \"gw_card_price\": \"\",\n          \"gw_card_price_incl_tax\": \"\",\n          \"gw_card_price_invoiced\": \"\",\n          \"gw_card_price_refunded\": \"\",\n          \"gw_card_tax_amount\": \"\",\n          \"gw_card_tax_invoiced\": \"\",\n          \"gw_card_tax_refunded\": \"\",\n          \"gw_id\": \"\",\n          \"gw_items_base_price\": \"\",\n          \"gw_items_base_price_incl_tax\": \"\",\n          \"gw_items_base_price_invoiced\": \"\",\n          \"gw_items_base_price_refunded\": \"\",\n          \"gw_items_base_tax_amount\": \"\",\n          \"gw_items_base_tax_invoiced\": \"\",\n          \"gw_items_base_tax_refunded\": \"\",\n          \"gw_items_price\": \"\",\n          \"gw_items_price_incl_tax\": \"\",\n          \"gw_items_price_invoiced\": \"\",\n          \"gw_items_price_refunded\": \"\",\n          \"gw_items_tax_amount\": \"\",\n          \"gw_items_tax_invoiced\": \"\",\n          \"gw_items_tax_refunded\": \"\",\n          \"gw_price\": \"\",\n          \"gw_price_incl_tax\": \"\",\n          \"gw_price_invoiced\": \"\",\n          \"gw_price_refunded\": \"\",\n          \"gw_tax_amount\": \"\",\n          \"gw_tax_amount_invoiced\": \"\",\n          \"gw_tax_amount_refunded\": \"\",\n          \"item_applied_taxes\": [\n            {\n              \"applied_taxes\": [\n                {}\n              ],\n              \"associated_item_id\": 0,\n              \"extension_attributes\": {},\n              \"item_id\": 0,\n              \"type\": \"\"\n            }\n          ],\n          \"payment_additional_info\": [\n            {\n              \"key\": \"\",\n              \"value\": \"\"\n            }\n          ],\n          \"reward_currency_amount\": \"\",\n          \"reward_points_balance\": 0,\n          \"shipping_assignments\": [\n            {\n              \"extension_attributes\": {},\n              \"items\": [\n                {\n                  \"additional_data\": \"\",\n                  \"amount_refunded\": \"\",\n                  \"applied_rule_ids\": \"\",\n                  \"base_amount_refunded\": \"\",\n                  \"base_cost\": \"\",\n                  \"base_discount_amount\": \"\",\n                  \"base_discount_invoiced\": \"\",\n                  \"base_discount_refunded\": \"\",\n                  \"base_discount_tax_compensation_amount\": \"\",\n                  \"base_discount_tax_compensation_invoiced\": \"\",\n                  \"base_discount_tax_compensation_refunded\": \"\",\n                  \"base_original_price\": \"\",\n                  \"base_price\": \"\",\n                  \"base_price_incl_tax\": \"\",\n                  \"base_row_invoiced\": \"\",\n                  \"base_row_total\": \"\",\n                  \"base_row_total_incl_tax\": \"\",\n                  \"base_tax_amount\": \"\",\n                  \"base_tax_before_discount\": \"\",\n                  \"base_tax_invoiced\": \"\",\n                  \"base_tax_refunded\": \"\",\n                  \"base_weee_tax_applied_amount\": \"\",\n                  \"base_weee_tax_applied_row_amnt\": \"\",\n                  \"base_weee_tax_disposition\": \"\",\n                  \"base_weee_tax_row_disposition\": \"\",\n                  \"created_at\": \"\",\n                  \"description\": \"\",\n                  \"discount_amount\": \"\",\n                  \"discount_invoiced\": \"\",\n                  \"discount_percent\": \"\",\n                  \"discount_refunded\": \"\",\n                  \"discount_tax_compensation_amount\": \"\",\n                  \"discount_tax_compensation_canceled\": \"\",\n                  \"discount_tax_compensation_invoiced\": \"\",\n                  \"discount_tax_compensation_refunded\": \"\",\n                  \"event_id\": 0,\n                  \"ext_order_item_id\": \"\",\n                  \"extension_attributes\": {\n                    \"gift_message\": {},\n                    \"gw_base_price\": \"\",\n                    \"gw_base_price_invoiced\": \"\",\n                    \"gw_base_price_refunded\": \"\",\n                    \"gw_base_tax_amount\": \"\",\n                    \"gw_base_tax_amount_invoiced\": \"\",\n                    \"gw_base_tax_amount_refunded\": \"\",\n                    \"gw_id\": \"\",\n                    \"gw_price\": \"\",\n                    \"gw_price_invoiced\": \"\",\n                    \"gw_price_refunded\": \"\",\n                    \"gw_tax_amount\": \"\",\n                    \"gw_tax_amount_invoiced\": \"\",\n                    \"gw_tax_amount_refunded\": \"\",\n                    \"invoice_text_codes\": [],\n                    \"tax_codes\": [],\n                    \"vertex_tax_codes\": []\n                  },\n                  \"free_shipping\": 0,\n                  \"gw_base_price\": \"\",\n                  \"gw_base_price_invoiced\": \"\",\n                  \"gw_base_price_refunded\": \"\",\n                  \"gw_base_tax_amount\": \"\",\n                  \"gw_base_tax_amount_invoiced\": \"\",\n                  \"gw_base_tax_amount_refunded\": \"\",\n                  \"gw_id\": 0,\n                  \"gw_price\": \"\",\n                  \"gw_price_invoiced\": \"\",\n                  \"gw_price_refunded\": \"\",\n                  \"gw_tax_amount\": \"\",\n                  \"gw_tax_amount_invoiced\": \"\",\n                  \"gw_tax_amount_refunded\": \"\",\n                  \"is_qty_decimal\": 0,\n                  \"is_virtual\": 0,\n                  \"item_id\": 0,\n                  \"locked_do_invoice\": 0,\n                  \"locked_do_ship\": 0,\n                  \"name\": \"\",\n                  \"no_discount\": 0,\n                  \"order_id\": 0,\n                  \"original_price\": \"\",\n                  \"parent_item\": \"\",\n                  \"parent_item_id\": 0,\n                  \"price\": \"\",\n                  \"price_incl_tax\": \"\",\n                  \"product_id\": 0,\n                  \"product_option\": {\n                    \"extension_attributes\": {\n                      \"bundle_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": 0,\n                          \"option_qty\": 0,\n                          \"option_selections\": []\n                        }\n                      ],\n                      \"configurable_item_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": \"\",\n                          \"option_value\": 0\n                        }\n                      ],\n                      \"custom_options\": [\n                        {\n                          \"extension_attributes\": {\n                            \"file_info\": {\n                              \"base64_encoded_data\": \"\",\n                              \"name\": \"\",\n                              \"type\": \"\"\n                            }\n                          },\n                          \"option_id\": \"\",\n                          \"option_value\": \"\"\n                        }\n                      ],\n                      \"downloadable_option\": {\n                        \"downloadable_links\": []\n                      },\n                      \"giftcard_item_option\": {\n                        \"custom_giftcard_amount\": \"\",\n                        \"extension_attributes\": {},\n                        \"giftcard_amount\": \"\",\n                        \"giftcard_message\": \"\",\n                        \"giftcard_recipient_email\": \"\",\n                        \"giftcard_recipient_name\": \"\",\n                        \"giftcard_sender_email\": \"\",\n                        \"giftcard_sender_name\": \"\"\n                      }\n                    }\n                  },\n                  \"product_type\": \"\",\n                  \"qty_backordered\": \"\",\n                  \"qty_canceled\": \"\",\n                  \"qty_invoiced\": \"\",\n                  \"qty_ordered\": \"\",\n                  \"qty_refunded\": \"\",\n                  \"qty_returned\": \"\",\n                  \"qty_shipped\": \"\",\n                  \"quote_item_id\": 0,\n                  \"row_invoiced\": \"\",\n                  \"row_total\": \"\",\n                  \"row_total_incl_tax\": \"\",\n                  \"row_weight\": \"\",\n                  \"sku\": \"\",\n                  \"store_id\": 0,\n                  \"tax_amount\": \"\",\n                  \"tax_before_discount\": \"\",\n                  \"tax_canceled\": \"\",\n                  \"tax_invoiced\": \"\",\n                  \"tax_percent\": \"\",\n                  \"tax_refunded\": \"\",\n                  \"updated_at\": \"\",\n                  \"weee_tax_applied\": \"\",\n                  \"weee_tax_applied_amount\": \"\",\n                  \"weee_tax_applied_row_amount\": \"\",\n                  \"weee_tax_disposition\": \"\",\n                  \"weee_tax_row_disposition\": \"\",\n                  \"weight\": \"\"\n                }\n              ],\n              \"shipping\": {\n                \"address\": {},\n                \"extension_attributes\": {\n                  \"collection_point\": {\n                    \"city\": \"\",\n                    \"collection_point_id\": \"\",\n                    \"country\": \"\",\n                    \"name\": \"\",\n                    \"postcode\": \"\",\n                    \"recipient_address_id\": 0,\n                    \"region\": \"\",\n                    \"street\": []\n                  },\n                  \"ext_order_id\": \"\",\n                  \"shipping_experience\": {\n                    \"code\": \"\",\n                    \"cost\": \"\",\n                    \"label\": \"\"\n                  }\n                },\n                \"method\": \"\",\n                \"total\": {\n                  \"base_shipping_amount\": \"\",\n                  \"base_shipping_canceled\": \"\",\n                  \"base_shipping_discount_amount\": \"\",\n                  \"base_shipping_discount_tax_compensation_amnt\": \"\",\n                  \"base_shipping_incl_tax\": \"\",\n                  \"base_shipping_invoiced\": \"\",\n                  \"base_shipping_refunded\": \"\",\n                  \"base_shipping_tax_amount\": \"\",\n                  \"base_shipping_tax_refunded\": \"\",\n                  \"extension_attributes\": {},\n                  \"shipping_amount\": \"\",\n                  \"shipping_canceled\": \"\",\n                  \"shipping_discount_amount\": \"\",\n                  \"shipping_discount_tax_compensation_amount\": \"\",\n                  \"shipping_incl_tax\": \"\",\n                  \"shipping_invoiced\": \"\",\n                  \"shipping_refunded\": \"\",\n                  \"shipping_tax_amount\": \"\",\n                  \"shipping_tax_refunded\": \"\"\n                }\n              },\n              \"stock_id\": 0\n            }\n          ]\n        },\n        \"forced_shipment_with_invoice\": 0,\n        \"global_currency_code\": \"\",\n        \"grand_total\": \"\",\n        \"hold_before_state\": \"\",\n        \"hold_before_status\": \"\",\n        \"increment_id\": \"\",\n        \"is_virtual\": 0,\n        \"items\": [\n          {}\n        ],\n        \"order_currency_code\": \"\",\n        \"original_increment_id\": \"\",\n        \"payment\": {\n          \"account_status\": \"\",\n          \"additional_data\": \"\",\n          \"additional_information\": [],\n          \"address_status\": \"\",\n          \"amount_authorized\": \"\",\n          \"amount_canceled\": \"\",\n          \"amount_ordered\": \"\",\n          \"amount_paid\": \"\",\n          \"amount_refunded\": \"\",\n          \"anet_trans_method\": \"\",\n          \"base_amount_authorized\": \"\",\n          \"base_amount_canceled\": \"\",\n          \"base_amount_ordered\": \"\",\n          \"base_amount_paid\": \"\",\n          \"base_amount_paid_online\": \"\",\n          \"base_amount_refunded\": \"\",\n          \"base_amount_refunded_online\": \"\",\n          \"base_shipping_amount\": \"\",\n          \"base_shipping_captured\": \"\",\n          \"base_shipping_refunded\": \"\",\n          \"cc_approval\": \"\",\n          \"cc_avs_status\": \"\",\n          \"cc_cid_status\": \"\",\n          \"cc_debug_request_body\": \"\",\n          \"cc_debug_response_body\": \"\",\n          \"cc_debug_response_serialized\": \"\",\n          \"cc_exp_month\": \"\",\n          \"cc_exp_year\": \"\",\n          \"cc_last4\": \"\",\n          \"cc_number_enc\": \"\",\n          \"cc_owner\": \"\",\n          \"cc_secure_verify\": \"\",\n          \"cc_ss_issue\": \"\",\n          \"cc_ss_start_month\": \"\",\n          \"cc_ss_start_year\": \"\",\n          \"cc_status\": \"\",\n          \"cc_status_description\": \"\",\n          \"cc_trans_id\": \"\",\n          \"cc_type\": \"\",\n          \"echeck_account_name\": \"\",\n          \"echeck_account_type\": \"\",\n          \"echeck_bank_name\": \"\",\n          \"echeck_routing_number\": \"\",\n          \"echeck_type\": \"\",\n          \"entity_id\": 0,\n          \"extension_attributes\": {\n            \"vault_payment_token\": {\n              \"created_at\": \"\",\n              \"customer_id\": 0,\n              \"entity_id\": 0,\n              \"expires_at\": \"\",\n              \"gateway_token\": \"\",\n              \"is_active\": false,\n              \"is_visible\": false,\n              \"payment_method_code\": \"\",\n              \"public_hash\": \"\",\n              \"token_details\": \"\",\n              \"type\": \"\"\n            }\n          },\n          \"last_trans_id\": \"\",\n          \"method\": \"\",\n          \"parent_id\": 0,\n          \"po_number\": \"\",\n          \"protection_eligibility\": \"\",\n          \"quote_payment_id\": 0,\n          \"shipping_amount\": \"\",\n          \"shipping_captured\": \"\",\n          \"shipping_refunded\": \"\"\n        },\n        \"payment_auth_expiration\": 0,\n        \"payment_authorization_amount\": \"\",\n        \"protect_code\": \"\",\n        \"quote_address_id\": 0,\n        \"quote_id\": 0,\n        \"relation_child_id\": \"\",\n        \"relation_child_real_id\": \"\",\n        \"relation_parent_id\": \"\",\n        \"relation_parent_real_id\": \"\",\n        \"remote_ip\": \"\",\n        \"shipping_amount\": \"\",\n        \"shipping_canceled\": \"\",\n        \"shipping_description\": \"\",\n        \"shipping_discount_amount\": \"\",\n        \"shipping_discount_tax_compensation_amount\": \"\",\n        \"shipping_incl_tax\": \"\",\n        \"shipping_invoiced\": \"\",\n        \"shipping_refunded\": \"\",\n        \"shipping_tax_amount\": \"\",\n        \"shipping_tax_refunded\": \"\",\n        \"state\": \"\",\n        \"status\": \"\",\n        \"status_histories\": [\n          {\n            \"comment\": \"\",\n            \"created_at\": \"\",\n            \"entity_id\": 0,\n            \"entity_name\": \"\",\n            \"extension_attributes\": {},\n            \"is_customer_notified\": 0,\n            \"is_visible_on_front\": 0,\n            \"parent_id\": 0,\n            \"status\": \"\"\n          }\n        ],\n        \"store_currency_code\": \"\",\n        \"store_id\": 0,\n        \"store_name\": \"\",\n        \"store_to_base_rate\": \"\",\n        \"store_to_order_rate\": \"\",\n        \"subtotal\": \"\",\n        \"subtotal_canceled\": \"\",\n        \"subtotal_incl_tax\": \"\",\n        \"subtotal_invoiced\": \"\",\n        \"subtotal_refunded\": \"\",\n        \"tax_amount\": \"\",\n        \"tax_canceled\": \"\",\n        \"tax_invoiced\": \"\",\n        \"tax_refunded\": \"\",\n        \"total_canceled\": \"\",\n        \"total_due\": \"\",\n        \"total_invoiced\": \"\",\n        \"total_item_count\": 0,\n        \"total_offline_refunded\": \"\",\n        \"total_online_refunded\": \"\",\n        \"total_paid\": \"\",\n        \"total_qty_ordered\": \"\",\n        \"total_refunded\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\",\n        \"x_forwarded_for\": \"\"\n      },\n      \"vertex_tax_calculation_shipping_address\": {}\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"is_used_for_refund\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"total_qty\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\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/V1/invoices/') do |req|
  req.body = "{\n  \"entity\": {\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address_id\": 0,\n    \"can_void_flag\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_description\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"base_customer_balance_amount\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"customer_balance_amount\": \"\",\n      \"gift_cards_amount\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_price\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"vertex_tax_calculation_billing_address\": {\n        \"address_type\": \"\",\n        \"city\": \"\",\n        \"company\": \"\",\n        \"country_id\": \"\",\n        \"customer_address_id\": 0,\n        \"customer_id\": 0,\n        \"email\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"checkout_fields\": [\n            {\n              \"attribute_code\": \"\",\n              \"value\": \"\"\n            }\n          ]\n        },\n        \"fax\": \"\",\n        \"firstname\": \"\",\n        \"lastname\": \"\",\n        \"middlename\": \"\",\n        \"parent_id\": 0,\n        \"postcode\": \"\",\n        \"prefix\": \"\",\n        \"region\": \"\",\n        \"region_code\": \"\",\n        \"region_id\": 0,\n        \"street\": [],\n        \"suffix\": \"\",\n        \"telephone\": \"\",\n        \"vat_id\": \"\",\n        \"vat_is_valid\": 0,\n        \"vat_request_date\": \"\",\n        \"vat_request_id\": \"\",\n        \"vat_request_success\": 0\n      },\n      \"vertex_tax_calculation_order\": {\n        \"adjustment_negative\": \"\",\n        \"adjustment_positive\": \"\",\n        \"applied_rule_ids\": \"\",\n        \"base_adjustment_negative\": \"\",\n        \"base_adjustment_positive\": \"\",\n        \"base_currency_code\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_canceled\": \"\",\n        \"base_discount_invoiced\": \"\",\n        \"base_discount_refunded\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_discount_tax_compensation_invoiced\": \"\",\n        \"base_discount_tax_compensation_refunded\": \"\",\n        \"base_grand_total\": \"\",\n        \"base_shipping_amount\": \"\",\n        \"base_shipping_canceled\": \"\",\n        \"base_shipping_discount_amount\": \"\",\n        \"base_shipping_discount_tax_compensation_amnt\": \"\",\n        \"base_shipping_incl_tax\": \"\",\n        \"base_shipping_invoiced\": \"\",\n        \"base_shipping_refunded\": \"\",\n        \"base_shipping_tax_amount\": \"\",\n        \"base_shipping_tax_refunded\": \"\",\n        \"base_subtotal\": \"\",\n        \"base_subtotal_canceled\": \"\",\n        \"base_subtotal_incl_tax\": \"\",\n        \"base_subtotal_invoiced\": \"\",\n        \"base_subtotal_refunded\": \"\",\n        \"base_tax_amount\": \"\",\n        \"base_tax_canceled\": \"\",\n        \"base_tax_invoiced\": \"\",\n        \"base_tax_refunded\": \"\",\n        \"base_to_global_rate\": \"\",\n        \"base_to_order_rate\": \"\",\n        \"base_total_canceled\": \"\",\n        \"base_total_due\": \"\",\n        \"base_total_invoiced\": \"\",\n        \"base_total_invoiced_cost\": \"\",\n        \"base_total_offline_refunded\": \"\",\n        \"base_total_online_refunded\": \"\",\n        \"base_total_paid\": \"\",\n        \"base_total_qty_ordered\": \"\",\n        \"base_total_refunded\": \"\",\n        \"billing_address\": {},\n        \"billing_address_id\": 0,\n        \"can_ship_partially\": 0,\n        \"can_ship_partially_item\": 0,\n        \"coupon_code\": \"\",\n        \"created_at\": \"\",\n        \"customer_dob\": \"\",\n        \"customer_email\": \"\",\n        \"customer_firstname\": \"\",\n        \"customer_gender\": 0,\n        \"customer_group_id\": 0,\n        \"customer_id\": 0,\n        \"customer_is_guest\": 0,\n        \"customer_lastname\": \"\",\n        \"customer_middlename\": \"\",\n        \"customer_note\": \"\",\n        \"customer_note_notify\": 0,\n        \"customer_prefix\": \"\",\n        \"customer_suffix\": \"\",\n        \"customer_taxvat\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_canceled\": \"\",\n        \"discount_description\": \"\",\n        \"discount_invoiced\": \"\",\n        \"discount_refunded\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"discount_tax_compensation_invoiced\": \"\",\n        \"discount_tax_compensation_refunded\": \"\",\n        \"edit_increment\": 0,\n        \"email_sent\": 0,\n        \"entity_id\": 0,\n        \"ext_customer_id\": \"\",\n        \"ext_order_id\": \"\",\n        \"extension_attributes\": {\n          \"amazon_order_reference_id\": \"\",\n          \"applied_taxes\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"extension_attributes\": {\n                \"rates\": [\n                  {\n                    \"code\": \"\",\n                    \"extension_attributes\": {},\n                    \"percent\": \"\",\n                    \"title\": \"\"\n                  }\n                ]\n              },\n              \"percent\": \"\",\n              \"title\": \"\"\n            }\n          ],\n          \"base_customer_balance_amount\": \"\",\n          \"base_customer_balance_invoiced\": \"\",\n          \"base_customer_balance_refunded\": \"\",\n          \"base_customer_balance_total_refunded\": \"\",\n          \"base_gift_cards_amount\": \"\",\n          \"base_gift_cards_invoiced\": \"\",\n          \"base_gift_cards_refunded\": \"\",\n          \"base_reward_currency_amount\": \"\",\n          \"company_order_attributes\": {\n            \"company_id\": 0,\n            \"company_name\": \"\",\n            \"extension_attributes\": {},\n            \"order_id\": 0\n          },\n          \"converting_from_quote\": false,\n          \"customer_balance_amount\": \"\",\n          \"customer_balance_invoiced\": \"\",\n          \"customer_balance_refunded\": \"\",\n          \"customer_balance_total_refunded\": \"\",\n          \"gift_cards\": [\n            {\n              \"amount\": \"\",\n              \"base_amount\": \"\",\n              \"code\": \"\",\n              \"id\": 0\n            }\n          ],\n          \"gift_cards_amount\": \"\",\n          \"gift_cards_invoiced\": \"\",\n          \"gift_cards_refunded\": \"\",\n          \"gift_message\": {\n            \"customer_id\": 0,\n            \"extension_attributes\": {\n              \"entity_id\": \"\",\n              \"entity_type\": \"\",\n              \"wrapping_add_printed_card\": false,\n              \"wrapping_allow_gift_receipt\": false,\n              \"wrapping_id\": 0\n            },\n            \"gift_message_id\": 0,\n            \"message\": \"\",\n            \"recipient\": \"\",\n            \"sender\": \"\"\n          },\n          \"gw_add_card\": \"\",\n          \"gw_allow_gift_receipt\": \"\",\n          \"gw_base_price\": \"\",\n          \"gw_base_price_incl_tax\": \"\",\n          \"gw_base_price_invoiced\": \"\",\n          \"gw_base_price_refunded\": \"\",\n          \"gw_base_tax_amount\": \"\",\n          \"gw_base_tax_amount_invoiced\": \"\",\n          \"gw_base_tax_amount_refunded\": \"\",\n          \"gw_card_base_price\": \"\",\n          \"gw_card_base_price_incl_tax\": \"\",\n          \"gw_card_base_price_invoiced\": \"\",\n          \"gw_card_base_price_refunded\": \"\",\n          \"gw_card_base_tax_amount\": \"\",\n          \"gw_card_base_tax_invoiced\": \"\",\n          \"gw_card_base_tax_refunded\": \"\",\n          \"gw_card_price\": \"\",\n          \"gw_card_price_incl_tax\": \"\",\n          \"gw_card_price_invoiced\": \"\",\n          \"gw_card_price_refunded\": \"\",\n          \"gw_card_tax_amount\": \"\",\n          \"gw_card_tax_invoiced\": \"\",\n          \"gw_card_tax_refunded\": \"\",\n          \"gw_id\": \"\",\n          \"gw_items_base_price\": \"\",\n          \"gw_items_base_price_incl_tax\": \"\",\n          \"gw_items_base_price_invoiced\": \"\",\n          \"gw_items_base_price_refunded\": \"\",\n          \"gw_items_base_tax_amount\": \"\",\n          \"gw_items_base_tax_invoiced\": \"\",\n          \"gw_items_base_tax_refunded\": \"\",\n          \"gw_items_price\": \"\",\n          \"gw_items_price_incl_tax\": \"\",\n          \"gw_items_price_invoiced\": \"\",\n          \"gw_items_price_refunded\": \"\",\n          \"gw_items_tax_amount\": \"\",\n          \"gw_items_tax_invoiced\": \"\",\n          \"gw_items_tax_refunded\": \"\",\n          \"gw_price\": \"\",\n          \"gw_price_incl_tax\": \"\",\n          \"gw_price_invoiced\": \"\",\n          \"gw_price_refunded\": \"\",\n          \"gw_tax_amount\": \"\",\n          \"gw_tax_amount_invoiced\": \"\",\n          \"gw_tax_amount_refunded\": \"\",\n          \"item_applied_taxes\": [\n            {\n              \"applied_taxes\": [\n                {}\n              ],\n              \"associated_item_id\": 0,\n              \"extension_attributes\": {},\n              \"item_id\": 0,\n              \"type\": \"\"\n            }\n          ],\n          \"payment_additional_info\": [\n            {\n              \"key\": \"\",\n              \"value\": \"\"\n            }\n          ],\n          \"reward_currency_amount\": \"\",\n          \"reward_points_balance\": 0,\n          \"shipping_assignments\": [\n            {\n              \"extension_attributes\": {},\n              \"items\": [\n                {\n                  \"additional_data\": \"\",\n                  \"amount_refunded\": \"\",\n                  \"applied_rule_ids\": \"\",\n                  \"base_amount_refunded\": \"\",\n                  \"base_cost\": \"\",\n                  \"base_discount_amount\": \"\",\n                  \"base_discount_invoiced\": \"\",\n                  \"base_discount_refunded\": \"\",\n                  \"base_discount_tax_compensation_amount\": \"\",\n                  \"base_discount_tax_compensation_invoiced\": \"\",\n                  \"base_discount_tax_compensation_refunded\": \"\",\n                  \"base_original_price\": \"\",\n                  \"base_price\": \"\",\n                  \"base_price_incl_tax\": \"\",\n                  \"base_row_invoiced\": \"\",\n                  \"base_row_total\": \"\",\n                  \"base_row_total_incl_tax\": \"\",\n                  \"base_tax_amount\": \"\",\n                  \"base_tax_before_discount\": \"\",\n                  \"base_tax_invoiced\": \"\",\n                  \"base_tax_refunded\": \"\",\n                  \"base_weee_tax_applied_amount\": \"\",\n                  \"base_weee_tax_applied_row_amnt\": \"\",\n                  \"base_weee_tax_disposition\": \"\",\n                  \"base_weee_tax_row_disposition\": \"\",\n                  \"created_at\": \"\",\n                  \"description\": \"\",\n                  \"discount_amount\": \"\",\n                  \"discount_invoiced\": \"\",\n                  \"discount_percent\": \"\",\n                  \"discount_refunded\": \"\",\n                  \"discount_tax_compensation_amount\": \"\",\n                  \"discount_tax_compensation_canceled\": \"\",\n                  \"discount_tax_compensation_invoiced\": \"\",\n                  \"discount_tax_compensation_refunded\": \"\",\n                  \"event_id\": 0,\n                  \"ext_order_item_id\": \"\",\n                  \"extension_attributes\": {\n                    \"gift_message\": {},\n                    \"gw_base_price\": \"\",\n                    \"gw_base_price_invoiced\": \"\",\n                    \"gw_base_price_refunded\": \"\",\n                    \"gw_base_tax_amount\": \"\",\n                    \"gw_base_tax_amount_invoiced\": \"\",\n                    \"gw_base_tax_amount_refunded\": \"\",\n                    \"gw_id\": \"\",\n                    \"gw_price\": \"\",\n                    \"gw_price_invoiced\": \"\",\n                    \"gw_price_refunded\": \"\",\n                    \"gw_tax_amount\": \"\",\n                    \"gw_tax_amount_invoiced\": \"\",\n                    \"gw_tax_amount_refunded\": \"\",\n                    \"invoice_text_codes\": [],\n                    \"tax_codes\": [],\n                    \"vertex_tax_codes\": []\n                  },\n                  \"free_shipping\": 0,\n                  \"gw_base_price\": \"\",\n                  \"gw_base_price_invoiced\": \"\",\n                  \"gw_base_price_refunded\": \"\",\n                  \"gw_base_tax_amount\": \"\",\n                  \"gw_base_tax_amount_invoiced\": \"\",\n                  \"gw_base_tax_amount_refunded\": \"\",\n                  \"gw_id\": 0,\n                  \"gw_price\": \"\",\n                  \"gw_price_invoiced\": \"\",\n                  \"gw_price_refunded\": \"\",\n                  \"gw_tax_amount\": \"\",\n                  \"gw_tax_amount_invoiced\": \"\",\n                  \"gw_tax_amount_refunded\": \"\",\n                  \"is_qty_decimal\": 0,\n                  \"is_virtual\": 0,\n                  \"item_id\": 0,\n                  \"locked_do_invoice\": 0,\n                  \"locked_do_ship\": 0,\n                  \"name\": \"\",\n                  \"no_discount\": 0,\n                  \"order_id\": 0,\n                  \"original_price\": \"\",\n                  \"parent_item\": \"\",\n                  \"parent_item_id\": 0,\n                  \"price\": \"\",\n                  \"price_incl_tax\": \"\",\n                  \"product_id\": 0,\n                  \"product_option\": {\n                    \"extension_attributes\": {\n                      \"bundle_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": 0,\n                          \"option_qty\": 0,\n                          \"option_selections\": []\n                        }\n                      ],\n                      \"configurable_item_options\": [\n                        {\n                          \"extension_attributes\": {},\n                          \"option_id\": \"\",\n                          \"option_value\": 0\n                        }\n                      ],\n                      \"custom_options\": [\n                        {\n                          \"extension_attributes\": {\n                            \"file_info\": {\n                              \"base64_encoded_data\": \"\",\n                              \"name\": \"\",\n                              \"type\": \"\"\n                            }\n                          },\n                          \"option_id\": \"\",\n                          \"option_value\": \"\"\n                        }\n                      ],\n                      \"downloadable_option\": {\n                        \"downloadable_links\": []\n                      },\n                      \"giftcard_item_option\": {\n                        \"custom_giftcard_amount\": \"\",\n                        \"extension_attributes\": {},\n                        \"giftcard_amount\": \"\",\n                        \"giftcard_message\": \"\",\n                        \"giftcard_recipient_email\": \"\",\n                        \"giftcard_recipient_name\": \"\",\n                        \"giftcard_sender_email\": \"\",\n                        \"giftcard_sender_name\": \"\"\n                      }\n                    }\n                  },\n                  \"product_type\": \"\",\n                  \"qty_backordered\": \"\",\n                  \"qty_canceled\": \"\",\n                  \"qty_invoiced\": \"\",\n                  \"qty_ordered\": \"\",\n                  \"qty_refunded\": \"\",\n                  \"qty_returned\": \"\",\n                  \"qty_shipped\": \"\",\n                  \"quote_item_id\": 0,\n                  \"row_invoiced\": \"\",\n                  \"row_total\": \"\",\n                  \"row_total_incl_tax\": \"\",\n                  \"row_weight\": \"\",\n                  \"sku\": \"\",\n                  \"store_id\": 0,\n                  \"tax_amount\": \"\",\n                  \"tax_before_discount\": \"\",\n                  \"tax_canceled\": \"\",\n                  \"tax_invoiced\": \"\",\n                  \"tax_percent\": \"\",\n                  \"tax_refunded\": \"\",\n                  \"updated_at\": \"\",\n                  \"weee_tax_applied\": \"\",\n                  \"weee_tax_applied_amount\": \"\",\n                  \"weee_tax_applied_row_amount\": \"\",\n                  \"weee_tax_disposition\": \"\",\n                  \"weee_tax_row_disposition\": \"\",\n                  \"weight\": \"\"\n                }\n              ],\n              \"shipping\": {\n                \"address\": {},\n                \"extension_attributes\": {\n                  \"collection_point\": {\n                    \"city\": \"\",\n                    \"collection_point_id\": \"\",\n                    \"country\": \"\",\n                    \"name\": \"\",\n                    \"postcode\": \"\",\n                    \"recipient_address_id\": 0,\n                    \"region\": \"\",\n                    \"street\": []\n                  },\n                  \"ext_order_id\": \"\",\n                  \"shipping_experience\": {\n                    \"code\": \"\",\n                    \"cost\": \"\",\n                    \"label\": \"\"\n                  }\n                },\n                \"method\": \"\",\n                \"total\": {\n                  \"base_shipping_amount\": \"\",\n                  \"base_shipping_canceled\": \"\",\n                  \"base_shipping_discount_amount\": \"\",\n                  \"base_shipping_discount_tax_compensation_amnt\": \"\",\n                  \"base_shipping_incl_tax\": \"\",\n                  \"base_shipping_invoiced\": \"\",\n                  \"base_shipping_refunded\": \"\",\n                  \"base_shipping_tax_amount\": \"\",\n                  \"base_shipping_tax_refunded\": \"\",\n                  \"extension_attributes\": {},\n                  \"shipping_amount\": \"\",\n                  \"shipping_canceled\": \"\",\n                  \"shipping_discount_amount\": \"\",\n                  \"shipping_discount_tax_compensation_amount\": \"\",\n                  \"shipping_incl_tax\": \"\",\n                  \"shipping_invoiced\": \"\",\n                  \"shipping_refunded\": \"\",\n                  \"shipping_tax_amount\": \"\",\n                  \"shipping_tax_refunded\": \"\"\n                }\n              },\n              \"stock_id\": 0\n            }\n          ]\n        },\n        \"forced_shipment_with_invoice\": 0,\n        \"global_currency_code\": \"\",\n        \"grand_total\": \"\",\n        \"hold_before_state\": \"\",\n        \"hold_before_status\": \"\",\n        \"increment_id\": \"\",\n        \"is_virtual\": 0,\n        \"items\": [\n          {}\n        ],\n        \"order_currency_code\": \"\",\n        \"original_increment_id\": \"\",\n        \"payment\": {\n          \"account_status\": \"\",\n          \"additional_data\": \"\",\n          \"additional_information\": [],\n          \"address_status\": \"\",\n          \"amount_authorized\": \"\",\n          \"amount_canceled\": \"\",\n          \"amount_ordered\": \"\",\n          \"amount_paid\": \"\",\n          \"amount_refunded\": \"\",\n          \"anet_trans_method\": \"\",\n          \"base_amount_authorized\": \"\",\n          \"base_amount_canceled\": \"\",\n          \"base_amount_ordered\": \"\",\n          \"base_amount_paid\": \"\",\n          \"base_amount_paid_online\": \"\",\n          \"base_amount_refunded\": \"\",\n          \"base_amount_refunded_online\": \"\",\n          \"base_shipping_amount\": \"\",\n          \"base_shipping_captured\": \"\",\n          \"base_shipping_refunded\": \"\",\n          \"cc_approval\": \"\",\n          \"cc_avs_status\": \"\",\n          \"cc_cid_status\": \"\",\n          \"cc_debug_request_body\": \"\",\n          \"cc_debug_response_body\": \"\",\n          \"cc_debug_response_serialized\": \"\",\n          \"cc_exp_month\": \"\",\n          \"cc_exp_year\": \"\",\n          \"cc_last4\": \"\",\n          \"cc_number_enc\": \"\",\n          \"cc_owner\": \"\",\n          \"cc_secure_verify\": \"\",\n          \"cc_ss_issue\": \"\",\n          \"cc_ss_start_month\": \"\",\n          \"cc_ss_start_year\": \"\",\n          \"cc_status\": \"\",\n          \"cc_status_description\": \"\",\n          \"cc_trans_id\": \"\",\n          \"cc_type\": \"\",\n          \"echeck_account_name\": \"\",\n          \"echeck_account_type\": \"\",\n          \"echeck_bank_name\": \"\",\n          \"echeck_routing_number\": \"\",\n          \"echeck_type\": \"\",\n          \"entity_id\": 0,\n          \"extension_attributes\": {\n            \"vault_payment_token\": {\n              \"created_at\": \"\",\n              \"customer_id\": 0,\n              \"entity_id\": 0,\n              \"expires_at\": \"\",\n              \"gateway_token\": \"\",\n              \"is_active\": false,\n              \"is_visible\": false,\n              \"payment_method_code\": \"\",\n              \"public_hash\": \"\",\n              \"token_details\": \"\",\n              \"type\": \"\"\n            }\n          },\n          \"last_trans_id\": \"\",\n          \"method\": \"\",\n          \"parent_id\": 0,\n          \"po_number\": \"\",\n          \"protection_eligibility\": \"\",\n          \"quote_payment_id\": 0,\n          \"shipping_amount\": \"\",\n          \"shipping_captured\": \"\",\n          \"shipping_refunded\": \"\"\n        },\n        \"payment_auth_expiration\": 0,\n        \"payment_authorization_amount\": \"\",\n        \"protect_code\": \"\",\n        \"quote_address_id\": 0,\n        \"quote_id\": 0,\n        \"relation_child_id\": \"\",\n        \"relation_child_real_id\": \"\",\n        \"relation_parent_id\": \"\",\n        \"relation_parent_real_id\": \"\",\n        \"remote_ip\": \"\",\n        \"shipping_amount\": \"\",\n        \"shipping_canceled\": \"\",\n        \"shipping_description\": \"\",\n        \"shipping_discount_amount\": \"\",\n        \"shipping_discount_tax_compensation_amount\": \"\",\n        \"shipping_incl_tax\": \"\",\n        \"shipping_invoiced\": \"\",\n        \"shipping_refunded\": \"\",\n        \"shipping_tax_amount\": \"\",\n        \"shipping_tax_refunded\": \"\",\n        \"state\": \"\",\n        \"status\": \"\",\n        \"status_histories\": [\n          {\n            \"comment\": \"\",\n            \"created_at\": \"\",\n            \"entity_id\": 0,\n            \"entity_name\": \"\",\n            \"extension_attributes\": {},\n            \"is_customer_notified\": 0,\n            \"is_visible_on_front\": 0,\n            \"parent_id\": 0,\n            \"status\": \"\"\n          }\n        ],\n        \"store_currency_code\": \"\",\n        \"store_id\": 0,\n        \"store_name\": \"\",\n        \"store_to_base_rate\": \"\",\n        \"store_to_order_rate\": \"\",\n        \"subtotal\": \"\",\n        \"subtotal_canceled\": \"\",\n        \"subtotal_incl_tax\": \"\",\n        \"subtotal_invoiced\": \"\",\n        \"subtotal_refunded\": \"\",\n        \"tax_amount\": \"\",\n        \"tax_canceled\": \"\",\n        \"tax_invoiced\": \"\",\n        \"tax_refunded\": \"\",\n        \"total_canceled\": \"\",\n        \"total_due\": \"\",\n        \"total_invoiced\": \"\",\n        \"total_item_count\": 0,\n        \"total_offline_refunded\": \"\",\n        \"total_online_refunded\": \"\",\n        \"total_paid\": \"\",\n        \"total_qty_ordered\": \"\",\n        \"total_refunded\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\",\n        \"x_forwarded_for\": \"\"\n      },\n      \"vertex_tax_calculation_shipping_address\": {}\n    },\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"increment_id\": \"\",\n    \"is_used_for_refund\": 0,\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"base_cost\": \"\",\n        \"base_discount_amount\": \"\",\n        \"base_discount_tax_compensation_amount\": \"\",\n        \"base_price\": \"\",\n        \"base_price_incl_tax\": \"\",\n        \"base_row_total\": \"\",\n        \"base_row_total_incl_tax\": \"\",\n        \"base_tax_amount\": \"\",\n        \"description\": \"\",\n        \"discount_amount\": \"\",\n        \"discount_tax_compensation_amount\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {\n          \"invoice_text_codes\": [],\n          \"tax_codes\": [],\n          \"vertex_tax_codes\": []\n        },\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"price_incl_tax\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"row_total_incl_tax\": \"\",\n        \"sku\": \"\",\n        \"tax_amount\": \"\"\n      }\n    ],\n    \"order_currency_code\": \"\",\n    \"order_id\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"state\": 0,\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"tax_amount\": \"\",\n    \"total_qty\": \"\",\n    \"transaction_id\": \"\",\n    \"updated_at\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/invoices/";

    let payload = json!({"entity": json!({
            "base_currency_code": "",
            "base_discount_amount": "",
            "base_discount_tax_compensation_amount": "",
            "base_grand_total": "",
            "base_shipping_amount": "",
            "base_shipping_discount_tax_compensation_amnt": "",
            "base_shipping_incl_tax": "",
            "base_shipping_tax_amount": "",
            "base_subtotal": "",
            "base_subtotal_incl_tax": "",
            "base_tax_amount": "",
            "base_to_global_rate": "",
            "base_to_order_rate": "",
            "base_total_refunded": "",
            "billing_address_id": 0,
            "can_void_flag": 0,
            "comments": (
                json!({
                    "comment": "",
                    "created_at": "",
                    "entity_id": 0,
                    "extension_attributes": json!({}),
                    "is_customer_notified": 0,
                    "is_visible_on_front": 0,
                    "parent_id": 0
                })
            ),
            "created_at": "",
            "discount_amount": "",
            "discount_description": "",
            "discount_tax_compensation_amount": "",
            "email_sent": 0,
            "entity_id": 0,
            "extension_attributes": json!({
                "base_customer_balance_amount": "",
                "base_gift_cards_amount": "",
                "customer_balance_amount": "",
                "gift_cards_amount": "",
                "gw_base_price": "",
                "gw_base_tax_amount": "",
                "gw_card_base_price": "",
                "gw_card_base_tax_amount": "",
                "gw_card_price": "",
                "gw_card_tax_amount": "",
                "gw_items_base_price": "",
                "gw_items_base_tax_amount": "",
                "gw_items_price": "",
                "gw_items_tax_amount": "",
                "gw_price": "",
                "gw_tax_amount": "",
                "vertex_tax_calculation_billing_address": json!({
                    "address_type": "",
                    "city": "",
                    "company": "",
                    "country_id": "",
                    "customer_address_id": 0,
                    "customer_id": 0,
                    "email": "",
                    "entity_id": 0,
                    "extension_attributes": json!({"checkout_fields": (
                            json!({
                                "attribute_code": "",
                                "value": ""
                            })
                        )}),
                    "fax": "",
                    "firstname": "",
                    "lastname": "",
                    "middlename": "",
                    "parent_id": 0,
                    "postcode": "",
                    "prefix": "",
                    "region": "",
                    "region_code": "",
                    "region_id": 0,
                    "street": (),
                    "suffix": "",
                    "telephone": "",
                    "vat_id": "",
                    "vat_is_valid": 0,
                    "vat_request_date": "",
                    "vat_request_id": "",
                    "vat_request_success": 0
                }),
                "vertex_tax_calculation_order": json!({
                    "adjustment_negative": "",
                    "adjustment_positive": "",
                    "applied_rule_ids": "",
                    "base_adjustment_negative": "",
                    "base_adjustment_positive": "",
                    "base_currency_code": "",
                    "base_discount_amount": "",
                    "base_discount_canceled": "",
                    "base_discount_invoiced": "",
                    "base_discount_refunded": "",
                    "base_discount_tax_compensation_amount": "",
                    "base_discount_tax_compensation_invoiced": "",
                    "base_discount_tax_compensation_refunded": "",
                    "base_grand_total": "",
                    "base_shipping_amount": "",
                    "base_shipping_canceled": "",
                    "base_shipping_discount_amount": "",
                    "base_shipping_discount_tax_compensation_amnt": "",
                    "base_shipping_incl_tax": "",
                    "base_shipping_invoiced": "",
                    "base_shipping_refunded": "",
                    "base_shipping_tax_amount": "",
                    "base_shipping_tax_refunded": "",
                    "base_subtotal": "",
                    "base_subtotal_canceled": "",
                    "base_subtotal_incl_tax": "",
                    "base_subtotal_invoiced": "",
                    "base_subtotal_refunded": "",
                    "base_tax_amount": "",
                    "base_tax_canceled": "",
                    "base_tax_invoiced": "",
                    "base_tax_refunded": "",
                    "base_to_global_rate": "",
                    "base_to_order_rate": "",
                    "base_total_canceled": "",
                    "base_total_due": "",
                    "base_total_invoiced": "",
                    "base_total_invoiced_cost": "",
                    "base_total_offline_refunded": "",
                    "base_total_online_refunded": "",
                    "base_total_paid": "",
                    "base_total_qty_ordered": "",
                    "base_total_refunded": "",
                    "billing_address": json!({}),
                    "billing_address_id": 0,
                    "can_ship_partially": 0,
                    "can_ship_partially_item": 0,
                    "coupon_code": "",
                    "created_at": "",
                    "customer_dob": "",
                    "customer_email": "",
                    "customer_firstname": "",
                    "customer_gender": 0,
                    "customer_group_id": 0,
                    "customer_id": 0,
                    "customer_is_guest": 0,
                    "customer_lastname": "",
                    "customer_middlename": "",
                    "customer_note": "",
                    "customer_note_notify": 0,
                    "customer_prefix": "",
                    "customer_suffix": "",
                    "customer_taxvat": "",
                    "discount_amount": "",
                    "discount_canceled": "",
                    "discount_description": "",
                    "discount_invoiced": "",
                    "discount_refunded": "",
                    "discount_tax_compensation_amount": "",
                    "discount_tax_compensation_invoiced": "",
                    "discount_tax_compensation_refunded": "",
                    "edit_increment": 0,
                    "email_sent": 0,
                    "entity_id": 0,
                    "ext_customer_id": "",
                    "ext_order_id": "",
                    "extension_attributes": json!({
                        "amazon_order_reference_id": "",
                        "applied_taxes": (
                            json!({
                                "amount": "",
                                "base_amount": "",
                                "code": "",
                                "extension_attributes": json!({"rates": (
                                        json!({
                                            "code": "",
                                            "extension_attributes": json!({}),
                                            "percent": "",
                                            "title": ""
                                        })
                                    )}),
                                "percent": "",
                                "title": ""
                            })
                        ),
                        "base_customer_balance_amount": "",
                        "base_customer_balance_invoiced": "",
                        "base_customer_balance_refunded": "",
                        "base_customer_balance_total_refunded": "",
                        "base_gift_cards_amount": "",
                        "base_gift_cards_invoiced": "",
                        "base_gift_cards_refunded": "",
                        "base_reward_currency_amount": "",
                        "company_order_attributes": json!({
                            "company_id": 0,
                            "company_name": "",
                            "extension_attributes": json!({}),
                            "order_id": 0
                        }),
                        "converting_from_quote": false,
                        "customer_balance_amount": "",
                        "customer_balance_invoiced": "",
                        "customer_balance_refunded": "",
                        "customer_balance_total_refunded": "",
                        "gift_cards": (
                            json!({
                                "amount": "",
                                "base_amount": "",
                                "code": "",
                                "id": 0
                            })
                        ),
                        "gift_cards_amount": "",
                        "gift_cards_invoiced": "",
                        "gift_cards_refunded": "",
                        "gift_message": json!({
                            "customer_id": 0,
                            "extension_attributes": json!({
                                "entity_id": "",
                                "entity_type": "",
                                "wrapping_add_printed_card": false,
                                "wrapping_allow_gift_receipt": false,
                                "wrapping_id": 0
                            }),
                            "gift_message_id": 0,
                            "message": "",
                            "recipient": "",
                            "sender": ""
                        }),
                        "gw_add_card": "",
                        "gw_allow_gift_receipt": "",
                        "gw_base_price": "",
                        "gw_base_price_incl_tax": "",
                        "gw_base_price_invoiced": "",
                        "gw_base_price_refunded": "",
                        "gw_base_tax_amount": "",
                        "gw_base_tax_amount_invoiced": "",
                        "gw_base_tax_amount_refunded": "",
                        "gw_card_base_price": "",
                        "gw_card_base_price_incl_tax": "",
                        "gw_card_base_price_invoiced": "",
                        "gw_card_base_price_refunded": "",
                        "gw_card_base_tax_amount": "",
                        "gw_card_base_tax_invoiced": "",
                        "gw_card_base_tax_refunded": "",
                        "gw_card_price": "",
                        "gw_card_price_incl_tax": "",
                        "gw_card_price_invoiced": "",
                        "gw_card_price_refunded": "",
                        "gw_card_tax_amount": "",
                        "gw_card_tax_invoiced": "",
                        "gw_card_tax_refunded": "",
                        "gw_id": "",
                        "gw_items_base_price": "",
                        "gw_items_base_price_incl_tax": "",
                        "gw_items_base_price_invoiced": "",
                        "gw_items_base_price_refunded": "",
                        "gw_items_base_tax_amount": "",
                        "gw_items_base_tax_invoiced": "",
                        "gw_items_base_tax_refunded": "",
                        "gw_items_price": "",
                        "gw_items_price_incl_tax": "",
                        "gw_items_price_invoiced": "",
                        "gw_items_price_refunded": "",
                        "gw_items_tax_amount": "",
                        "gw_items_tax_invoiced": "",
                        "gw_items_tax_refunded": "",
                        "gw_price": "",
                        "gw_price_incl_tax": "",
                        "gw_price_invoiced": "",
                        "gw_price_refunded": "",
                        "gw_tax_amount": "",
                        "gw_tax_amount_invoiced": "",
                        "gw_tax_amount_refunded": "",
                        "item_applied_taxes": (
                            json!({
                                "applied_taxes": (json!({})),
                                "associated_item_id": 0,
                                "extension_attributes": json!({}),
                                "item_id": 0,
                                "type": ""
                            })
                        ),
                        "payment_additional_info": (
                            json!({
                                "key": "",
                                "value": ""
                            })
                        ),
                        "reward_currency_amount": "",
                        "reward_points_balance": 0,
                        "shipping_assignments": (
                            json!({
                                "extension_attributes": json!({}),
                                "items": (
                                    json!({
                                        "additional_data": "",
                                        "amount_refunded": "",
                                        "applied_rule_ids": "",
                                        "base_amount_refunded": "",
                                        "base_cost": "",
                                        "base_discount_amount": "",
                                        "base_discount_invoiced": "",
                                        "base_discount_refunded": "",
                                        "base_discount_tax_compensation_amount": "",
                                        "base_discount_tax_compensation_invoiced": "",
                                        "base_discount_tax_compensation_refunded": "",
                                        "base_original_price": "",
                                        "base_price": "",
                                        "base_price_incl_tax": "",
                                        "base_row_invoiced": "",
                                        "base_row_total": "",
                                        "base_row_total_incl_tax": "",
                                        "base_tax_amount": "",
                                        "base_tax_before_discount": "",
                                        "base_tax_invoiced": "",
                                        "base_tax_refunded": "",
                                        "base_weee_tax_applied_amount": "",
                                        "base_weee_tax_applied_row_amnt": "",
                                        "base_weee_tax_disposition": "",
                                        "base_weee_tax_row_disposition": "",
                                        "created_at": "",
                                        "description": "",
                                        "discount_amount": "",
                                        "discount_invoiced": "",
                                        "discount_percent": "",
                                        "discount_refunded": "",
                                        "discount_tax_compensation_amount": "",
                                        "discount_tax_compensation_canceled": "",
                                        "discount_tax_compensation_invoiced": "",
                                        "discount_tax_compensation_refunded": "",
                                        "event_id": 0,
                                        "ext_order_item_id": "",
                                        "extension_attributes": json!({
                                            "gift_message": json!({}),
                                            "gw_base_price": "",
                                            "gw_base_price_invoiced": "",
                                            "gw_base_price_refunded": "",
                                            "gw_base_tax_amount": "",
                                            "gw_base_tax_amount_invoiced": "",
                                            "gw_base_tax_amount_refunded": "",
                                            "gw_id": "",
                                            "gw_price": "",
                                            "gw_price_invoiced": "",
                                            "gw_price_refunded": "",
                                            "gw_tax_amount": "",
                                            "gw_tax_amount_invoiced": "",
                                            "gw_tax_amount_refunded": "",
                                            "invoice_text_codes": (),
                                            "tax_codes": (),
                                            "vertex_tax_codes": ()
                                        }),
                                        "free_shipping": 0,
                                        "gw_base_price": "",
                                        "gw_base_price_invoiced": "",
                                        "gw_base_price_refunded": "",
                                        "gw_base_tax_amount": "",
                                        "gw_base_tax_amount_invoiced": "",
                                        "gw_base_tax_amount_refunded": "",
                                        "gw_id": 0,
                                        "gw_price": "",
                                        "gw_price_invoiced": "",
                                        "gw_price_refunded": "",
                                        "gw_tax_amount": "",
                                        "gw_tax_amount_invoiced": "",
                                        "gw_tax_amount_refunded": "",
                                        "is_qty_decimal": 0,
                                        "is_virtual": 0,
                                        "item_id": 0,
                                        "locked_do_invoice": 0,
                                        "locked_do_ship": 0,
                                        "name": "",
                                        "no_discount": 0,
                                        "order_id": 0,
                                        "original_price": "",
                                        "parent_item": "",
                                        "parent_item_id": 0,
                                        "price": "",
                                        "price_incl_tax": "",
                                        "product_id": 0,
                                        "product_option": json!({"extension_attributes": json!({
                                                "bundle_options": (
                                                    json!({
                                                        "extension_attributes": json!({}),
                                                        "option_id": 0,
                                                        "option_qty": 0,
                                                        "option_selections": ()
                                                    })
                                                ),
                                                "configurable_item_options": (
                                                    json!({
                                                        "extension_attributes": json!({}),
                                                        "option_id": "",
                                                        "option_value": 0
                                                    })
                                                ),
                                                "custom_options": (
                                                    json!({
                                                        "extension_attributes": json!({"file_info": json!({
                                                                "base64_encoded_data": "",
                                                                "name": "",
                                                                "type": ""
                                                            })}),
                                                        "option_id": "",
                                                        "option_value": ""
                                                    })
                                                ),
                                                "downloadable_option": json!({"downloadable_links": ()}),
                                                "giftcard_item_option": json!({
                                                    "custom_giftcard_amount": "",
                                                    "extension_attributes": json!({}),
                                                    "giftcard_amount": "",
                                                    "giftcard_message": "",
                                                    "giftcard_recipient_email": "",
                                                    "giftcard_recipient_name": "",
                                                    "giftcard_sender_email": "",
                                                    "giftcard_sender_name": ""
                                                })
                                            })}),
                                        "product_type": "",
                                        "qty_backordered": "",
                                        "qty_canceled": "",
                                        "qty_invoiced": "",
                                        "qty_ordered": "",
                                        "qty_refunded": "",
                                        "qty_returned": "",
                                        "qty_shipped": "",
                                        "quote_item_id": 0,
                                        "row_invoiced": "",
                                        "row_total": "",
                                        "row_total_incl_tax": "",
                                        "row_weight": "",
                                        "sku": "",
                                        "store_id": 0,
                                        "tax_amount": "",
                                        "tax_before_discount": "",
                                        "tax_canceled": "",
                                        "tax_invoiced": "",
                                        "tax_percent": "",
                                        "tax_refunded": "",
                                        "updated_at": "",
                                        "weee_tax_applied": "",
                                        "weee_tax_applied_amount": "",
                                        "weee_tax_applied_row_amount": "",
                                        "weee_tax_disposition": "",
                                        "weee_tax_row_disposition": "",
                                        "weight": ""
                                    })
                                ),
                                "shipping": json!({
                                    "address": json!({}),
                                    "extension_attributes": json!({
                                        "collection_point": json!({
                                            "city": "",
                                            "collection_point_id": "",
                                            "country": "",
                                            "name": "",
                                            "postcode": "",
                                            "recipient_address_id": 0,
                                            "region": "",
                                            "street": ()
                                        }),
                                        "ext_order_id": "",
                                        "shipping_experience": json!({
                                            "code": "",
                                            "cost": "",
                                            "label": ""
                                        })
                                    }),
                                    "method": "",
                                    "total": json!({
                                        "base_shipping_amount": "",
                                        "base_shipping_canceled": "",
                                        "base_shipping_discount_amount": "",
                                        "base_shipping_discount_tax_compensation_amnt": "",
                                        "base_shipping_incl_tax": "",
                                        "base_shipping_invoiced": "",
                                        "base_shipping_refunded": "",
                                        "base_shipping_tax_amount": "",
                                        "base_shipping_tax_refunded": "",
                                        "extension_attributes": json!({}),
                                        "shipping_amount": "",
                                        "shipping_canceled": "",
                                        "shipping_discount_amount": "",
                                        "shipping_discount_tax_compensation_amount": "",
                                        "shipping_incl_tax": "",
                                        "shipping_invoiced": "",
                                        "shipping_refunded": "",
                                        "shipping_tax_amount": "",
                                        "shipping_tax_refunded": ""
                                    })
                                }),
                                "stock_id": 0
                            })
                        )
                    }),
                    "forced_shipment_with_invoice": 0,
                    "global_currency_code": "",
                    "grand_total": "",
                    "hold_before_state": "",
                    "hold_before_status": "",
                    "increment_id": "",
                    "is_virtual": 0,
                    "items": (json!({})),
                    "order_currency_code": "",
                    "original_increment_id": "",
                    "payment": json!({
                        "account_status": "",
                        "additional_data": "",
                        "additional_information": (),
                        "address_status": "",
                        "amount_authorized": "",
                        "amount_canceled": "",
                        "amount_ordered": "",
                        "amount_paid": "",
                        "amount_refunded": "",
                        "anet_trans_method": "",
                        "base_amount_authorized": "",
                        "base_amount_canceled": "",
                        "base_amount_ordered": "",
                        "base_amount_paid": "",
                        "base_amount_paid_online": "",
                        "base_amount_refunded": "",
                        "base_amount_refunded_online": "",
                        "base_shipping_amount": "",
                        "base_shipping_captured": "",
                        "base_shipping_refunded": "",
                        "cc_approval": "",
                        "cc_avs_status": "",
                        "cc_cid_status": "",
                        "cc_debug_request_body": "",
                        "cc_debug_response_body": "",
                        "cc_debug_response_serialized": "",
                        "cc_exp_month": "",
                        "cc_exp_year": "",
                        "cc_last4": "",
                        "cc_number_enc": "",
                        "cc_owner": "",
                        "cc_secure_verify": "",
                        "cc_ss_issue": "",
                        "cc_ss_start_month": "",
                        "cc_ss_start_year": "",
                        "cc_status": "",
                        "cc_status_description": "",
                        "cc_trans_id": "",
                        "cc_type": "",
                        "echeck_account_name": "",
                        "echeck_account_type": "",
                        "echeck_bank_name": "",
                        "echeck_routing_number": "",
                        "echeck_type": "",
                        "entity_id": 0,
                        "extension_attributes": json!({"vault_payment_token": json!({
                                "created_at": "",
                                "customer_id": 0,
                                "entity_id": 0,
                                "expires_at": "",
                                "gateway_token": "",
                                "is_active": false,
                                "is_visible": false,
                                "payment_method_code": "",
                                "public_hash": "",
                                "token_details": "",
                                "type": ""
                            })}),
                        "last_trans_id": "",
                        "method": "",
                        "parent_id": 0,
                        "po_number": "",
                        "protection_eligibility": "",
                        "quote_payment_id": 0,
                        "shipping_amount": "",
                        "shipping_captured": "",
                        "shipping_refunded": ""
                    }),
                    "payment_auth_expiration": 0,
                    "payment_authorization_amount": "",
                    "protect_code": "",
                    "quote_address_id": 0,
                    "quote_id": 0,
                    "relation_child_id": "",
                    "relation_child_real_id": "",
                    "relation_parent_id": "",
                    "relation_parent_real_id": "",
                    "remote_ip": "",
                    "shipping_amount": "",
                    "shipping_canceled": "",
                    "shipping_description": "",
                    "shipping_discount_amount": "",
                    "shipping_discount_tax_compensation_amount": "",
                    "shipping_incl_tax": "",
                    "shipping_invoiced": "",
                    "shipping_refunded": "",
                    "shipping_tax_amount": "",
                    "shipping_tax_refunded": "",
                    "state": "",
                    "status": "",
                    "status_histories": (
                        json!({
                            "comment": "",
                            "created_at": "",
                            "entity_id": 0,
                            "entity_name": "",
                            "extension_attributes": json!({}),
                            "is_customer_notified": 0,
                            "is_visible_on_front": 0,
                            "parent_id": 0,
                            "status": ""
                        })
                    ),
                    "store_currency_code": "",
                    "store_id": 0,
                    "store_name": "",
                    "store_to_base_rate": "",
                    "store_to_order_rate": "",
                    "subtotal": "",
                    "subtotal_canceled": "",
                    "subtotal_incl_tax": "",
                    "subtotal_invoiced": "",
                    "subtotal_refunded": "",
                    "tax_amount": "",
                    "tax_canceled": "",
                    "tax_invoiced": "",
                    "tax_refunded": "",
                    "total_canceled": "",
                    "total_due": "",
                    "total_invoiced": "",
                    "total_item_count": 0,
                    "total_offline_refunded": "",
                    "total_online_refunded": "",
                    "total_paid": "",
                    "total_qty_ordered": "",
                    "total_refunded": "",
                    "updated_at": "",
                    "weight": "",
                    "x_forwarded_for": ""
                }),
                "vertex_tax_calculation_shipping_address": json!({})
            }),
            "global_currency_code": "",
            "grand_total": "",
            "increment_id": "",
            "is_used_for_refund": 0,
            "items": (
                json!({
                    "additional_data": "",
                    "base_cost": "",
                    "base_discount_amount": "",
                    "base_discount_tax_compensation_amount": "",
                    "base_price": "",
                    "base_price_incl_tax": "",
                    "base_row_total": "",
                    "base_row_total_incl_tax": "",
                    "base_tax_amount": "",
                    "description": "",
                    "discount_amount": "",
                    "discount_tax_compensation_amount": "",
                    "entity_id": 0,
                    "extension_attributes": json!({
                        "invoice_text_codes": (),
                        "tax_codes": (),
                        "vertex_tax_codes": ()
                    }),
                    "name": "",
                    "order_item_id": 0,
                    "parent_id": 0,
                    "price": "",
                    "price_incl_tax": "",
                    "product_id": 0,
                    "qty": "",
                    "row_total": "",
                    "row_total_incl_tax": "",
                    "sku": "",
                    "tax_amount": ""
                })
            ),
            "order_currency_code": "",
            "order_id": 0,
            "shipping_address_id": 0,
            "shipping_amount": "",
            "shipping_discount_tax_compensation_amount": "",
            "shipping_incl_tax": "",
            "shipping_tax_amount": "",
            "state": 0,
            "store_currency_code": "",
            "store_id": 0,
            "store_to_base_rate": "",
            "store_to_order_rate": "",
            "subtotal": "",
            "subtotal_incl_tax": "",
            "tax_amount": "",
            "total_qty": "",
            "transaction_id": "",
            "updated_at": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/invoices/ \
  --header 'content-type: application/json' \
  --data '{
  "entity": {
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_refunded": "",
    "billing_address_id": 0,
    "can_void_flag": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": "",
      "vertex_tax_calculation_billing_address": {
        "address_type": "",
        "city": "",
        "company": "",
        "country_id": "",
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "entity_id": 0,
        "extension_attributes": {
          "checkout_fields": [
            {
              "attribute_code": "",
              "value": ""
            }
          ]
        },
        "fax": "",
        "firstname": "",
        "lastname": "",
        "middlename": "",
        "parent_id": 0,
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": "",
        "vat_is_valid": 0,
        "vat_request_date": "",
        "vat_request_id": "",
        "vat_request_success": 0
      },
      "vertex_tax_calculation_order": {
        "adjustment_negative": "",
        "adjustment_positive": "",
        "applied_rule_ids": "",
        "base_adjustment_negative": "",
        "base_adjustment_positive": "",
        "base_currency_code": "",
        "base_discount_amount": "",
        "base_discount_canceled": "",
        "base_discount_invoiced": "",
        "base_discount_refunded": "",
        "base_discount_tax_compensation_amount": "",
        "base_discount_tax_compensation_invoiced": "",
        "base_discount_tax_compensation_refunded": "",
        "base_grand_total": "",
        "base_shipping_amount": "",
        "base_shipping_canceled": "",
        "base_shipping_discount_amount": "",
        "base_shipping_discount_tax_compensation_amnt": "",
        "base_shipping_incl_tax": "",
        "base_shipping_invoiced": "",
        "base_shipping_refunded": "",
        "base_shipping_tax_amount": "",
        "base_shipping_tax_refunded": "",
        "base_subtotal": "",
        "base_subtotal_canceled": "",
        "base_subtotal_incl_tax": "",
        "base_subtotal_invoiced": "",
        "base_subtotal_refunded": "",
        "base_tax_amount": "",
        "base_tax_canceled": "",
        "base_tax_invoiced": "",
        "base_tax_refunded": "",
        "base_to_global_rate": "",
        "base_to_order_rate": "",
        "base_total_canceled": "",
        "base_total_due": "",
        "base_total_invoiced": "",
        "base_total_invoiced_cost": "",
        "base_total_offline_refunded": "",
        "base_total_online_refunded": "",
        "base_total_paid": "",
        "base_total_qty_ordered": "",
        "base_total_refunded": "",
        "billing_address": {},
        "billing_address_id": 0,
        "can_ship_partially": 0,
        "can_ship_partially_item": 0,
        "coupon_code": "",
        "created_at": "",
        "customer_dob": "",
        "customer_email": "",
        "customer_firstname": "",
        "customer_gender": 0,
        "customer_group_id": 0,
        "customer_id": 0,
        "customer_is_guest": 0,
        "customer_lastname": "",
        "customer_middlename": "",
        "customer_note": "",
        "customer_note_notify": 0,
        "customer_prefix": "",
        "customer_suffix": "",
        "customer_taxvat": "",
        "discount_amount": "",
        "discount_canceled": "",
        "discount_description": "",
        "discount_invoiced": "",
        "discount_refunded": "",
        "discount_tax_compensation_amount": "",
        "discount_tax_compensation_invoiced": "",
        "discount_tax_compensation_refunded": "",
        "edit_increment": 0,
        "email_sent": 0,
        "entity_id": 0,
        "ext_customer_id": "",
        "ext_order_id": "",
        "extension_attributes": {
          "amazon_order_reference_id": "",
          "applied_taxes": [
            {
              "amount": "",
              "base_amount": "",
              "code": "",
              "extension_attributes": {
                "rates": [
                  {
                    "code": "",
                    "extension_attributes": {},
                    "percent": "",
                    "title": ""
                  }
                ]
              },
              "percent": "",
              "title": ""
            }
          ],
          "base_customer_balance_amount": "",
          "base_customer_balance_invoiced": "",
          "base_customer_balance_refunded": "",
          "base_customer_balance_total_refunded": "",
          "base_gift_cards_amount": "",
          "base_gift_cards_invoiced": "",
          "base_gift_cards_refunded": "",
          "base_reward_currency_amount": "",
          "company_order_attributes": {
            "company_id": 0,
            "company_name": "",
            "extension_attributes": {},
            "order_id": 0
          },
          "converting_from_quote": false,
          "customer_balance_amount": "",
          "customer_balance_invoiced": "",
          "customer_balance_refunded": "",
          "customer_balance_total_refunded": "",
          "gift_cards": [
            {
              "amount": "",
              "base_amount": "",
              "code": "",
              "id": 0
            }
          ],
          "gift_cards_amount": "",
          "gift_cards_invoiced": "",
          "gift_cards_refunded": "",
          "gift_message": {
            "customer_id": 0,
            "extension_attributes": {
              "entity_id": "",
              "entity_type": "",
              "wrapping_add_printed_card": false,
              "wrapping_allow_gift_receipt": false,
              "wrapping_id": 0
            },
            "gift_message_id": 0,
            "message": "",
            "recipient": "",
            "sender": ""
          },
          "gw_add_card": "",
          "gw_allow_gift_receipt": "",
          "gw_base_price": "",
          "gw_base_price_incl_tax": "",
          "gw_base_price_invoiced": "",
          "gw_base_price_refunded": "",
          "gw_base_tax_amount": "",
          "gw_base_tax_amount_invoiced": "",
          "gw_base_tax_amount_refunded": "",
          "gw_card_base_price": "",
          "gw_card_base_price_incl_tax": "",
          "gw_card_base_price_invoiced": "",
          "gw_card_base_price_refunded": "",
          "gw_card_base_tax_amount": "",
          "gw_card_base_tax_invoiced": "",
          "gw_card_base_tax_refunded": "",
          "gw_card_price": "",
          "gw_card_price_incl_tax": "",
          "gw_card_price_invoiced": "",
          "gw_card_price_refunded": "",
          "gw_card_tax_amount": "",
          "gw_card_tax_invoiced": "",
          "gw_card_tax_refunded": "",
          "gw_id": "",
          "gw_items_base_price": "",
          "gw_items_base_price_incl_tax": "",
          "gw_items_base_price_invoiced": "",
          "gw_items_base_price_refunded": "",
          "gw_items_base_tax_amount": "",
          "gw_items_base_tax_invoiced": "",
          "gw_items_base_tax_refunded": "",
          "gw_items_price": "",
          "gw_items_price_incl_tax": "",
          "gw_items_price_invoiced": "",
          "gw_items_price_refunded": "",
          "gw_items_tax_amount": "",
          "gw_items_tax_invoiced": "",
          "gw_items_tax_refunded": "",
          "gw_price": "",
          "gw_price_incl_tax": "",
          "gw_price_invoiced": "",
          "gw_price_refunded": "",
          "gw_tax_amount": "",
          "gw_tax_amount_invoiced": "",
          "gw_tax_amount_refunded": "",
          "item_applied_taxes": [
            {
              "applied_taxes": [
                {}
              ],
              "associated_item_id": 0,
              "extension_attributes": {},
              "item_id": 0,
              "type": ""
            }
          ],
          "payment_additional_info": [
            {
              "key": "",
              "value": ""
            }
          ],
          "reward_currency_amount": "",
          "reward_points_balance": 0,
          "shipping_assignments": [
            {
              "extension_attributes": {},
              "items": [
                {
                  "additional_data": "",
                  "amount_refunded": "",
                  "applied_rule_ids": "",
                  "base_amount_refunded": "",
                  "base_cost": "",
                  "base_discount_amount": "",
                  "base_discount_invoiced": "",
                  "base_discount_refunded": "",
                  "base_discount_tax_compensation_amount": "",
                  "base_discount_tax_compensation_invoiced": "",
                  "base_discount_tax_compensation_refunded": "",
                  "base_original_price": "",
                  "base_price": "",
                  "base_price_incl_tax": "",
                  "base_row_invoiced": "",
                  "base_row_total": "",
                  "base_row_total_incl_tax": "",
                  "base_tax_amount": "",
                  "base_tax_before_discount": "",
                  "base_tax_invoiced": "",
                  "base_tax_refunded": "",
                  "base_weee_tax_applied_amount": "",
                  "base_weee_tax_applied_row_amnt": "",
                  "base_weee_tax_disposition": "",
                  "base_weee_tax_row_disposition": "",
                  "created_at": "",
                  "description": "",
                  "discount_amount": "",
                  "discount_invoiced": "",
                  "discount_percent": "",
                  "discount_refunded": "",
                  "discount_tax_compensation_amount": "",
                  "discount_tax_compensation_canceled": "",
                  "discount_tax_compensation_invoiced": "",
                  "discount_tax_compensation_refunded": "",
                  "event_id": 0,
                  "ext_order_item_id": "",
                  "extension_attributes": {
                    "gift_message": {},
                    "gw_base_price": "",
                    "gw_base_price_invoiced": "",
                    "gw_base_price_refunded": "",
                    "gw_base_tax_amount": "",
                    "gw_base_tax_amount_invoiced": "",
                    "gw_base_tax_amount_refunded": "",
                    "gw_id": "",
                    "gw_price": "",
                    "gw_price_invoiced": "",
                    "gw_price_refunded": "",
                    "gw_tax_amount": "",
                    "gw_tax_amount_invoiced": "",
                    "gw_tax_amount_refunded": "",
                    "invoice_text_codes": [],
                    "tax_codes": [],
                    "vertex_tax_codes": []
                  },
                  "free_shipping": 0,
                  "gw_base_price": "",
                  "gw_base_price_invoiced": "",
                  "gw_base_price_refunded": "",
                  "gw_base_tax_amount": "",
                  "gw_base_tax_amount_invoiced": "",
                  "gw_base_tax_amount_refunded": "",
                  "gw_id": 0,
                  "gw_price": "",
                  "gw_price_invoiced": "",
                  "gw_price_refunded": "",
                  "gw_tax_amount": "",
                  "gw_tax_amount_invoiced": "",
                  "gw_tax_amount_refunded": "",
                  "is_qty_decimal": 0,
                  "is_virtual": 0,
                  "item_id": 0,
                  "locked_do_invoice": 0,
                  "locked_do_ship": 0,
                  "name": "",
                  "no_discount": 0,
                  "order_id": 0,
                  "original_price": "",
                  "parent_item": "",
                  "parent_item_id": 0,
                  "price": "",
                  "price_incl_tax": "",
                  "product_id": 0,
                  "product_option": {
                    "extension_attributes": {
                      "bundle_options": [
                        {
                          "extension_attributes": {},
                          "option_id": 0,
                          "option_qty": 0,
                          "option_selections": []
                        }
                      ],
                      "configurable_item_options": [
                        {
                          "extension_attributes": {},
                          "option_id": "",
                          "option_value": 0
                        }
                      ],
                      "custom_options": [
                        {
                          "extension_attributes": {
                            "file_info": {
                              "base64_encoded_data": "",
                              "name": "",
                              "type": ""
                            }
                          },
                          "option_id": "",
                          "option_value": ""
                        }
                      ],
                      "downloadable_option": {
                        "downloadable_links": []
                      },
                      "giftcard_item_option": {
                        "custom_giftcard_amount": "",
                        "extension_attributes": {},
                        "giftcard_amount": "",
                        "giftcard_message": "",
                        "giftcard_recipient_email": "",
                        "giftcard_recipient_name": "",
                        "giftcard_sender_email": "",
                        "giftcard_sender_name": ""
                      }
                    }
                  },
                  "product_type": "",
                  "qty_backordered": "",
                  "qty_canceled": "",
                  "qty_invoiced": "",
                  "qty_ordered": "",
                  "qty_refunded": "",
                  "qty_returned": "",
                  "qty_shipped": "",
                  "quote_item_id": 0,
                  "row_invoiced": "",
                  "row_total": "",
                  "row_total_incl_tax": "",
                  "row_weight": "",
                  "sku": "",
                  "store_id": 0,
                  "tax_amount": "",
                  "tax_before_discount": "",
                  "tax_canceled": "",
                  "tax_invoiced": "",
                  "tax_percent": "",
                  "tax_refunded": "",
                  "updated_at": "",
                  "weee_tax_applied": "",
                  "weee_tax_applied_amount": "",
                  "weee_tax_applied_row_amount": "",
                  "weee_tax_disposition": "",
                  "weee_tax_row_disposition": "",
                  "weight": ""
                }
              ],
              "shipping": {
                "address": {},
                "extension_attributes": {
                  "collection_point": {
                    "city": "",
                    "collection_point_id": "",
                    "country": "",
                    "name": "",
                    "postcode": "",
                    "recipient_address_id": 0,
                    "region": "",
                    "street": []
                  },
                  "ext_order_id": "",
                  "shipping_experience": {
                    "code": "",
                    "cost": "",
                    "label": ""
                  }
                },
                "method": "",
                "total": {
                  "base_shipping_amount": "",
                  "base_shipping_canceled": "",
                  "base_shipping_discount_amount": "",
                  "base_shipping_discount_tax_compensation_amnt": "",
                  "base_shipping_incl_tax": "",
                  "base_shipping_invoiced": "",
                  "base_shipping_refunded": "",
                  "base_shipping_tax_amount": "",
                  "base_shipping_tax_refunded": "",
                  "extension_attributes": {},
                  "shipping_amount": "",
                  "shipping_canceled": "",
                  "shipping_discount_amount": "",
                  "shipping_discount_tax_compensation_amount": "",
                  "shipping_incl_tax": "",
                  "shipping_invoiced": "",
                  "shipping_refunded": "",
                  "shipping_tax_amount": "",
                  "shipping_tax_refunded": ""
                }
              },
              "stock_id": 0
            }
          ]
        },
        "forced_shipment_with_invoice": 0,
        "global_currency_code": "",
        "grand_total": "",
        "hold_before_state": "",
        "hold_before_status": "",
        "increment_id": "",
        "is_virtual": 0,
        "items": [
          {}
        ],
        "order_currency_code": "",
        "original_increment_id": "",
        "payment": {
          "account_status": "",
          "additional_data": "",
          "additional_information": [],
          "address_status": "",
          "amount_authorized": "",
          "amount_canceled": "",
          "amount_ordered": "",
          "amount_paid": "",
          "amount_refunded": "",
          "anet_trans_method": "",
          "base_amount_authorized": "",
          "base_amount_canceled": "",
          "base_amount_ordered": "",
          "base_amount_paid": "",
          "base_amount_paid_online": "",
          "base_amount_refunded": "",
          "base_amount_refunded_online": "",
          "base_shipping_amount": "",
          "base_shipping_captured": "",
          "base_shipping_refunded": "",
          "cc_approval": "",
          "cc_avs_status": "",
          "cc_cid_status": "",
          "cc_debug_request_body": "",
          "cc_debug_response_body": "",
          "cc_debug_response_serialized": "",
          "cc_exp_month": "",
          "cc_exp_year": "",
          "cc_last4": "",
          "cc_number_enc": "",
          "cc_owner": "",
          "cc_secure_verify": "",
          "cc_ss_issue": "",
          "cc_ss_start_month": "",
          "cc_ss_start_year": "",
          "cc_status": "",
          "cc_status_description": "",
          "cc_trans_id": "",
          "cc_type": "",
          "echeck_account_name": "",
          "echeck_account_type": "",
          "echeck_bank_name": "",
          "echeck_routing_number": "",
          "echeck_type": "",
          "entity_id": 0,
          "extension_attributes": {
            "vault_payment_token": {
              "created_at": "",
              "customer_id": 0,
              "entity_id": 0,
              "expires_at": "",
              "gateway_token": "",
              "is_active": false,
              "is_visible": false,
              "payment_method_code": "",
              "public_hash": "",
              "token_details": "",
              "type": ""
            }
          },
          "last_trans_id": "",
          "method": "",
          "parent_id": 0,
          "po_number": "",
          "protection_eligibility": "",
          "quote_payment_id": 0,
          "shipping_amount": "",
          "shipping_captured": "",
          "shipping_refunded": ""
        },
        "payment_auth_expiration": 0,
        "payment_authorization_amount": "",
        "protect_code": "",
        "quote_address_id": 0,
        "quote_id": 0,
        "relation_child_id": "",
        "relation_child_real_id": "",
        "relation_parent_id": "",
        "relation_parent_real_id": "",
        "remote_ip": "",
        "shipping_amount": "",
        "shipping_canceled": "",
        "shipping_description": "",
        "shipping_discount_amount": "",
        "shipping_discount_tax_compensation_amount": "",
        "shipping_incl_tax": "",
        "shipping_invoiced": "",
        "shipping_refunded": "",
        "shipping_tax_amount": "",
        "shipping_tax_refunded": "",
        "state": "",
        "status": "",
        "status_histories": [
          {
            "comment": "",
            "created_at": "",
            "entity_id": 0,
            "entity_name": "",
            "extension_attributes": {},
            "is_customer_notified": 0,
            "is_visible_on_front": 0,
            "parent_id": 0,
            "status": ""
          }
        ],
        "store_currency_code": "",
        "store_id": 0,
        "store_name": "",
        "store_to_base_rate": "",
        "store_to_order_rate": "",
        "subtotal": "",
        "subtotal_canceled": "",
        "subtotal_incl_tax": "",
        "subtotal_invoiced": "",
        "subtotal_refunded": "",
        "tax_amount": "",
        "tax_canceled": "",
        "tax_invoiced": "",
        "tax_refunded": "",
        "total_canceled": "",
        "total_due": "",
        "total_invoiced": "",
        "total_item_count": 0,
        "total_offline_refunded": "",
        "total_online_refunded": "",
        "total_paid": "",
        "total_qty_ordered": "",
        "total_refunded": "",
        "updated_at": "",
        "weight": "",
        "x_forwarded_for": ""
      },
      "vertex_tax_calculation_shipping_address": {}
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "is_used_for_refund": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "total_qty": "",
    "transaction_id": "",
    "updated_at": ""
  }
}'
echo '{
  "entity": {
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_refunded": "",
    "billing_address_id": 0,
    "can_void_flag": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": "",
      "vertex_tax_calculation_billing_address": {
        "address_type": "",
        "city": "",
        "company": "",
        "country_id": "",
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "entity_id": 0,
        "extension_attributes": {
          "checkout_fields": [
            {
              "attribute_code": "",
              "value": ""
            }
          ]
        },
        "fax": "",
        "firstname": "",
        "lastname": "",
        "middlename": "",
        "parent_id": 0,
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": "",
        "vat_is_valid": 0,
        "vat_request_date": "",
        "vat_request_id": "",
        "vat_request_success": 0
      },
      "vertex_tax_calculation_order": {
        "adjustment_negative": "",
        "adjustment_positive": "",
        "applied_rule_ids": "",
        "base_adjustment_negative": "",
        "base_adjustment_positive": "",
        "base_currency_code": "",
        "base_discount_amount": "",
        "base_discount_canceled": "",
        "base_discount_invoiced": "",
        "base_discount_refunded": "",
        "base_discount_tax_compensation_amount": "",
        "base_discount_tax_compensation_invoiced": "",
        "base_discount_tax_compensation_refunded": "",
        "base_grand_total": "",
        "base_shipping_amount": "",
        "base_shipping_canceled": "",
        "base_shipping_discount_amount": "",
        "base_shipping_discount_tax_compensation_amnt": "",
        "base_shipping_incl_tax": "",
        "base_shipping_invoiced": "",
        "base_shipping_refunded": "",
        "base_shipping_tax_amount": "",
        "base_shipping_tax_refunded": "",
        "base_subtotal": "",
        "base_subtotal_canceled": "",
        "base_subtotal_incl_tax": "",
        "base_subtotal_invoiced": "",
        "base_subtotal_refunded": "",
        "base_tax_amount": "",
        "base_tax_canceled": "",
        "base_tax_invoiced": "",
        "base_tax_refunded": "",
        "base_to_global_rate": "",
        "base_to_order_rate": "",
        "base_total_canceled": "",
        "base_total_due": "",
        "base_total_invoiced": "",
        "base_total_invoiced_cost": "",
        "base_total_offline_refunded": "",
        "base_total_online_refunded": "",
        "base_total_paid": "",
        "base_total_qty_ordered": "",
        "base_total_refunded": "",
        "billing_address": {},
        "billing_address_id": 0,
        "can_ship_partially": 0,
        "can_ship_partially_item": 0,
        "coupon_code": "",
        "created_at": "",
        "customer_dob": "",
        "customer_email": "",
        "customer_firstname": "",
        "customer_gender": 0,
        "customer_group_id": 0,
        "customer_id": 0,
        "customer_is_guest": 0,
        "customer_lastname": "",
        "customer_middlename": "",
        "customer_note": "",
        "customer_note_notify": 0,
        "customer_prefix": "",
        "customer_suffix": "",
        "customer_taxvat": "",
        "discount_amount": "",
        "discount_canceled": "",
        "discount_description": "",
        "discount_invoiced": "",
        "discount_refunded": "",
        "discount_tax_compensation_amount": "",
        "discount_tax_compensation_invoiced": "",
        "discount_tax_compensation_refunded": "",
        "edit_increment": 0,
        "email_sent": 0,
        "entity_id": 0,
        "ext_customer_id": "",
        "ext_order_id": "",
        "extension_attributes": {
          "amazon_order_reference_id": "",
          "applied_taxes": [
            {
              "amount": "",
              "base_amount": "",
              "code": "",
              "extension_attributes": {
                "rates": [
                  {
                    "code": "",
                    "extension_attributes": {},
                    "percent": "",
                    "title": ""
                  }
                ]
              },
              "percent": "",
              "title": ""
            }
          ],
          "base_customer_balance_amount": "",
          "base_customer_balance_invoiced": "",
          "base_customer_balance_refunded": "",
          "base_customer_balance_total_refunded": "",
          "base_gift_cards_amount": "",
          "base_gift_cards_invoiced": "",
          "base_gift_cards_refunded": "",
          "base_reward_currency_amount": "",
          "company_order_attributes": {
            "company_id": 0,
            "company_name": "",
            "extension_attributes": {},
            "order_id": 0
          },
          "converting_from_quote": false,
          "customer_balance_amount": "",
          "customer_balance_invoiced": "",
          "customer_balance_refunded": "",
          "customer_balance_total_refunded": "",
          "gift_cards": [
            {
              "amount": "",
              "base_amount": "",
              "code": "",
              "id": 0
            }
          ],
          "gift_cards_amount": "",
          "gift_cards_invoiced": "",
          "gift_cards_refunded": "",
          "gift_message": {
            "customer_id": 0,
            "extension_attributes": {
              "entity_id": "",
              "entity_type": "",
              "wrapping_add_printed_card": false,
              "wrapping_allow_gift_receipt": false,
              "wrapping_id": 0
            },
            "gift_message_id": 0,
            "message": "",
            "recipient": "",
            "sender": ""
          },
          "gw_add_card": "",
          "gw_allow_gift_receipt": "",
          "gw_base_price": "",
          "gw_base_price_incl_tax": "",
          "gw_base_price_invoiced": "",
          "gw_base_price_refunded": "",
          "gw_base_tax_amount": "",
          "gw_base_tax_amount_invoiced": "",
          "gw_base_tax_amount_refunded": "",
          "gw_card_base_price": "",
          "gw_card_base_price_incl_tax": "",
          "gw_card_base_price_invoiced": "",
          "gw_card_base_price_refunded": "",
          "gw_card_base_tax_amount": "",
          "gw_card_base_tax_invoiced": "",
          "gw_card_base_tax_refunded": "",
          "gw_card_price": "",
          "gw_card_price_incl_tax": "",
          "gw_card_price_invoiced": "",
          "gw_card_price_refunded": "",
          "gw_card_tax_amount": "",
          "gw_card_tax_invoiced": "",
          "gw_card_tax_refunded": "",
          "gw_id": "",
          "gw_items_base_price": "",
          "gw_items_base_price_incl_tax": "",
          "gw_items_base_price_invoiced": "",
          "gw_items_base_price_refunded": "",
          "gw_items_base_tax_amount": "",
          "gw_items_base_tax_invoiced": "",
          "gw_items_base_tax_refunded": "",
          "gw_items_price": "",
          "gw_items_price_incl_tax": "",
          "gw_items_price_invoiced": "",
          "gw_items_price_refunded": "",
          "gw_items_tax_amount": "",
          "gw_items_tax_invoiced": "",
          "gw_items_tax_refunded": "",
          "gw_price": "",
          "gw_price_incl_tax": "",
          "gw_price_invoiced": "",
          "gw_price_refunded": "",
          "gw_tax_amount": "",
          "gw_tax_amount_invoiced": "",
          "gw_tax_amount_refunded": "",
          "item_applied_taxes": [
            {
              "applied_taxes": [
                {}
              ],
              "associated_item_id": 0,
              "extension_attributes": {},
              "item_id": 0,
              "type": ""
            }
          ],
          "payment_additional_info": [
            {
              "key": "",
              "value": ""
            }
          ],
          "reward_currency_amount": "",
          "reward_points_balance": 0,
          "shipping_assignments": [
            {
              "extension_attributes": {},
              "items": [
                {
                  "additional_data": "",
                  "amount_refunded": "",
                  "applied_rule_ids": "",
                  "base_amount_refunded": "",
                  "base_cost": "",
                  "base_discount_amount": "",
                  "base_discount_invoiced": "",
                  "base_discount_refunded": "",
                  "base_discount_tax_compensation_amount": "",
                  "base_discount_tax_compensation_invoiced": "",
                  "base_discount_tax_compensation_refunded": "",
                  "base_original_price": "",
                  "base_price": "",
                  "base_price_incl_tax": "",
                  "base_row_invoiced": "",
                  "base_row_total": "",
                  "base_row_total_incl_tax": "",
                  "base_tax_amount": "",
                  "base_tax_before_discount": "",
                  "base_tax_invoiced": "",
                  "base_tax_refunded": "",
                  "base_weee_tax_applied_amount": "",
                  "base_weee_tax_applied_row_amnt": "",
                  "base_weee_tax_disposition": "",
                  "base_weee_tax_row_disposition": "",
                  "created_at": "",
                  "description": "",
                  "discount_amount": "",
                  "discount_invoiced": "",
                  "discount_percent": "",
                  "discount_refunded": "",
                  "discount_tax_compensation_amount": "",
                  "discount_tax_compensation_canceled": "",
                  "discount_tax_compensation_invoiced": "",
                  "discount_tax_compensation_refunded": "",
                  "event_id": 0,
                  "ext_order_item_id": "",
                  "extension_attributes": {
                    "gift_message": {},
                    "gw_base_price": "",
                    "gw_base_price_invoiced": "",
                    "gw_base_price_refunded": "",
                    "gw_base_tax_amount": "",
                    "gw_base_tax_amount_invoiced": "",
                    "gw_base_tax_amount_refunded": "",
                    "gw_id": "",
                    "gw_price": "",
                    "gw_price_invoiced": "",
                    "gw_price_refunded": "",
                    "gw_tax_amount": "",
                    "gw_tax_amount_invoiced": "",
                    "gw_tax_amount_refunded": "",
                    "invoice_text_codes": [],
                    "tax_codes": [],
                    "vertex_tax_codes": []
                  },
                  "free_shipping": 0,
                  "gw_base_price": "",
                  "gw_base_price_invoiced": "",
                  "gw_base_price_refunded": "",
                  "gw_base_tax_amount": "",
                  "gw_base_tax_amount_invoiced": "",
                  "gw_base_tax_amount_refunded": "",
                  "gw_id": 0,
                  "gw_price": "",
                  "gw_price_invoiced": "",
                  "gw_price_refunded": "",
                  "gw_tax_amount": "",
                  "gw_tax_amount_invoiced": "",
                  "gw_tax_amount_refunded": "",
                  "is_qty_decimal": 0,
                  "is_virtual": 0,
                  "item_id": 0,
                  "locked_do_invoice": 0,
                  "locked_do_ship": 0,
                  "name": "",
                  "no_discount": 0,
                  "order_id": 0,
                  "original_price": "",
                  "parent_item": "",
                  "parent_item_id": 0,
                  "price": "",
                  "price_incl_tax": "",
                  "product_id": 0,
                  "product_option": {
                    "extension_attributes": {
                      "bundle_options": [
                        {
                          "extension_attributes": {},
                          "option_id": 0,
                          "option_qty": 0,
                          "option_selections": []
                        }
                      ],
                      "configurable_item_options": [
                        {
                          "extension_attributes": {},
                          "option_id": "",
                          "option_value": 0
                        }
                      ],
                      "custom_options": [
                        {
                          "extension_attributes": {
                            "file_info": {
                              "base64_encoded_data": "",
                              "name": "",
                              "type": ""
                            }
                          },
                          "option_id": "",
                          "option_value": ""
                        }
                      ],
                      "downloadable_option": {
                        "downloadable_links": []
                      },
                      "giftcard_item_option": {
                        "custom_giftcard_amount": "",
                        "extension_attributes": {},
                        "giftcard_amount": "",
                        "giftcard_message": "",
                        "giftcard_recipient_email": "",
                        "giftcard_recipient_name": "",
                        "giftcard_sender_email": "",
                        "giftcard_sender_name": ""
                      }
                    }
                  },
                  "product_type": "",
                  "qty_backordered": "",
                  "qty_canceled": "",
                  "qty_invoiced": "",
                  "qty_ordered": "",
                  "qty_refunded": "",
                  "qty_returned": "",
                  "qty_shipped": "",
                  "quote_item_id": 0,
                  "row_invoiced": "",
                  "row_total": "",
                  "row_total_incl_tax": "",
                  "row_weight": "",
                  "sku": "",
                  "store_id": 0,
                  "tax_amount": "",
                  "tax_before_discount": "",
                  "tax_canceled": "",
                  "tax_invoiced": "",
                  "tax_percent": "",
                  "tax_refunded": "",
                  "updated_at": "",
                  "weee_tax_applied": "",
                  "weee_tax_applied_amount": "",
                  "weee_tax_applied_row_amount": "",
                  "weee_tax_disposition": "",
                  "weee_tax_row_disposition": "",
                  "weight": ""
                }
              ],
              "shipping": {
                "address": {},
                "extension_attributes": {
                  "collection_point": {
                    "city": "",
                    "collection_point_id": "",
                    "country": "",
                    "name": "",
                    "postcode": "",
                    "recipient_address_id": 0,
                    "region": "",
                    "street": []
                  },
                  "ext_order_id": "",
                  "shipping_experience": {
                    "code": "",
                    "cost": "",
                    "label": ""
                  }
                },
                "method": "",
                "total": {
                  "base_shipping_amount": "",
                  "base_shipping_canceled": "",
                  "base_shipping_discount_amount": "",
                  "base_shipping_discount_tax_compensation_amnt": "",
                  "base_shipping_incl_tax": "",
                  "base_shipping_invoiced": "",
                  "base_shipping_refunded": "",
                  "base_shipping_tax_amount": "",
                  "base_shipping_tax_refunded": "",
                  "extension_attributes": {},
                  "shipping_amount": "",
                  "shipping_canceled": "",
                  "shipping_discount_amount": "",
                  "shipping_discount_tax_compensation_amount": "",
                  "shipping_incl_tax": "",
                  "shipping_invoiced": "",
                  "shipping_refunded": "",
                  "shipping_tax_amount": "",
                  "shipping_tax_refunded": ""
                }
              },
              "stock_id": 0
            }
          ]
        },
        "forced_shipment_with_invoice": 0,
        "global_currency_code": "",
        "grand_total": "",
        "hold_before_state": "",
        "hold_before_status": "",
        "increment_id": "",
        "is_virtual": 0,
        "items": [
          {}
        ],
        "order_currency_code": "",
        "original_increment_id": "",
        "payment": {
          "account_status": "",
          "additional_data": "",
          "additional_information": [],
          "address_status": "",
          "amount_authorized": "",
          "amount_canceled": "",
          "amount_ordered": "",
          "amount_paid": "",
          "amount_refunded": "",
          "anet_trans_method": "",
          "base_amount_authorized": "",
          "base_amount_canceled": "",
          "base_amount_ordered": "",
          "base_amount_paid": "",
          "base_amount_paid_online": "",
          "base_amount_refunded": "",
          "base_amount_refunded_online": "",
          "base_shipping_amount": "",
          "base_shipping_captured": "",
          "base_shipping_refunded": "",
          "cc_approval": "",
          "cc_avs_status": "",
          "cc_cid_status": "",
          "cc_debug_request_body": "",
          "cc_debug_response_body": "",
          "cc_debug_response_serialized": "",
          "cc_exp_month": "",
          "cc_exp_year": "",
          "cc_last4": "",
          "cc_number_enc": "",
          "cc_owner": "",
          "cc_secure_verify": "",
          "cc_ss_issue": "",
          "cc_ss_start_month": "",
          "cc_ss_start_year": "",
          "cc_status": "",
          "cc_status_description": "",
          "cc_trans_id": "",
          "cc_type": "",
          "echeck_account_name": "",
          "echeck_account_type": "",
          "echeck_bank_name": "",
          "echeck_routing_number": "",
          "echeck_type": "",
          "entity_id": 0,
          "extension_attributes": {
            "vault_payment_token": {
              "created_at": "",
              "customer_id": 0,
              "entity_id": 0,
              "expires_at": "",
              "gateway_token": "",
              "is_active": false,
              "is_visible": false,
              "payment_method_code": "",
              "public_hash": "",
              "token_details": "",
              "type": ""
            }
          },
          "last_trans_id": "",
          "method": "",
          "parent_id": 0,
          "po_number": "",
          "protection_eligibility": "",
          "quote_payment_id": 0,
          "shipping_amount": "",
          "shipping_captured": "",
          "shipping_refunded": ""
        },
        "payment_auth_expiration": 0,
        "payment_authorization_amount": "",
        "protect_code": "",
        "quote_address_id": 0,
        "quote_id": 0,
        "relation_child_id": "",
        "relation_child_real_id": "",
        "relation_parent_id": "",
        "relation_parent_real_id": "",
        "remote_ip": "",
        "shipping_amount": "",
        "shipping_canceled": "",
        "shipping_description": "",
        "shipping_discount_amount": "",
        "shipping_discount_tax_compensation_amount": "",
        "shipping_incl_tax": "",
        "shipping_invoiced": "",
        "shipping_refunded": "",
        "shipping_tax_amount": "",
        "shipping_tax_refunded": "",
        "state": "",
        "status": "",
        "status_histories": [
          {
            "comment": "",
            "created_at": "",
            "entity_id": 0,
            "entity_name": "",
            "extension_attributes": {},
            "is_customer_notified": 0,
            "is_visible_on_front": 0,
            "parent_id": 0,
            "status": ""
          }
        ],
        "store_currency_code": "",
        "store_id": 0,
        "store_name": "",
        "store_to_base_rate": "",
        "store_to_order_rate": "",
        "subtotal": "",
        "subtotal_canceled": "",
        "subtotal_incl_tax": "",
        "subtotal_invoiced": "",
        "subtotal_refunded": "",
        "tax_amount": "",
        "tax_canceled": "",
        "tax_invoiced": "",
        "tax_refunded": "",
        "total_canceled": "",
        "total_due": "",
        "total_invoiced": "",
        "total_item_count": 0,
        "total_offline_refunded": "",
        "total_online_refunded": "",
        "total_paid": "",
        "total_qty_ordered": "",
        "total_refunded": "",
        "updated_at": "",
        "weight": "",
        "x_forwarded_for": ""
      },
      "vertex_tax_calculation_shipping_address": {}
    },
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "is_used_for_refund": 0,
    "items": [
      {
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": {
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        },
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": ""
      }
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "total_qty": "",
    "transaction_id": "",
    "updated_at": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/invoices/ \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "entity": {\n    "base_currency_code": "",\n    "base_discount_amount": "",\n    "base_discount_tax_compensation_amount": "",\n    "base_grand_total": "",\n    "base_shipping_amount": "",\n    "base_shipping_discount_tax_compensation_amnt": "",\n    "base_shipping_incl_tax": "",\n    "base_shipping_tax_amount": "",\n    "base_subtotal": "",\n    "base_subtotal_incl_tax": "",\n    "base_tax_amount": "",\n    "base_to_global_rate": "",\n    "base_to_order_rate": "",\n    "base_total_refunded": "",\n    "billing_address_id": 0,\n    "can_void_flag": 0,\n    "comments": [\n      {\n        "comment": "",\n        "created_at": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "is_customer_notified": 0,\n        "is_visible_on_front": 0,\n        "parent_id": 0\n      }\n    ],\n    "created_at": "",\n    "discount_amount": "",\n    "discount_description": "",\n    "discount_tax_compensation_amount": "",\n    "email_sent": 0,\n    "entity_id": 0,\n    "extension_attributes": {\n      "base_customer_balance_amount": "",\n      "base_gift_cards_amount": "",\n      "customer_balance_amount": "",\n      "gift_cards_amount": "",\n      "gw_base_price": "",\n      "gw_base_tax_amount": "",\n      "gw_card_base_price": "",\n      "gw_card_base_tax_amount": "",\n      "gw_card_price": "",\n      "gw_card_tax_amount": "",\n      "gw_items_base_price": "",\n      "gw_items_base_tax_amount": "",\n      "gw_items_price": "",\n      "gw_items_tax_amount": "",\n      "gw_price": "",\n      "gw_tax_amount": "",\n      "vertex_tax_calculation_billing_address": {\n        "address_type": "",\n        "city": "",\n        "company": "",\n        "country_id": "",\n        "customer_address_id": 0,\n        "customer_id": 0,\n        "email": "",\n        "entity_id": 0,\n        "extension_attributes": {\n          "checkout_fields": [\n            {\n              "attribute_code": "",\n              "value": ""\n            }\n          ]\n        },\n        "fax": "",\n        "firstname": "",\n        "lastname": "",\n        "middlename": "",\n        "parent_id": 0,\n        "postcode": "",\n        "prefix": "",\n        "region": "",\n        "region_code": "",\n        "region_id": 0,\n        "street": [],\n        "suffix": "",\n        "telephone": "",\n        "vat_id": "",\n        "vat_is_valid": 0,\n        "vat_request_date": "",\n        "vat_request_id": "",\n        "vat_request_success": 0\n      },\n      "vertex_tax_calculation_order": {\n        "adjustment_negative": "",\n        "adjustment_positive": "",\n        "applied_rule_ids": "",\n        "base_adjustment_negative": "",\n        "base_adjustment_positive": "",\n        "base_currency_code": "",\n        "base_discount_amount": "",\n        "base_discount_canceled": "",\n        "base_discount_invoiced": "",\n        "base_discount_refunded": "",\n        "base_discount_tax_compensation_amount": "",\n        "base_discount_tax_compensation_invoiced": "",\n        "base_discount_tax_compensation_refunded": "",\n        "base_grand_total": "",\n        "base_shipping_amount": "",\n        "base_shipping_canceled": "",\n        "base_shipping_discount_amount": "",\n        "base_shipping_discount_tax_compensation_amnt": "",\n        "base_shipping_incl_tax": "",\n        "base_shipping_invoiced": "",\n        "base_shipping_refunded": "",\n        "base_shipping_tax_amount": "",\n        "base_shipping_tax_refunded": "",\n        "base_subtotal": "",\n        "base_subtotal_canceled": "",\n        "base_subtotal_incl_tax": "",\n        "base_subtotal_invoiced": "",\n        "base_subtotal_refunded": "",\n        "base_tax_amount": "",\n        "base_tax_canceled": "",\n        "base_tax_invoiced": "",\n        "base_tax_refunded": "",\n        "base_to_global_rate": "",\n        "base_to_order_rate": "",\n        "base_total_canceled": "",\n        "base_total_due": "",\n        "base_total_invoiced": "",\n        "base_total_invoiced_cost": "",\n        "base_total_offline_refunded": "",\n        "base_total_online_refunded": "",\n        "base_total_paid": "",\n        "base_total_qty_ordered": "",\n        "base_total_refunded": "",\n        "billing_address": {},\n        "billing_address_id": 0,\n        "can_ship_partially": 0,\n        "can_ship_partially_item": 0,\n        "coupon_code": "",\n        "created_at": "",\n        "customer_dob": "",\n        "customer_email": "",\n        "customer_firstname": "",\n        "customer_gender": 0,\n        "customer_group_id": 0,\n        "customer_id": 0,\n        "customer_is_guest": 0,\n        "customer_lastname": "",\n        "customer_middlename": "",\n        "customer_note": "",\n        "customer_note_notify": 0,\n        "customer_prefix": "",\n        "customer_suffix": "",\n        "customer_taxvat": "",\n        "discount_amount": "",\n        "discount_canceled": "",\n        "discount_description": "",\n        "discount_invoiced": "",\n        "discount_refunded": "",\n        "discount_tax_compensation_amount": "",\n        "discount_tax_compensation_invoiced": "",\n        "discount_tax_compensation_refunded": "",\n        "edit_increment": 0,\n        "email_sent": 0,\n        "entity_id": 0,\n        "ext_customer_id": "",\n        "ext_order_id": "",\n        "extension_attributes": {\n          "amazon_order_reference_id": "",\n          "applied_taxes": [\n            {\n              "amount": "",\n              "base_amount": "",\n              "code": "",\n              "extension_attributes": {\n                "rates": [\n                  {\n                    "code": "",\n                    "extension_attributes": {},\n                    "percent": "",\n                    "title": ""\n                  }\n                ]\n              },\n              "percent": "",\n              "title": ""\n            }\n          ],\n          "base_customer_balance_amount": "",\n          "base_customer_balance_invoiced": "",\n          "base_customer_balance_refunded": "",\n          "base_customer_balance_total_refunded": "",\n          "base_gift_cards_amount": "",\n          "base_gift_cards_invoiced": "",\n          "base_gift_cards_refunded": "",\n          "base_reward_currency_amount": "",\n          "company_order_attributes": {\n            "company_id": 0,\n            "company_name": "",\n            "extension_attributes": {},\n            "order_id": 0\n          },\n          "converting_from_quote": false,\n          "customer_balance_amount": "",\n          "customer_balance_invoiced": "",\n          "customer_balance_refunded": "",\n          "customer_balance_total_refunded": "",\n          "gift_cards": [\n            {\n              "amount": "",\n              "base_amount": "",\n              "code": "",\n              "id": 0\n            }\n          ],\n          "gift_cards_amount": "",\n          "gift_cards_invoiced": "",\n          "gift_cards_refunded": "",\n          "gift_message": {\n            "customer_id": 0,\n            "extension_attributes": {\n              "entity_id": "",\n              "entity_type": "",\n              "wrapping_add_printed_card": false,\n              "wrapping_allow_gift_receipt": false,\n              "wrapping_id": 0\n            },\n            "gift_message_id": 0,\n            "message": "",\n            "recipient": "",\n            "sender": ""\n          },\n          "gw_add_card": "",\n          "gw_allow_gift_receipt": "",\n          "gw_base_price": "",\n          "gw_base_price_incl_tax": "",\n          "gw_base_price_invoiced": "",\n          "gw_base_price_refunded": "",\n          "gw_base_tax_amount": "",\n          "gw_base_tax_amount_invoiced": "",\n          "gw_base_tax_amount_refunded": "",\n          "gw_card_base_price": "",\n          "gw_card_base_price_incl_tax": "",\n          "gw_card_base_price_invoiced": "",\n          "gw_card_base_price_refunded": "",\n          "gw_card_base_tax_amount": "",\n          "gw_card_base_tax_invoiced": "",\n          "gw_card_base_tax_refunded": "",\n          "gw_card_price": "",\n          "gw_card_price_incl_tax": "",\n          "gw_card_price_invoiced": "",\n          "gw_card_price_refunded": "",\n          "gw_card_tax_amount": "",\n          "gw_card_tax_invoiced": "",\n          "gw_card_tax_refunded": "",\n          "gw_id": "",\n          "gw_items_base_price": "",\n          "gw_items_base_price_incl_tax": "",\n          "gw_items_base_price_invoiced": "",\n          "gw_items_base_price_refunded": "",\n          "gw_items_base_tax_amount": "",\n          "gw_items_base_tax_invoiced": "",\n          "gw_items_base_tax_refunded": "",\n          "gw_items_price": "",\n          "gw_items_price_incl_tax": "",\n          "gw_items_price_invoiced": "",\n          "gw_items_price_refunded": "",\n          "gw_items_tax_amount": "",\n          "gw_items_tax_invoiced": "",\n          "gw_items_tax_refunded": "",\n          "gw_price": "",\n          "gw_price_incl_tax": "",\n          "gw_price_invoiced": "",\n          "gw_price_refunded": "",\n          "gw_tax_amount": "",\n          "gw_tax_amount_invoiced": "",\n          "gw_tax_amount_refunded": "",\n          "item_applied_taxes": [\n            {\n              "applied_taxes": [\n                {}\n              ],\n              "associated_item_id": 0,\n              "extension_attributes": {},\n              "item_id": 0,\n              "type": ""\n            }\n          ],\n          "payment_additional_info": [\n            {\n              "key": "",\n              "value": ""\n            }\n          ],\n          "reward_currency_amount": "",\n          "reward_points_balance": 0,\n          "shipping_assignments": [\n            {\n              "extension_attributes": {},\n              "items": [\n                {\n                  "additional_data": "",\n                  "amount_refunded": "",\n                  "applied_rule_ids": "",\n                  "base_amount_refunded": "",\n                  "base_cost": "",\n                  "base_discount_amount": "",\n                  "base_discount_invoiced": "",\n                  "base_discount_refunded": "",\n                  "base_discount_tax_compensation_amount": "",\n                  "base_discount_tax_compensation_invoiced": "",\n                  "base_discount_tax_compensation_refunded": "",\n                  "base_original_price": "",\n                  "base_price": "",\n                  "base_price_incl_tax": "",\n                  "base_row_invoiced": "",\n                  "base_row_total": "",\n                  "base_row_total_incl_tax": "",\n                  "base_tax_amount": "",\n                  "base_tax_before_discount": "",\n                  "base_tax_invoiced": "",\n                  "base_tax_refunded": "",\n                  "base_weee_tax_applied_amount": "",\n                  "base_weee_tax_applied_row_amnt": "",\n                  "base_weee_tax_disposition": "",\n                  "base_weee_tax_row_disposition": "",\n                  "created_at": "",\n                  "description": "",\n                  "discount_amount": "",\n                  "discount_invoiced": "",\n                  "discount_percent": "",\n                  "discount_refunded": "",\n                  "discount_tax_compensation_amount": "",\n                  "discount_tax_compensation_canceled": "",\n                  "discount_tax_compensation_invoiced": "",\n                  "discount_tax_compensation_refunded": "",\n                  "event_id": 0,\n                  "ext_order_item_id": "",\n                  "extension_attributes": {\n                    "gift_message": {},\n                    "gw_base_price": "",\n                    "gw_base_price_invoiced": "",\n                    "gw_base_price_refunded": "",\n                    "gw_base_tax_amount": "",\n                    "gw_base_tax_amount_invoiced": "",\n                    "gw_base_tax_amount_refunded": "",\n                    "gw_id": "",\n                    "gw_price": "",\n                    "gw_price_invoiced": "",\n                    "gw_price_refunded": "",\n                    "gw_tax_amount": "",\n                    "gw_tax_amount_invoiced": "",\n                    "gw_tax_amount_refunded": "",\n                    "invoice_text_codes": [],\n                    "tax_codes": [],\n                    "vertex_tax_codes": []\n                  },\n                  "free_shipping": 0,\n                  "gw_base_price": "",\n                  "gw_base_price_invoiced": "",\n                  "gw_base_price_refunded": "",\n                  "gw_base_tax_amount": "",\n                  "gw_base_tax_amount_invoiced": "",\n                  "gw_base_tax_amount_refunded": "",\n                  "gw_id": 0,\n                  "gw_price": "",\n                  "gw_price_invoiced": "",\n                  "gw_price_refunded": "",\n                  "gw_tax_amount": "",\n                  "gw_tax_amount_invoiced": "",\n                  "gw_tax_amount_refunded": "",\n                  "is_qty_decimal": 0,\n                  "is_virtual": 0,\n                  "item_id": 0,\n                  "locked_do_invoice": 0,\n                  "locked_do_ship": 0,\n                  "name": "",\n                  "no_discount": 0,\n                  "order_id": 0,\n                  "original_price": "",\n                  "parent_item": "",\n                  "parent_item_id": 0,\n                  "price": "",\n                  "price_incl_tax": "",\n                  "product_id": 0,\n                  "product_option": {\n                    "extension_attributes": {\n                      "bundle_options": [\n                        {\n                          "extension_attributes": {},\n                          "option_id": 0,\n                          "option_qty": 0,\n                          "option_selections": []\n                        }\n                      ],\n                      "configurable_item_options": [\n                        {\n                          "extension_attributes": {},\n                          "option_id": "",\n                          "option_value": 0\n                        }\n                      ],\n                      "custom_options": [\n                        {\n                          "extension_attributes": {\n                            "file_info": {\n                              "base64_encoded_data": "",\n                              "name": "",\n                              "type": ""\n                            }\n                          },\n                          "option_id": "",\n                          "option_value": ""\n                        }\n                      ],\n                      "downloadable_option": {\n                        "downloadable_links": []\n                      },\n                      "giftcard_item_option": {\n                        "custom_giftcard_amount": "",\n                        "extension_attributes": {},\n                        "giftcard_amount": "",\n                        "giftcard_message": "",\n                        "giftcard_recipient_email": "",\n                        "giftcard_recipient_name": "",\n                        "giftcard_sender_email": "",\n                        "giftcard_sender_name": ""\n                      }\n                    }\n                  },\n                  "product_type": "",\n                  "qty_backordered": "",\n                  "qty_canceled": "",\n                  "qty_invoiced": "",\n                  "qty_ordered": "",\n                  "qty_refunded": "",\n                  "qty_returned": "",\n                  "qty_shipped": "",\n                  "quote_item_id": 0,\n                  "row_invoiced": "",\n                  "row_total": "",\n                  "row_total_incl_tax": "",\n                  "row_weight": "",\n                  "sku": "",\n                  "store_id": 0,\n                  "tax_amount": "",\n                  "tax_before_discount": "",\n                  "tax_canceled": "",\n                  "tax_invoiced": "",\n                  "tax_percent": "",\n                  "tax_refunded": "",\n                  "updated_at": "",\n                  "weee_tax_applied": "",\n                  "weee_tax_applied_amount": "",\n                  "weee_tax_applied_row_amount": "",\n                  "weee_tax_disposition": "",\n                  "weee_tax_row_disposition": "",\n                  "weight": ""\n                }\n              ],\n              "shipping": {\n                "address": {},\n                "extension_attributes": {\n                  "collection_point": {\n                    "city": "",\n                    "collection_point_id": "",\n                    "country": "",\n                    "name": "",\n                    "postcode": "",\n                    "recipient_address_id": 0,\n                    "region": "",\n                    "street": []\n                  },\n                  "ext_order_id": "",\n                  "shipping_experience": {\n                    "code": "",\n                    "cost": "",\n                    "label": ""\n                  }\n                },\n                "method": "",\n                "total": {\n                  "base_shipping_amount": "",\n                  "base_shipping_canceled": "",\n                  "base_shipping_discount_amount": "",\n                  "base_shipping_discount_tax_compensation_amnt": "",\n                  "base_shipping_incl_tax": "",\n                  "base_shipping_invoiced": "",\n                  "base_shipping_refunded": "",\n                  "base_shipping_tax_amount": "",\n                  "base_shipping_tax_refunded": "",\n                  "extension_attributes": {},\n                  "shipping_amount": "",\n                  "shipping_canceled": "",\n                  "shipping_discount_amount": "",\n                  "shipping_discount_tax_compensation_amount": "",\n                  "shipping_incl_tax": "",\n                  "shipping_invoiced": "",\n                  "shipping_refunded": "",\n                  "shipping_tax_amount": "",\n                  "shipping_tax_refunded": ""\n                }\n              },\n              "stock_id": 0\n            }\n          ]\n        },\n        "forced_shipment_with_invoice": 0,\n        "global_currency_code": "",\n        "grand_total": "",\n        "hold_before_state": "",\n        "hold_before_status": "",\n        "increment_id": "",\n        "is_virtual": 0,\n        "items": [\n          {}\n        ],\n        "order_currency_code": "",\n        "original_increment_id": "",\n        "payment": {\n          "account_status": "",\n          "additional_data": "",\n          "additional_information": [],\n          "address_status": "",\n          "amount_authorized": "",\n          "amount_canceled": "",\n          "amount_ordered": "",\n          "amount_paid": "",\n          "amount_refunded": "",\n          "anet_trans_method": "",\n          "base_amount_authorized": "",\n          "base_amount_canceled": "",\n          "base_amount_ordered": "",\n          "base_amount_paid": "",\n          "base_amount_paid_online": "",\n          "base_amount_refunded": "",\n          "base_amount_refunded_online": "",\n          "base_shipping_amount": "",\n          "base_shipping_captured": "",\n          "base_shipping_refunded": "",\n          "cc_approval": "",\n          "cc_avs_status": "",\n          "cc_cid_status": "",\n          "cc_debug_request_body": "",\n          "cc_debug_response_body": "",\n          "cc_debug_response_serialized": "",\n          "cc_exp_month": "",\n          "cc_exp_year": "",\n          "cc_last4": "",\n          "cc_number_enc": "",\n          "cc_owner": "",\n          "cc_secure_verify": "",\n          "cc_ss_issue": "",\n          "cc_ss_start_month": "",\n          "cc_ss_start_year": "",\n          "cc_status": "",\n          "cc_status_description": "",\n          "cc_trans_id": "",\n          "cc_type": "",\n          "echeck_account_name": "",\n          "echeck_account_type": "",\n          "echeck_bank_name": "",\n          "echeck_routing_number": "",\n          "echeck_type": "",\n          "entity_id": 0,\n          "extension_attributes": {\n            "vault_payment_token": {\n              "created_at": "",\n              "customer_id": 0,\n              "entity_id": 0,\n              "expires_at": "",\n              "gateway_token": "",\n              "is_active": false,\n              "is_visible": false,\n              "payment_method_code": "",\n              "public_hash": "",\n              "token_details": "",\n              "type": ""\n            }\n          },\n          "last_trans_id": "",\n          "method": "",\n          "parent_id": 0,\n          "po_number": "",\n          "protection_eligibility": "",\n          "quote_payment_id": 0,\n          "shipping_amount": "",\n          "shipping_captured": "",\n          "shipping_refunded": ""\n        },\n        "payment_auth_expiration": 0,\n        "payment_authorization_amount": "",\n        "protect_code": "",\n        "quote_address_id": 0,\n        "quote_id": 0,\n        "relation_child_id": "",\n        "relation_child_real_id": "",\n        "relation_parent_id": "",\n        "relation_parent_real_id": "",\n        "remote_ip": "",\n        "shipping_amount": "",\n        "shipping_canceled": "",\n        "shipping_description": "",\n        "shipping_discount_amount": "",\n        "shipping_discount_tax_compensation_amount": "",\n        "shipping_incl_tax": "",\n        "shipping_invoiced": "",\n        "shipping_refunded": "",\n        "shipping_tax_amount": "",\n        "shipping_tax_refunded": "",\n        "state": "",\n        "status": "",\n        "status_histories": [\n          {\n            "comment": "",\n            "created_at": "",\n            "entity_id": 0,\n            "entity_name": "",\n            "extension_attributes": {},\n            "is_customer_notified": 0,\n            "is_visible_on_front": 0,\n            "parent_id": 0,\n            "status": ""\n          }\n        ],\n        "store_currency_code": "",\n        "store_id": 0,\n        "store_name": "",\n        "store_to_base_rate": "",\n        "store_to_order_rate": "",\n        "subtotal": "",\n        "subtotal_canceled": "",\n        "subtotal_incl_tax": "",\n        "subtotal_invoiced": "",\n        "subtotal_refunded": "",\n        "tax_amount": "",\n        "tax_canceled": "",\n        "tax_invoiced": "",\n        "tax_refunded": "",\n        "total_canceled": "",\n        "total_due": "",\n        "total_invoiced": "",\n        "total_item_count": 0,\n        "total_offline_refunded": "",\n        "total_online_refunded": "",\n        "total_paid": "",\n        "total_qty_ordered": "",\n        "total_refunded": "",\n        "updated_at": "",\n        "weight": "",\n        "x_forwarded_for": ""\n      },\n      "vertex_tax_calculation_shipping_address": {}\n    },\n    "global_currency_code": "",\n    "grand_total": "",\n    "increment_id": "",\n    "is_used_for_refund": 0,\n    "items": [\n      {\n        "additional_data": "",\n        "base_cost": "",\n        "base_discount_amount": "",\n        "base_discount_tax_compensation_amount": "",\n        "base_price": "",\n        "base_price_incl_tax": "",\n        "base_row_total": "",\n        "base_row_total_incl_tax": "",\n        "base_tax_amount": "",\n        "description": "",\n        "discount_amount": "",\n        "discount_tax_compensation_amount": "",\n        "entity_id": 0,\n        "extension_attributes": {\n          "invoice_text_codes": [],\n          "tax_codes": [],\n          "vertex_tax_codes": []\n        },\n        "name": "",\n        "order_item_id": 0,\n        "parent_id": 0,\n        "price": "",\n        "price_incl_tax": "",\n        "product_id": 0,\n        "qty": "",\n        "row_total": "",\n        "row_total_incl_tax": "",\n        "sku": "",\n        "tax_amount": ""\n      }\n    ],\n    "order_currency_code": "",\n    "order_id": 0,\n    "shipping_address_id": 0,\n    "shipping_amount": "",\n    "shipping_discount_tax_compensation_amount": "",\n    "shipping_incl_tax": "",\n    "shipping_tax_amount": "",\n    "state": 0,\n    "store_currency_code": "",\n    "store_id": 0,\n    "store_to_base_rate": "",\n    "store_to_order_rate": "",\n    "subtotal": "",\n    "subtotal_incl_tax": "",\n    "tax_amount": "",\n    "total_qty": "",\n    "transaction_id": "",\n    "updated_at": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/invoices/
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["entity": [
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_tax_compensation_amount": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_tax_amount": "",
    "base_subtotal": "",
    "base_subtotal_incl_tax": "",
    "base_tax_amount": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_refunded": "",
    "billing_address_id": 0,
    "can_void_flag": 0,
    "comments": [
      [
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": [],
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      ]
    ],
    "created_at": "",
    "discount_amount": "",
    "discount_description": "",
    "discount_tax_compensation_amount": "",
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": [
      "base_customer_balance_amount": "",
      "base_gift_cards_amount": "",
      "customer_balance_amount": "",
      "gift_cards_amount": "",
      "gw_base_price": "",
      "gw_base_tax_amount": "",
      "gw_card_base_price": "",
      "gw_card_base_tax_amount": "",
      "gw_card_price": "",
      "gw_card_tax_amount": "",
      "gw_items_base_price": "",
      "gw_items_base_tax_amount": "",
      "gw_items_price": "",
      "gw_items_tax_amount": "",
      "gw_price": "",
      "gw_tax_amount": "",
      "vertex_tax_calculation_billing_address": [
        "address_type": "",
        "city": "",
        "company": "",
        "country_id": "",
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "entity_id": 0,
        "extension_attributes": ["checkout_fields": [
            [
              "attribute_code": "",
              "value": ""
            ]
          ]],
        "fax": "",
        "firstname": "",
        "lastname": "",
        "middlename": "",
        "parent_id": 0,
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": "",
        "vat_is_valid": 0,
        "vat_request_date": "",
        "vat_request_id": "",
        "vat_request_success": 0
      ],
      "vertex_tax_calculation_order": [
        "adjustment_negative": "",
        "adjustment_positive": "",
        "applied_rule_ids": "",
        "base_adjustment_negative": "",
        "base_adjustment_positive": "",
        "base_currency_code": "",
        "base_discount_amount": "",
        "base_discount_canceled": "",
        "base_discount_invoiced": "",
        "base_discount_refunded": "",
        "base_discount_tax_compensation_amount": "",
        "base_discount_tax_compensation_invoiced": "",
        "base_discount_tax_compensation_refunded": "",
        "base_grand_total": "",
        "base_shipping_amount": "",
        "base_shipping_canceled": "",
        "base_shipping_discount_amount": "",
        "base_shipping_discount_tax_compensation_amnt": "",
        "base_shipping_incl_tax": "",
        "base_shipping_invoiced": "",
        "base_shipping_refunded": "",
        "base_shipping_tax_amount": "",
        "base_shipping_tax_refunded": "",
        "base_subtotal": "",
        "base_subtotal_canceled": "",
        "base_subtotal_incl_tax": "",
        "base_subtotal_invoiced": "",
        "base_subtotal_refunded": "",
        "base_tax_amount": "",
        "base_tax_canceled": "",
        "base_tax_invoiced": "",
        "base_tax_refunded": "",
        "base_to_global_rate": "",
        "base_to_order_rate": "",
        "base_total_canceled": "",
        "base_total_due": "",
        "base_total_invoiced": "",
        "base_total_invoiced_cost": "",
        "base_total_offline_refunded": "",
        "base_total_online_refunded": "",
        "base_total_paid": "",
        "base_total_qty_ordered": "",
        "base_total_refunded": "",
        "billing_address": [],
        "billing_address_id": 0,
        "can_ship_partially": 0,
        "can_ship_partially_item": 0,
        "coupon_code": "",
        "created_at": "",
        "customer_dob": "",
        "customer_email": "",
        "customer_firstname": "",
        "customer_gender": 0,
        "customer_group_id": 0,
        "customer_id": 0,
        "customer_is_guest": 0,
        "customer_lastname": "",
        "customer_middlename": "",
        "customer_note": "",
        "customer_note_notify": 0,
        "customer_prefix": "",
        "customer_suffix": "",
        "customer_taxvat": "",
        "discount_amount": "",
        "discount_canceled": "",
        "discount_description": "",
        "discount_invoiced": "",
        "discount_refunded": "",
        "discount_tax_compensation_amount": "",
        "discount_tax_compensation_invoiced": "",
        "discount_tax_compensation_refunded": "",
        "edit_increment": 0,
        "email_sent": 0,
        "entity_id": 0,
        "ext_customer_id": "",
        "ext_order_id": "",
        "extension_attributes": [
          "amazon_order_reference_id": "",
          "applied_taxes": [
            [
              "amount": "",
              "base_amount": "",
              "code": "",
              "extension_attributes": ["rates": [
                  [
                    "code": "",
                    "extension_attributes": [],
                    "percent": "",
                    "title": ""
                  ]
                ]],
              "percent": "",
              "title": ""
            ]
          ],
          "base_customer_balance_amount": "",
          "base_customer_balance_invoiced": "",
          "base_customer_balance_refunded": "",
          "base_customer_balance_total_refunded": "",
          "base_gift_cards_amount": "",
          "base_gift_cards_invoiced": "",
          "base_gift_cards_refunded": "",
          "base_reward_currency_amount": "",
          "company_order_attributes": [
            "company_id": 0,
            "company_name": "",
            "extension_attributes": [],
            "order_id": 0
          ],
          "converting_from_quote": false,
          "customer_balance_amount": "",
          "customer_balance_invoiced": "",
          "customer_balance_refunded": "",
          "customer_balance_total_refunded": "",
          "gift_cards": [
            [
              "amount": "",
              "base_amount": "",
              "code": "",
              "id": 0
            ]
          ],
          "gift_cards_amount": "",
          "gift_cards_invoiced": "",
          "gift_cards_refunded": "",
          "gift_message": [
            "customer_id": 0,
            "extension_attributes": [
              "entity_id": "",
              "entity_type": "",
              "wrapping_add_printed_card": false,
              "wrapping_allow_gift_receipt": false,
              "wrapping_id": 0
            ],
            "gift_message_id": 0,
            "message": "",
            "recipient": "",
            "sender": ""
          ],
          "gw_add_card": "",
          "gw_allow_gift_receipt": "",
          "gw_base_price": "",
          "gw_base_price_incl_tax": "",
          "gw_base_price_invoiced": "",
          "gw_base_price_refunded": "",
          "gw_base_tax_amount": "",
          "gw_base_tax_amount_invoiced": "",
          "gw_base_tax_amount_refunded": "",
          "gw_card_base_price": "",
          "gw_card_base_price_incl_tax": "",
          "gw_card_base_price_invoiced": "",
          "gw_card_base_price_refunded": "",
          "gw_card_base_tax_amount": "",
          "gw_card_base_tax_invoiced": "",
          "gw_card_base_tax_refunded": "",
          "gw_card_price": "",
          "gw_card_price_incl_tax": "",
          "gw_card_price_invoiced": "",
          "gw_card_price_refunded": "",
          "gw_card_tax_amount": "",
          "gw_card_tax_invoiced": "",
          "gw_card_tax_refunded": "",
          "gw_id": "",
          "gw_items_base_price": "",
          "gw_items_base_price_incl_tax": "",
          "gw_items_base_price_invoiced": "",
          "gw_items_base_price_refunded": "",
          "gw_items_base_tax_amount": "",
          "gw_items_base_tax_invoiced": "",
          "gw_items_base_tax_refunded": "",
          "gw_items_price": "",
          "gw_items_price_incl_tax": "",
          "gw_items_price_invoiced": "",
          "gw_items_price_refunded": "",
          "gw_items_tax_amount": "",
          "gw_items_tax_invoiced": "",
          "gw_items_tax_refunded": "",
          "gw_price": "",
          "gw_price_incl_tax": "",
          "gw_price_invoiced": "",
          "gw_price_refunded": "",
          "gw_tax_amount": "",
          "gw_tax_amount_invoiced": "",
          "gw_tax_amount_refunded": "",
          "item_applied_taxes": [
            [
              "applied_taxes": [[]],
              "associated_item_id": 0,
              "extension_attributes": [],
              "item_id": 0,
              "type": ""
            ]
          ],
          "payment_additional_info": [
            [
              "key": "",
              "value": ""
            ]
          ],
          "reward_currency_amount": "",
          "reward_points_balance": 0,
          "shipping_assignments": [
            [
              "extension_attributes": [],
              "items": [
                [
                  "additional_data": "",
                  "amount_refunded": "",
                  "applied_rule_ids": "",
                  "base_amount_refunded": "",
                  "base_cost": "",
                  "base_discount_amount": "",
                  "base_discount_invoiced": "",
                  "base_discount_refunded": "",
                  "base_discount_tax_compensation_amount": "",
                  "base_discount_tax_compensation_invoiced": "",
                  "base_discount_tax_compensation_refunded": "",
                  "base_original_price": "",
                  "base_price": "",
                  "base_price_incl_tax": "",
                  "base_row_invoiced": "",
                  "base_row_total": "",
                  "base_row_total_incl_tax": "",
                  "base_tax_amount": "",
                  "base_tax_before_discount": "",
                  "base_tax_invoiced": "",
                  "base_tax_refunded": "",
                  "base_weee_tax_applied_amount": "",
                  "base_weee_tax_applied_row_amnt": "",
                  "base_weee_tax_disposition": "",
                  "base_weee_tax_row_disposition": "",
                  "created_at": "",
                  "description": "",
                  "discount_amount": "",
                  "discount_invoiced": "",
                  "discount_percent": "",
                  "discount_refunded": "",
                  "discount_tax_compensation_amount": "",
                  "discount_tax_compensation_canceled": "",
                  "discount_tax_compensation_invoiced": "",
                  "discount_tax_compensation_refunded": "",
                  "event_id": 0,
                  "ext_order_item_id": "",
                  "extension_attributes": [
                    "gift_message": [],
                    "gw_base_price": "",
                    "gw_base_price_invoiced": "",
                    "gw_base_price_refunded": "",
                    "gw_base_tax_amount": "",
                    "gw_base_tax_amount_invoiced": "",
                    "gw_base_tax_amount_refunded": "",
                    "gw_id": "",
                    "gw_price": "",
                    "gw_price_invoiced": "",
                    "gw_price_refunded": "",
                    "gw_tax_amount": "",
                    "gw_tax_amount_invoiced": "",
                    "gw_tax_amount_refunded": "",
                    "invoice_text_codes": [],
                    "tax_codes": [],
                    "vertex_tax_codes": []
                  ],
                  "free_shipping": 0,
                  "gw_base_price": "",
                  "gw_base_price_invoiced": "",
                  "gw_base_price_refunded": "",
                  "gw_base_tax_amount": "",
                  "gw_base_tax_amount_invoiced": "",
                  "gw_base_tax_amount_refunded": "",
                  "gw_id": 0,
                  "gw_price": "",
                  "gw_price_invoiced": "",
                  "gw_price_refunded": "",
                  "gw_tax_amount": "",
                  "gw_tax_amount_invoiced": "",
                  "gw_tax_amount_refunded": "",
                  "is_qty_decimal": 0,
                  "is_virtual": 0,
                  "item_id": 0,
                  "locked_do_invoice": 0,
                  "locked_do_ship": 0,
                  "name": "",
                  "no_discount": 0,
                  "order_id": 0,
                  "original_price": "",
                  "parent_item": "",
                  "parent_item_id": 0,
                  "price": "",
                  "price_incl_tax": "",
                  "product_id": 0,
                  "product_option": ["extension_attributes": [
                      "bundle_options": [
                        [
                          "extension_attributes": [],
                          "option_id": 0,
                          "option_qty": 0,
                          "option_selections": []
                        ]
                      ],
                      "configurable_item_options": [
                        [
                          "extension_attributes": [],
                          "option_id": "",
                          "option_value": 0
                        ]
                      ],
                      "custom_options": [
                        [
                          "extension_attributes": ["file_info": [
                              "base64_encoded_data": "",
                              "name": "",
                              "type": ""
                            ]],
                          "option_id": "",
                          "option_value": ""
                        ]
                      ],
                      "downloadable_option": ["downloadable_links": []],
                      "giftcard_item_option": [
                        "custom_giftcard_amount": "",
                        "extension_attributes": [],
                        "giftcard_amount": "",
                        "giftcard_message": "",
                        "giftcard_recipient_email": "",
                        "giftcard_recipient_name": "",
                        "giftcard_sender_email": "",
                        "giftcard_sender_name": ""
                      ]
                    ]],
                  "product_type": "",
                  "qty_backordered": "",
                  "qty_canceled": "",
                  "qty_invoiced": "",
                  "qty_ordered": "",
                  "qty_refunded": "",
                  "qty_returned": "",
                  "qty_shipped": "",
                  "quote_item_id": 0,
                  "row_invoiced": "",
                  "row_total": "",
                  "row_total_incl_tax": "",
                  "row_weight": "",
                  "sku": "",
                  "store_id": 0,
                  "tax_amount": "",
                  "tax_before_discount": "",
                  "tax_canceled": "",
                  "tax_invoiced": "",
                  "tax_percent": "",
                  "tax_refunded": "",
                  "updated_at": "",
                  "weee_tax_applied": "",
                  "weee_tax_applied_amount": "",
                  "weee_tax_applied_row_amount": "",
                  "weee_tax_disposition": "",
                  "weee_tax_row_disposition": "",
                  "weight": ""
                ]
              ],
              "shipping": [
                "address": [],
                "extension_attributes": [
                  "collection_point": [
                    "city": "",
                    "collection_point_id": "",
                    "country": "",
                    "name": "",
                    "postcode": "",
                    "recipient_address_id": 0,
                    "region": "",
                    "street": []
                  ],
                  "ext_order_id": "",
                  "shipping_experience": [
                    "code": "",
                    "cost": "",
                    "label": ""
                  ]
                ],
                "method": "",
                "total": [
                  "base_shipping_amount": "",
                  "base_shipping_canceled": "",
                  "base_shipping_discount_amount": "",
                  "base_shipping_discount_tax_compensation_amnt": "",
                  "base_shipping_incl_tax": "",
                  "base_shipping_invoiced": "",
                  "base_shipping_refunded": "",
                  "base_shipping_tax_amount": "",
                  "base_shipping_tax_refunded": "",
                  "extension_attributes": [],
                  "shipping_amount": "",
                  "shipping_canceled": "",
                  "shipping_discount_amount": "",
                  "shipping_discount_tax_compensation_amount": "",
                  "shipping_incl_tax": "",
                  "shipping_invoiced": "",
                  "shipping_refunded": "",
                  "shipping_tax_amount": "",
                  "shipping_tax_refunded": ""
                ]
              ],
              "stock_id": 0
            ]
          ]
        ],
        "forced_shipment_with_invoice": 0,
        "global_currency_code": "",
        "grand_total": "",
        "hold_before_state": "",
        "hold_before_status": "",
        "increment_id": "",
        "is_virtual": 0,
        "items": [[]],
        "order_currency_code": "",
        "original_increment_id": "",
        "payment": [
          "account_status": "",
          "additional_data": "",
          "additional_information": [],
          "address_status": "",
          "amount_authorized": "",
          "amount_canceled": "",
          "amount_ordered": "",
          "amount_paid": "",
          "amount_refunded": "",
          "anet_trans_method": "",
          "base_amount_authorized": "",
          "base_amount_canceled": "",
          "base_amount_ordered": "",
          "base_amount_paid": "",
          "base_amount_paid_online": "",
          "base_amount_refunded": "",
          "base_amount_refunded_online": "",
          "base_shipping_amount": "",
          "base_shipping_captured": "",
          "base_shipping_refunded": "",
          "cc_approval": "",
          "cc_avs_status": "",
          "cc_cid_status": "",
          "cc_debug_request_body": "",
          "cc_debug_response_body": "",
          "cc_debug_response_serialized": "",
          "cc_exp_month": "",
          "cc_exp_year": "",
          "cc_last4": "",
          "cc_number_enc": "",
          "cc_owner": "",
          "cc_secure_verify": "",
          "cc_ss_issue": "",
          "cc_ss_start_month": "",
          "cc_ss_start_year": "",
          "cc_status": "",
          "cc_status_description": "",
          "cc_trans_id": "",
          "cc_type": "",
          "echeck_account_name": "",
          "echeck_account_type": "",
          "echeck_bank_name": "",
          "echeck_routing_number": "",
          "echeck_type": "",
          "entity_id": 0,
          "extension_attributes": ["vault_payment_token": [
              "created_at": "",
              "customer_id": 0,
              "entity_id": 0,
              "expires_at": "",
              "gateway_token": "",
              "is_active": false,
              "is_visible": false,
              "payment_method_code": "",
              "public_hash": "",
              "token_details": "",
              "type": ""
            ]],
          "last_trans_id": "",
          "method": "",
          "parent_id": 0,
          "po_number": "",
          "protection_eligibility": "",
          "quote_payment_id": 0,
          "shipping_amount": "",
          "shipping_captured": "",
          "shipping_refunded": ""
        ],
        "payment_auth_expiration": 0,
        "payment_authorization_amount": "",
        "protect_code": "",
        "quote_address_id": 0,
        "quote_id": 0,
        "relation_child_id": "",
        "relation_child_real_id": "",
        "relation_parent_id": "",
        "relation_parent_real_id": "",
        "remote_ip": "",
        "shipping_amount": "",
        "shipping_canceled": "",
        "shipping_description": "",
        "shipping_discount_amount": "",
        "shipping_discount_tax_compensation_amount": "",
        "shipping_incl_tax": "",
        "shipping_invoiced": "",
        "shipping_refunded": "",
        "shipping_tax_amount": "",
        "shipping_tax_refunded": "",
        "state": "",
        "status": "",
        "status_histories": [
          [
            "comment": "",
            "created_at": "",
            "entity_id": 0,
            "entity_name": "",
            "extension_attributes": [],
            "is_customer_notified": 0,
            "is_visible_on_front": 0,
            "parent_id": 0,
            "status": ""
          ]
        ],
        "store_currency_code": "",
        "store_id": 0,
        "store_name": "",
        "store_to_base_rate": "",
        "store_to_order_rate": "",
        "subtotal": "",
        "subtotal_canceled": "",
        "subtotal_incl_tax": "",
        "subtotal_invoiced": "",
        "subtotal_refunded": "",
        "tax_amount": "",
        "tax_canceled": "",
        "tax_invoiced": "",
        "tax_refunded": "",
        "total_canceled": "",
        "total_due": "",
        "total_invoiced": "",
        "total_item_count": 0,
        "total_offline_refunded": "",
        "total_online_refunded": "",
        "total_paid": "",
        "total_qty_ordered": "",
        "total_refunded": "",
        "updated_at": "",
        "weight": "",
        "x_forwarded_for": ""
      ],
      "vertex_tax_calculation_shipping_address": []
    ],
    "global_currency_code": "",
    "grand_total": "",
    "increment_id": "",
    "is_used_for_refund": 0,
    "items": [
      [
        "additional_data": "",
        "base_cost": "",
        "base_discount_amount": "",
        "base_discount_tax_compensation_amount": "",
        "base_price": "",
        "base_price_incl_tax": "",
        "base_row_total": "",
        "base_row_total_incl_tax": "",
        "base_tax_amount": "",
        "description": "",
        "discount_amount": "",
        "discount_tax_compensation_amount": "",
        "entity_id": 0,
        "extension_attributes": [
          "invoice_text_codes": [],
          "tax_codes": [],
          "vertex_tax_codes": []
        ],
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "price_incl_tax": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "row_total_incl_tax": "",
        "sku": "",
        "tax_amount": ""
      ]
    ],
    "order_currency_code": "",
    "order_id": 0,
    "shipping_address_id": 0,
    "shipping_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_tax_amount": "",
    "state": 0,
    "store_currency_code": "",
    "store_id": 0,
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_incl_tax": "",
    "tax_amount": "",
    "total_qty": "",
    "transaction_id": "",
    "updated_at": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/invoices/")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET invoices-{id}
{{baseUrl}}/V1/invoices/:id
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/invoices/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/invoices/:id")
require "http/client"

url = "{{baseUrl}}/V1/invoices/:id"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/invoices/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/invoices/:id");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/invoices/:id"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/invoices/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/invoices/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/invoices/:id"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/invoices/:id")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/invoices/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/invoices/:id');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/invoices/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/invoices/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/invoices/:id',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/invoices/:id")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/invoices/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/invoices/:id'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/invoices/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/invoices/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/invoices/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/invoices/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/invoices/:id" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/invoices/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/invoices/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/invoices/:id');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/invoices/:id');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/invoices/:id' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/invoices/:id' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/invoices/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/invoices/:id"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/invoices/:id"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/invoices/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/invoices/:id') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/invoices/:id";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/invoices/:id
http GET {{baseUrl}}/V1/invoices/:id
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/invoices/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/invoices/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST invoices-{id}-capture
{{baseUrl}}/V1/invoices/:id/capture
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/invoices/:id/capture");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/invoices/:id/capture")
require "http/client"

url = "{{baseUrl}}/V1/invoices/:id/capture"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/invoices/:id/capture"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/invoices/:id/capture");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/invoices/:id/capture"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/invoices/:id/capture HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/invoices/:id/capture")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/invoices/:id/capture"))
    .method("POST", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/invoices/:id/capture")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/invoices/:id/capture")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/invoices/:id/capture');

xhr.send(data);
import axios from 'axios';

const options = {method: 'POST', url: '{{baseUrl}}/V1/invoices/:id/capture'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/invoices/:id/capture';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/invoices/:id/capture',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/invoices/:id/capture")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/invoices/:id/capture',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'POST', url: '{{baseUrl}}/V1/invoices/:id/capture'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/invoices/:id/capture');

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}}/V1/invoices/:id/capture'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/invoices/:id/capture';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/invoices/:id/capture"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/invoices/:id/capture" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/invoices/:id/capture",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/invoices/:id/capture');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/invoices/:id/capture');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/invoices/:id/capture');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/invoices/:id/capture' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/invoices/:id/capture' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/V1/invoices/:id/capture")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/invoices/:id/capture"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/invoices/:id/capture"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/invoices/:id/capture")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/V1/invoices/:id/capture') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/invoices/:id/capture";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/invoices/:id/capture
http POST {{baseUrl}}/V1/invoices/:id/capture
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/V1/invoices/:id/capture
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/invoices/:id/capture")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET invoices-{id}-comments
{{baseUrl}}/V1/invoices/:id/comments
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/invoices/:id/comments");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/invoices/:id/comments")
require "http/client"

url = "{{baseUrl}}/V1/invoices/:id/comments"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/invoices/:id/comments"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/invoices/:id/comments");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/invoices/:id/comments"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/invoices/:id/comments HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/invoices/:id/comments")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/invoices/:id/comments"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/invoices/:id/comments")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/invoices/:id/comments")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/invoices/:id/comments');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/invoices/:id/comments'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/invoices/:id/comments';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/invoices/:id/comments',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/invoices/:id/comments")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/invoices/:id/comments',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/invoices/:id/comments'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/invoices/:id/comments');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/invoices/:id/comments'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/invoices/:id/comments';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/invoices/:id/comments"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/invoices/:id/comments" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/invoices/:id/comments",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/invoices/:id/comments');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/invoices/:id/comments');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/invoices/:id/comments');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/invoices/:id/comments' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/invoices/:id/comments' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/invoices/:id/comments")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/invoices/:id/comments"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/invoices/:id/comments"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/invoices/:id/comments")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/invoices/:id/comments') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/invoices/:id/comments";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/invoices/:id/comments
http GET {{baseUrl}}/V1/invoices/:id/comments
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/invoices/:id/comments
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/invoices/:id/comments")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST invoices-{id}-emails
{{baseUrl}}/V1/invoices/:id/emails
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/invoices/:id/emails");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/invoices/:id/emails")
require "http/client"

url = "{{baseUrl}}/V1/invoices/:id/emails"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/invoices/:id/emails"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/invoices/:id/emails");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/invoices/:id/emails"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/invoices/:id/emails HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/invoices/:id/emails")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/invoices/:id/emails"))
    .method("POST", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/invoices/:id/emails")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/invoices/:id/emails")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/invoices/:id/emails');

xhr.send(data);
import axios from 'axios';

const options = {method: 'POST', url: '{{baseUrl}}/V1/invoices/:id/emails'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/invoices/:id/emails';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/invoices/:id/emails',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/invoices/:id/emails")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/invoices/:id/emails',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'POST', url: '{{baseUrl}}/V1/invoices/:id/emails'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/invoices/:id/emails');

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}}/V1/invoices/:id/emails'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/invoices/:id/emails';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/invoices/:id/emails"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/invoices/:id/emails" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/invoices/:id/emails",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/invoices/:id/emails');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/invoices/:id/emails');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/invoices/:id/emails');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/invoices/:id/emails' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/invoices/:id/emails' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/V1/invoices/:id/emails")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/invoices/:id/emails"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/invoices/:id/emails"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/invoices/:id/emails")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/V1/invoices/:id/emails') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/invoices/:id/emails";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/invoices/:id/emails
http POST {{baseUrl}}/V1/invoices/:id/emails
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/V1/invoices/:id/emails
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/invoices/:id/emails")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST invoices-{id}-void
{{baseUrl}}/V1/invoices/:id/void
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/invoices/:id/void");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/invoices/:id/void")
require "http/client"

url = "{{baseUrl}}/V1/invoices/:id/void"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/invoices/:id/void"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/invoices/:id/void");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/invoices/:id/void"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/invoices/:id/void HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/invoices/:id/void")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/invoices/:id/void"))
    .method("POST", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/invoices/:id/void")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/invoices/:id/void")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/invoices/:id/void');

xhr.send(data);
import axios from 'axios';

const options = {method: 'POST', url: '{{baseUrl}}/V1/invoices/:id/void'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/invoices/:id/void';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/invoices/:id/void',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/invoices/:id/void")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/invoices/:id/void',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'POST', url: '{{baseUrl}}/V1/invoices/:id/void'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/invoices/:id/void');

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}}/V1/invoices/:id/void'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/invoices/:id/void';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/invoices/:id/void"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/invoices/:id/void" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/invoices/:id/void",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/invoices/:id/void');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/invoices/:id/void');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/invoices/:id/void');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/invoices/:id/void' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/invoices/:id/void' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/V1/invoices/:id/void")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/invoices/:id/void"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/invoices/:id/void"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/invoices/:id/void")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/V1/invoices/:id/void') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/invoices/:id/void";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/invoices/:id/void
http POST {{baseUrl}}/V1/invoices/:id/void
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/V1/invoices/:id/void
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/invoices/:id/void")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST invoices-comments
{{baseUrl}}/V1/invoices/comments
BODY json

{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/invoices/comments");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/invoices/comments" {:content-type :json
                                                                 :form-params {:entity {:comment ""
                                                                                        :created_at ""
                                                                                        :entity_id 0
                                                                                        :extension_attributes {}
                                                                                        :is_customer_notified 0
                                                                                        :is_visible_on_front 0
                                                                                        :parent_id 0}}})
require "http/client"

url = "{{baseUrl}}/V1/invoices/comments"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\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}}/V1/invoices/comments"),
    Content = new StringContent("{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\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}}/V1/invoices/comments");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/invoices/comments"

	payload := strings.NewReader("{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/invoices/comments HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 194

{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/invoices/comments")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/invoices/comments"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\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  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/invoices/comments")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/invoices/comments")
  .header("content-type", "application/json")
  .body("{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  entity: {
    comment: '',
    created_at: '',
    entity_id: 0,
    extension_attributes: {},
    is_customer_notified: 0,
    is_visible_on_front: 0,
    parent_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}}/V1/invoices/comments');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/invoices/comments',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      comment: '',
      created_at: '',
      entity_id: 0,
      extension_attributes: {},
      is_customer_notified: 0,
      is_visible_on_front: 0,
      parent_id: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/invoices/comments';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"comment":"","created_at":"","entity_id":0,"extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_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}}/V1/invoices/comments',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "entity": {\n    "comment": "",\n    "created_at": "",\n    "entity_id": 0,\n    "extension_attributes": {},\n    "is_customer_notified": 0,\n    "is_visible_on_front": 0,\n    "parent_id": 0\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  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/invoices/comments")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/invoices/comments',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  entity: {
    comment: '',
    created_at: '',
    entity_id: 0,
    extension_attributes: {},
    is_customer_notified: 0,
    is_visible_on_front: 0,
    parent_id: 0
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/invoices/comments',
  headers: {'content-type': 'application/json'},
  body: {
    entity: {
      comment: '',
      created_at: '',
      entity_id: 0,
      extension_attributes: {},
      is_customer_notified: 0,
      is_visible_on_front: 0,
      parent_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}}/V1/invoices/comments');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  entity: {
    comment: '',
    created_at: '',
    entity_id: 0,
    extension_attributes: {},
    is_customer_notified: 0,
    is_visible_on_front: 0,
    parent_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}}/V1/invoices/comments',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      comment: '',
      created_at: '',
      entity_id: 0,
      extension_attributes: {},
      is_customer_notified: 0,
      is_visible_on_front: 0,
      parent_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}}/V1/invoices/comments';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"comment":"","created_at":"","entity_id":0,"extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_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 = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"entity": @{ @"comment": @"", @"created_at": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"is_customer_notified": @0, @"is_visible_on_front": @0, @"parent_id": @0 } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/invoices/comments"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/invoices/comments" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/invoices/comments",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'entity' => [
        'comment' => '',
        'created_at' => '',
        'entity_id' => 0,
        'extension_attributes' => [
                
        ],
        'is_customer_notified' => 0,
        'is_visible_on_front' => 0,
        'parent_id' => 0
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/invoices/comments', [
  'body' => '{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/invoices/comments');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'entity' => [
    'comment' => '',
    'created_at' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'is_customer_notified' => 0,
    'is_visible_on_front' => 0,
    'parent_id' => 0
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'entity' => [
    'comment' => '',
    'created_at' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'is_customer_notified' => 0,
    'is_visible_on_front' => 0,
    'parent_id' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/invoices/comments');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/invoices/comments' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/invoices/comments' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/invoices/comments", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/invoices/comments"

payload = { "entity": {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/invoices/comments"

payload <- "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/invoices/comments")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\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/V1/invoices/comments') do |req|
  req.body = "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/invoices/comments";

    let payload = json!({"entity": json!({
            "comment": "",
            "created_at": "",
            "entity_id": 0,
            "extension_attributes": json!({}),
            "is_customer_notified": 0,
            "is_visible_on_front": 0,
            "parent_id": 0
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/invoices/comments \
  --header 'content-type: application/json' \
  --data '{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}'
echo '{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}' |  \
  http POST {{baseUrl}}/V1/invoices/comments \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "entity": {\n    "comment": "",\n    "created_at": "",\n    "entity_id": 0,\n    "extension_attributes": {},\n    "is_customer_notified": 0,\n    "is_visible_on_front": 0,\n    "parent_id": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/invoices/comments
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["entity": [
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": [],
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/invoices/comments")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET modules
{{baseUrl}}/V1/modules
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/modules");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/modules")
require "http/client"

url = "{{baseUrl}}/V1/modules"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/modules"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/modules");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/modules"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/modules HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/modules")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/modules"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/modules")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/modules")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/modules');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/modules'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/modules';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/modules',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/modules")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/modules',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/modules'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/modules');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/modules'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/modules';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/modules"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/modules" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/modules",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/modules');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/modules');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/modules');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/modules' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/modules' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/modules")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/modules"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/modules"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/modules")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/modules') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/modules";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/modules
http GET {{baseUrl}}/V1/modules
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/modules
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/modules")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST negotiable-carts-{cartId}-billing-address (POST)
{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address
QUERY PARAMS

cartId
BODY json

{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address" {:content-type :json
                                                                                        :form-params {:address {:city ""
                                                                                                                :company ""
                                                                                                                :country_id ""
                                                                                                                :custom_attributes [{:attribute_code ""
                                                                                                                                     :value ""}]
                                                                                                                :customer_address_id 0
                                                                                                                :customer_id 0
                                                                                                                :email ""
                                                                                                                :extension_attributes {:checkout_fields [{}]
                                                                                                                                       :gift_registry_id 0}
                                                                                                                :fax ""
                                                                                                                :firstname ""
                                                                                                                :id 0
                                                                                                                :lastname ""
                                                                                                                :middlename ""
                                                                                                                :postcode ""
                                                                                                                :prefix ""
                                                                                                                :region ""
                                                                                                                :region_code ""
                                                                                                                :region_id 0
                                                                                                                :same_as_billing 0
                                                                                                                :save_in_address_book 0
                                                                                                                :street []
                                                                                                                :suffix ""
                                                                                                                :telephone ""
                                                                                                                :vat_id ""}
                                                                                                      :useForShipping false}})
require "http/client"

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": 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}}/V1/negotiable-carts/:cartId/billing-address"),
    Content = new StringContent("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": 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}}/V1/negotiable-carts/:cartId/billing-address");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address"

	payload := strings.NewReader("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/negotiable-carts/:cartId/billing-address HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 708

{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": 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\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address")
  .header("content-type", "application/json")
  .body("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}")
  .asString();
const data = JSON.stringify({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  useForShipping: 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}}/V1/negotiable-carts/:cartId/billing-address');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address',
  headers: {'content-type': 'application/json'},
  data: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    useForShipping: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"useForShipping":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}}/V1/negotiable-carts/:cartId/billing-address',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "useForShipping": 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\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiable-carts/:cartId/billing-address',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  useForShipping: false
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address',
  headers: {'content-type': 'application/json'},
  body: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    useForShipping: 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}}/V1/negotiable-carts/:cartId/billing-address');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  useForShipping: 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}}/V1/negotiable-carts/:cartId/billing-address',
  headers: {'content-type': 'application/json'},
  data: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    useForShipping: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"useForShipping":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" },
                              @"useForShipping": @NO };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address"]
                                                       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}}/V1/negotiable-carts/:cartId/billing-address" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'useForShipping' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address', [
  'body' => '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'useForShipping' => null
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'useForShipping' => null
]));
$request->setRequestUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/negotiable-carts/:cartId/billing-address", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address"

payload = {
    "address": {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "extension_attributes": {
            "checkout_fields": [{}],
            "gift_registry_id": 0
        },
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "same_as_billing": 0,
        "save_in_address_book": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
    },
    "useForShipping": False
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address"

payload <- "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": 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/V1/negotiable-carts/:cartId/billing-address') do |req|
  req.body = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"useForShipping\": false\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address";

    let payload = json!({
        "address": json!({
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": json!({
                "checkout_fields": (json!({})),
                "gift_registry_id": 0
            }),
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": (),
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        }),
        "useForShipping": false
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/negotiable-carts/:cartId/billing-address \
  --header 'content-type: application/json' \
  --data '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}'
echo '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "useForShipping": false
}' |  \
  http POST {{baseUrl}}/V1/negotiable-carts/:cartId/billing-address \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "address": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "useForShipping": false\n}' \
  --output-document \
  - {{baseUrl}}/V1/negotiable-carts/:cartId/billing-address
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "address": [
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": [
      "checkout_fields": [[]],
      "gift_registry_id": 0
    ],
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  ],
  "useForShipping": false
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address")! 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 negotiable-carts-{cartId}-billing-address
{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address")
require "http/client"

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/negotiable-carts/:cartId/billing-address HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiable-carts/:cartId/billing-address',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/negotiable-carts/:cartId/billing-address")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/negotiable-carts/:cartId/billing-address') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/negotiable-carts/:cartId/billing-address
http GET {{baseUrl}}/V1/negotiable-carts/:cartId/billing-address
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/negotiable-carts/:cartId/billing-address
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiable-carts/:cartId/billing-address")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE negotiable-carts-{cartId}-coupons
{{baseUrl}}/V1/negotiable-carts/:cartId/coupons
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons")
require "http/client"

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/negotiable-carts/:cartId/coupons"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/negotiable-carts/:cartId/coupons");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/negotiable-carts/:cartId/coupons HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiable-carts/:cartId/coupons"))
    .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}}/V1/negotiable-carts/:cartId/coupons")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/negotiable-carts/:cartId/coupons")
  .asString();
const 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}}/V1/negotiable-carts/:cartId/coupons');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/coupons")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiable-carts/:cartId/coupons',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons');

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}}/V1/negotiable-carts/:cartId/coupons'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiable-carts/:cartId/coupons"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/coupons');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/coupons');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/negotiable-carts/:cartId/coupons")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiable-carts/:cartId/coupons")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/negotiable-carts/:cartId/coupons') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/negotiable-carts/:cartId/coupons
http DELETE {{baseUrl}}/V1/negotiable-carts/:cartId/coupons
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/negotiable-carts/:cartId/coupons
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT negotiable-carts-{cartId}-coupons-{couponCode}
{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode
QUERY PARAMS

cartId
couponCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode")
require "http/client"

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode"

response = HTTP::Client.put url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode");
var request = new RestRequest("", Method.Put);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode"

	req, _ := http.NewRequest("PUT", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/negotiable-carts/:cartId/coupons/:couponCode HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode"))
    .method("PUT", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode")
  .put(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode';
const options = {method: 'PUT'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode',
  method: 'PUT',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode")
  .put(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiable-carts/:cartId/coupons/:couponCode',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode');

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}}/V1/negotiable-carts/:cartId/coupons/:couponCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode';
const options = {method: 'PUT'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode" in

Client.call `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode');
$request->setMethod(HTTP_METH_PUT);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode');
$request->setRequestMethod('PUT');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode' -Method PUT 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode' -Method PUT 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("PUT", "/baseUrl/V1/negotiable-carts/:cartId/coupons/:couponCode")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode"

response = requests.put(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode"

response <- VERB("PUT", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/V1/negotiable-carts/:cartId/coupons/:couponCode') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode
http PUT {{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode
wget --quiet \
  --method PUT \
  --output-document \
  - {{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiable-carts/:cartId/coupons/:couponCode")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST negotiable-carts-{cartId}-estimate-shipping-methods
{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods
QUERY PARAMS

cartId
BODY json

{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods" {:content-type :json
                                                                                                  :form-params {:address {:city ""
                                                                                                                          :company ""
                                                                                                                          :country_id ""
                                                                                                                          :custom_attributes [{:attribute_code ""
                                                                                                                                               :value ""}]
                                                                                                                          :customer_address_id 0
                                                                                                                          :customer_id 0
                                                                                                                          :email ""
                                                                                                                          :extension_attributes {:checkout_fields [{}]
                                                                                                                                                 :gift_registry_id 0}
                                                                                                                          :fax ""
                                                                                                                          :firstname ""
                                                                                                                          :id 0
                                                                                                                          :lastname ""
                                                                                                                          :middlename ""
                                                                                                                          :postcode ""
                                                                                                                          :prefix ""
                                                                                                                          :region ""
                                                                                                                          :region_code ""
                                                                                                                          :region_id 0
                                                                                                                          :same_as_billing 0
                                                                                                                          :save_in_address_book 0
                                                                                                                          :street []
                                                                                                                          :suffix ""
                                                                                                                          :telephone ""
                                                                                                                          :vat_id ""}}})
require "http/client"

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\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}}/V1/negotiable-carts/:cartId/estimate-shipping-methods"),
    Content = new StringContent("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\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}}/V1/negotiable-carts/:cartId/estimate-shipping-methods");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods"

	payload := strings.NewReader("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/negotiable-carts/:cartId/estimate-shipping-methods HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 681

{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\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\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods")
  .header("content-type", "application/json")
  .body("{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_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}}/V1/negotiable-carts/:cartId/estimate-shipping-methods');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  data: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_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}}/V1/negotiable-carts/:cartId/estimate-shipping-methods',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\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\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiable-carts/:cartId/estimate-shipping-methods',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  body: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_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}}/V1/negotiable-carts/:cartId/estimate-shipping-methods');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_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}}/V1/negotiable-carts/:cartId/estimate-shipping-methods',
  headers: {'content-type': 'application/json'},
  data: {
    address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods"]
                                                       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}}/V1/negotiable-carts/:cartId/estimate-shipping-methods" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods', [
  'body' => '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/negotiable-carts/:cartId/estimate-shipping-methods", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods"

payload = { "address": {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "extension_attributes": {
            "checkout_fields": [{}],
            "gift_registry_id": 0
        },
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "same_as_billing": 0,
        "save_in_address_book": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods"

payload <- "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\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/V1/negotiable-carts/:cartId/estimate-shipping-methods') do |req|
  req.body = "{\n  \"address\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods";

    let payload = json!({"address": json!({
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": json!({
                "checkout_fields": (json!({})),
                "gift_registry_id": 0
            }),
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": (),
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods \
  --header 'content-type: application/json' \
  --data '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}'
echo '{
  "address": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "address": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["address": [
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": [
      "checkout_fields": [[]],
      "gift_registry_id": 0
    ],
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods")! 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 negotiable-carts-{cartId}-estimate-shipping-methods-by-address-id
{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id
QUERY PARAMS

cartId
BODY json

{
  "addressId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"addressId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id" {:content-type :json
                                                                                                                :form-params {:addressId 0}})
require "http/client"

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"addressId\": 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}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id"),
    Content = new StringContent("{\n  \"addressId\": 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}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"addressId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id"

	payload := strings.NewReader("{\n  \"addressId\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 20

{
  "addressId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"addressId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"addressId\": 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  \"addressId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id")
  .header("content-type", "application/json")
  .body("{\n  \"addressId\": 0\n}")
  .asString();
const data = JSON.stringify({
  addressId: 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}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id',
  headers: {'content-type': 'application/json'},
  data: {addressId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressId":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}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "addressId": 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  \"addressId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({addressId: 0}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id',
  headers: {'content-type': 'application/json'},
  body: {addressId: 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}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  addressId: 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}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id',
  headers: {'content-type': 'application/json'},
  data: {addressId: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"addressId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"addressId\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'addressId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id', [
  'body' => '{
  "addressId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'addressId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'addressId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"addressId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id"

payload = { "addressId": 0 }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id"

payload <- "{\n  \"addressId\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"addressId\": 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/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id') do |req|
  req.body = "{\n  \"addressId\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id";

    let payload = json!({"addressId": 0});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id \
  --header 'content-type: application/json' \
  --data '{
  "addressId": 0
}'
echo '{
  "addressId": 0
}' |  \
  http POST {{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "addressId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["addressId": 0] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiable-carts/:cartId/estimate-shipping-methods-by-address-id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST negotiable-carts-{cartId}-giftCards
{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards
QUERY PARAMS

cartId
BODY json

{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards" {:content-type :json
                                                                                  :form-params {:giftCardAccountData {:base_gift_cards_amount ""
                                                                                                                      :base_gift_cards_amount_used ""
                                                                                                                      :extension_attributes {}
                                                                                                                      :gift_cards []
                                                                                                                      :gift_cards_amount ""
                                                                                                                      :gift_cards_amount_used ""}}})
require "http/client"

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\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}}/V1/negotiable-carts/:cartId/giftCards"),
    Content = new StringContent("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\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}}/V1/negotiable-carts/:cartId/giftCards");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards"

	payload := strings.NewReader("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/negotiable-carts/:cartId/giftCards HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 223

{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\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  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards")
  .header("content-type", "application/json")
  .body("{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  giftCardAccountData: {
    base_gift_cards_amount: '',
    base_gift_cards_amount_used: '',
    extension_attributes: {},
    gift_cards: [],
    gift_cards_amount: '',
    gift_cards_amount_used: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards',
  headers: {'content-type': 'application/json'},
  data: {
    giftCardAccountData: {
      base_gift_cards_amount: '',
      base_gift_cards_amount_used: '',
      extension_attributes: {},
      gift_cards: [],
      gift_cards_amount: '',
      gift_cards_amount_used: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftCardAccountData":{"base_gift_cards_amount":"","base_gift_cards_amount_used":"","extension_attributes":{},"gift_cards":[],"gift_cards_amount":"","gift_cards_amount_used":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "giftCardAccountData": {\n    "base_gift_cards_amount": "",\n    "base_gift_cards_amount_used": "",\n    "extension_attributes": {},\n    "gift_cards": [],\n    "gift_cards_amount": "",\n    "gift_cards_amount_used": ""\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  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiable-carts/:cartId/giftCards',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  giftCardAccountData: {
    base_gift_cards_amount: '',
    base_gift_cards_amount_used: '',
    extension_attributes: {},
    gift_cards: [],
    gift_cards_amount: '',
    gift_cards_amount_used: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards',
  headers: {'content-type': 'application/json'},
  body: {
    giftCardAccountData: {
      base_gift_cards_amount: '',
      base_gift_cards_amount_used: '',
      extension_attributes: {},
      gift_cards: [],
      gift_cards_amount: '',
      gift_cards_amount_used: ''
    }
  },
  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}}/V1/negotiable-carts/:cartId/giftCards');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  giftCardAccountData: {
    base_gift_cards_amount: '',
    base_gift_cards_amount_used: '',
    extension_attributes: {},
    gift_cards: [],
    gift_cards_amount: '',
    gift_cards_amount_used: ''
  }
});

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}}/V1/negotiable-carts/:cartId/giftCards',
  headers: {'content-type': 'application/json'},
  data: {
    giftCardAccountData: {
      base_gift_cards_amount: '',
      base_gift_cards_amount_used: '',
      extension_attributes: {},
      gift_cards: [],
      gift_cards_amount: '',
      gift_cards_amount_used: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"giftCardAccountData":{"base_gift_cards_amount":"","base_gift_cards_amount_used":"","extension_attributes":{},"gift_cards":[],"gift_cards_amount":"","gift_cards_amount_used":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"giftCardAccountData": @{ @"base_gift_cards_amount": @"", @"base_gift_cards_amount_used": @"", @"extension_attributes": @{  }, @"gift_cards": @[  ], @"gift_cards_amount": @"", @"gift_cards_amount_used": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards"]
                                                       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}}/V1/negotiable-carts/:cartId/giftCards" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards",
  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([
    'giftCardAccountData' => [
        'base_gift_cards_amount' => '',
        'base_gift_cards_amount_used' => '',
        'extension_attributes' => [
                
        ],
        'gift_cards' => [
                
        ],
        'gift_cards_amount' => '',
        'gift_cards_amount_used' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards', [
  'body' => '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'giftCardAccountData' => [
    'base_gift_cards_amount' => '',
    'base_gift_cards_amount_used' => '',
    'extension_attributes' => [
        
    ],
    'gift_cards' => [
        
    ],
    'gift_cards_amount' => '',
    'gift_cards_amount_used' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'giftCardAccountData' => [
    'base_gift_cards_amount' => '',
    'base_gift_cards_amount_used' => '',
    'extension_attributes' => [
        
    ],
    'gift_cards' => [
        
    ],
    'gift_cards_amount' => '',
    'gift_cards_amount_used' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/negotiable-carts/:cartId/giftCards", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards"

payload = { "giftCardAccountData": {
        "base_gift_cards_amount": "",
        "base_gift_cards_amount_used": "",
        "extension_attributes": {},
        "gift_cards": [],
        "gift_cards_amount": "",
        "gift_cards_amount_used": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards"

payload <- "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\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/V1/negotiable-carts/:cartId/giftCards') do |req|
  req.body = "{\n  \"giftCardAccountData\": {\n    \"base_gift_cards_amount\": \"\",\n    \"base_gift_cards_amount_used\": \"\",\n    \"extension_attributes\": {},\n    \"gift_cards\": [],\n    \"gift_cards_amount\": \"\",\n    \"gift_cards_amount_used\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards";

    let payload = json!({"giftCardAccountData": json!({
            "base_gift_cards_amount": "",
            "base_gift_cards_amount_used": "",
            "extension_attributes": json!({}),
            "gift_cards": (),
            "gift_cards_amount": "",
            "gift_cards_amount_used": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/negotiable-carts/:cartId/giftCards \
  --header 'content-type: application/json' \
  --data '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}'
echo '{
  "giftCardAccountData": {
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": {},
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/negotiable-carts/:cartId/giftCards \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "giftCardAccountData": {\n    "base_gift_cards_amount": "",\n    "base_gift_cards_amount_used": "",\n    "extension_attributes": {},\n    "gift_cards": [],\n    "gift_cards_amount": "",\n    "gift_cards_amount_used": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/negotiable-carts/:cartId/giftCards
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["giftCardAccountData": [
    "base_gift_cards_amount": "",
    "base_gift_cards_amount_used": "",
    "extension_attributes": [],
    "gift_cards": [],
    "gift_cards_amount": "",
    "gift_cards_amount_used": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards")! 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 negotiable-carts-{cartId}-giftCards-{giftCardCode}
{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode
QUERY PARAMS

cartId
giftCardCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode")
require "http/client"

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/negotiable-carts/:cartId/giftCards/:giftCardCode HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode"))
    .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}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode")
  .asString();
const 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}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiable-carts/:cartId/giftCards/:giftCardCode',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode');

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}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/negotiable-carts/:cartId/giftCards/:giftCardCode")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/negotiable-carts/:cartId/giftCards/:giftCardCode') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode
http DELETE {{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiable-carts/:cartId/giftCards/:giftCardCode")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST negotiable-carts-{cartId}-payment-information (POST)
{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information
QUERY PARAMS

cartId
BODY json

{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information" {:content-type :json
                                                                                            :form-params {:billingAddress {:city ""
                                                                                                                           :company ""
                                                                                                                           :country_id ""
                                                                                                                           :custom_attributes [{:attribute_code ""
                                                                                                                                                :value ""}]
                                                                                                                           :customer_address_id 0
                                                                                                                           :customer_id 0
                                                                                                                           :email ""
                                                                                                                           :extension_attributes {:checkout_fields [{}]
                                                                                                                                                  :gift_registry_id 0}
                                                                                                                           :fax ""
                                                                                                                           :firstname ""
                                                                                                                           :id 0
                                                                                                                           :lastname ""
                                                                                                                           :middlename ""
                                                                                                                           :postcode ""
                                                                                                                           :prefix ""
                                                                                                                           :region ""
                                                                                                                           :region_code ""
                                                                                                                           :region_id 0
                                                                                                                           :same_as_billing 0
                                                                                                                           :save_in_address_book 0
                                                                                                                           :street []
                                                                                                                           :suffix ""
                                                                                                                           :telephone ""
                                                                                                                           :vat_id ""}
                                                                                                          :paymentMethod {:additional_data []
                                                                                                                          :extension_attributes {:agreement_ids []}
                                                                                                                          :method ""
                                                                                                                          :po_number ""}}})
require "http/client"

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/negotiable-carts/:cartId/payment-information"),
    Content = new StringContent("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/negotiable-carts/:cartId/payment-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information"

	payload := strings.NewReader("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/negotiable-carts/:cartId/payment-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 842

{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information")
  .header("content-type", "application/json")
  .body("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information',
  headers: {'content-type': 'application/json'},
  data: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"billingAddress":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "billingAddress": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\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  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiable-carts/:cartId/payment-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {agreement_ids: []},
    method: '',
    po_number: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information',
  headers: {'content-type': 'application/json'},
  body: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information',
  headers: {'content-type': 'application/json'},
  data: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"billingAddress":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"billingAddress": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" },
                              @"paymentMethod": @{ @"additional_data": @[  ], @"extension_attributes": @{ @"agreement_ids": @[  ] }, @"method": @"", @"po_number": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information"]
                                                       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}}/V1/negotiable-carts/:cartId/payment-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information",
  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([
    'billingAddress' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'paymentMethod' => [
        'additional_data' => [
                
        ],
        'extension_attributes' => [
                'agreement_ids' => [
                                
                ]
        ],
        'method' => '',
        'po_number' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information', [
  'body' => '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'billingAddress' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'billingAddress' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/negotiable-carts/:cartId/payment-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information"

payload = {
    "billingAddress": {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "extension_attributes": {
            "checkout_fields": [{}],
            "gift_registry_id": 0
        },
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "same_as_billing": 0,
        "save_in_address_book": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
    },
    "paymentMethod": {
        "additional_data": [],
        "extension_attributes": { "agreement_ids": [] },
        "method": "",
        "po_number": ""
    }
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information"

payload <- "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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/V1/negotiable-carts/:cartId/payment-information') do |req|
  req.body = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information";

    let payload = json!({
        "billingAddress": json!({
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": json!({
                "checkout_fields": (json!({})),
                "gift_registry_id": 0
            }),
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": (),
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        }),
        "paymentMethod": json!({
            "additional_data": (),
            "extension_attributes": json!({"agreement_ids": ()}),
            "method": "",
            "po_number": ""
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/negotiable-carts/:cartId/payment-information \
  --header 'content-type: application/json' \
  --data '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
echo '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/negotiable-carts/:cartId/payment-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "billingAddress": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/negotiable-carts/:cartId/payment-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "billingAddress": [
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": [
      "checkout_fields": [[]],
      "gift_registry_id": 0
    ],
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  ],
  "paymentMethod": [
    "additional_data": [],
    "extension_attributes": ["agreement_ids": []],
    "method": "",
    "po_number": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information")! 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 negotiable-carts-{cartId}-payment-information
{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information")
require "http/client"

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/negotiable-carts/:cartId/payment-information HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiable-carts/:cartId/payment-information',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/negotiable-carts/:cartId/payment-information")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/negotiable-carts/:cartId/payment-information') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/negotiable-carts/:cartId/payment-information
http GET {{baseUrl}}/V1/negotiable-carts/:cartId/payment-information
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/negotiable-carts/:cartId/payment-information
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiable-carts/:cartId/payment-information")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST negotiable-carts-{cartId}-set-payment-information
{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information
QUERY PARAMS

cartId
BODY json

{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information" {:content-type :json
                                                                                                :form-params {:billingAddress {:city ""
                                                                                                                               :company ""
                                                                                                                               :country_id ""
                                                                                                                               :custom_attributes [{:attribute_code ""
                                                                                                                                                    :value ""}]
                                                                                                                               :customer_address_id 0
                                                                                                                               :customer_id 0
                                                                                                                               :email ""
                                                                                                                               :extension_attributes {:checkout_fields [{}]
                                                                                                                                                      :gift_registry_id 0}
                                                                                                                               :fax ""
                                                                                                                               :firstname ""
                                                                                                                               :id 0
                                                                                                                               :lastname ""
                                                                                                                               :middlename ""
                                                                                                                               :postcode ""
                                                                                                                               :prefix ""
                                                                                                                               :region ""
                                                                                                                               :region_code ""
                                                                                                                               :region_id 0
                                                                                                                               :same_as_billing 0
                                                                                                                               :save_in_address_book 0
                                                                                                                               :street []
                                                                                                                               :suffix ""
                                                                                                                               :telephone ""
                                                                                                                               :vat_id ""}
                                                                                                              :paymentMethod {:additional_data []
                                                                                                                              :extension_attributes {:agreement_ids []}
                                                                                                                              :method ""
                                                                                                                              :po_number ""}}})
require "http/client"

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/negotiable-carts/:cartId/set-payment-information"),
    Content = new StringContent("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/negotiable-carts/:cartId/set-payment-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information"

	payload := strings.NewReader("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/negotiable-carts/:cartId/set-payment-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 842

{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information")
  .header("content-type", "application/json")
  .body("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information',
  headers: {'content-type': 'application/json'},
  data: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"billingAddress":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "billingAddress": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\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  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiable-carts/:cartId/set-payment-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {agreement_ids: []},
    method: '',
    po_number: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information',
  headers: {'content-type': 'application/json'},
  body: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information',
  headers: {'content-type': 'application/json'},
  data: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"billingAddress":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"billingAddress": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" },
                              @"paymentMethod": @{ @"additional_data": @[  ], @"extension_attributes": @{ @"agreement_ids": @[  ] }, @"method": @"", @"po_number": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information"]
                                                       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}}/V1/negotiable-carts/:cartId/set-payment-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information",
  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([
    'billingAddress' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'paymentMethod' => [
        'additional_data' => [
                
        ],
        'extension_attributes' => [
                'agreement_ids' => [
                                
                ]
        ],
        'method' => '',
        'po_number' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information', [
  'body' => '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'billingAddress' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'billingAddress' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/negotiable-carts/:cartId/set-payment-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information"

payload = {
    "billingAddress": {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "extension_attributes": {
            "checkout_fields": [{}],
            "gift_registry_id": 0
        },
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "same_as_billing": 0,
        "save_in_address_book": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
    },
    "paymentMethod": {
        "additional_data": [],
        "extension_attributes": { "agreement_ids": [] },
        "method": "",
        "po_number": ""
    }
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information"

payload <- "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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/V1/negotiable-carts/:cartId/set-payment-information') do |req|
  req.body = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information";

    let payload = json!({
        "billingAddress": json!({
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": json!({
                "checkout_fields": (json!({})),
                "gift_registry_id": 0
            }),
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": (),
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        }),
        "paymentMethod": json!({
            "additional_data": (),
            "extension_attributes": json!({"agreement_ids": ()}),
            "method": "",
            "po_number": ""
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information \
  --header 'content-type: application/json' \
  --data '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
echo '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "billingAddress": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "billingAddress": [
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": [
      "checkout_fields": [[]],
      "gift_registry_id": 0
    ],
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  ],
  "paymentMethod": [
    "additional_data": [],
    "extension_attributes": ["agreement_ids": []],
    "method": "",
    "po_number": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiable-carts/:cartId/set-payment-information")! 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 negotiable-carts-{cartId}-shipping-information
{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information
QUERY PARAMS

cartId
BODY json

{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information" {:content-type :json
                                                                                             :form-params {:addressInformation {:billing_address {:city ""
                                                                                                                                                  :company ""
                                                                                                                                                  :country_id ""
                                                                                                                                                  :custom_attributes [{:attribute_code ""
                                                                                                                                                                       :value ""}]
                                                                                                                                                  :customer_address_id 0
                                                                                                                                                  :customer_id 0
                                                                                                                                                  :email ""
                                                                                                                                                  :extension_attributes {:checkout_fields [{}]
                                                                                                                                                                         :gift_registry_id 0}
                                                                                                                                                  :fax ""
                                                                                                                                                  :firstname ""
                                                                                                                                                  :id 0
                                                                                                                                                  :lastname ""
                                                                                                                                                  :middlename ""
                                                                                                                                                  :postcode ""
                                                                                                                                                  :prefix ""
                                                                                                                                                  :region ""
                                                                                                                                                  :region_code ""
                                                                                                                                                  :region_id 0
                                                                                                                                                  :same_as_billing 0
                                                                                                                                                  :save_in_address_book 0
                                                                                                                                                  :street []
                                                                                                                                                  :suffix ""
                                                                                                                                                  :telephone ""
                                                                                                                                                  :vat_id ""}
                                                                                                                                :custom_attributes [{}]
                                                                                                                                :extension_attributes {}
                                                                                                                                :shipping_address {}
                                                                                                                                :shipping_carrier_code ""
                                                                                                                                :shipping_method_code ""}}})
require "http/client"

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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}}/V1/negotiable-carts/:cartId/shipping-information"),
    Content = new StringContent("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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}}/V1/negotiable-carts/:cartId/shipping-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information"

	payload := strings.NewReader("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/negotiable-carts/:cartId/shipping-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 959

{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information")
  .header("content-type", "application/json")
  .body("{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  addressInformation: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [
      {}
    ],
    extension_attributes: {},
    shipping_address: {},
    shipping_carrier_code: '',
    shipping_method_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}}/V1/negotiable-carts/:cartId/shipping-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information',
  headers: {'content-type': 'application/json'},
  data: {
    addressInformation: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_address: {},
      shipping_carrier_code: '',
      shipping_method_code: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressInformation":{"billing_address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"custom_attributes":[{}],"extension_attributes":{},"shipping_address":{},"shipping_carrier_code":"","shipping_method_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}}/V1/negotiable-carts/:cartId/shipping-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "addressInformation": {\n    "billing_address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "custom_attributes": [\n      {}\n    ],\n    "extension_attributes": {},\n    "shipping_address": {},\n    "shipping_carrier_code": "",\n    "shipping_method_code": ""\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  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiable-carts/:cartId/shipping-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  addressInformation: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [{}],
    extension_attributes: {},
    shipping_address: {},
    shipping_carrier_code: '',
    shipping_method_code: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information',
  headers: {'content-type': 'application/json'},
  body: {
    addressInformation: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_address: {},
      shipping_carrier_code: '',
      shipping_method_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}}/V1/negotiable-carts/:cartId/shipping-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  addressInformation: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    custom_attributes: [
      {}
    ],
    extension_attributes: {},
    shipping_address: {},
    shipping_carrier_code: '',
    shipping_method_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}}/V1/negotiable-carts/:cartId/shipping-information',
  headers: {'content-type': 'application/json'},
  data: {
    addressInformation: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      custom_attributes: [{}],
      extension_attributes: {},
      shipping_address: {},
      shipping_carrier_code: '',
      shipping_method_code: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addressInformation":{"billing_address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"custom_attributes":[{}],"extension_attributes":{},"shipping_address":{},"shipping_carrier_code":"","shipping_method_code":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"addressInformation": @{ @"billing_address": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" }, @"custom_attributes": @[ @{  } ], @"extension_attributes": @{  }, @"shipping_address": @{  }, @"shipping_carrier_code": @"", @"shipping_method_code": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information"]
                                                       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}}/V1/negotiable-carts/:cartId/shipping-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information",
  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([
    'addressInformation' => [
        'billing_address' => [
                'city' => '',
                'company' => '',
                'country_id' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_address_id' => 0,
                'customer_id' => 0,
                'email' => '',
                'extension_attributes' => [
                                'checkout_fields' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'gift_registry_id' => 0
                ],
                'fax' => '',
                'firstname' => '',
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'postcode' => '',
                'prefix' => '',
                'region' => '',
                'region_code' => '',
                'region_id' => 0,
                'same_as_billing' => 0,
                'save_in_address_book' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => ''
        ],
        'custom_attributes' => [
                [
                                
                ]
        ],
        'extension_attributes' => [
                
        ],
        'shipping_address' => [
                
        ],
        'shipping_carrier_code' => '',
        'shipping_method_code' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information', [
  'body' => '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'addressInformation' => [
    'billing_address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'extension_attributes' => [
        
    ],
    'shipping_address' => [
        
    ],
    'shipping_carrier_code' => '',
    'shipping_method_code' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'addressInformation' => [
    'billing_address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'extension_attributes' => [
        
    ],
    'shipping_address' => [
        
    ],
    'shipping_carrier_code' => '',
    'shipping_method_code' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/negotiable-carts/:cartId/shipping-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information"

payload = { "addressInformation": {
        "billing_address": {
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": [
                {
                    "attribute_code": "",
                    "value": ""
                }
            ],
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": {
                "checkout_fields": [{}],
                "gift_registry_id": 0
            },
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": [],
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        },
        "custom_attributes": [{}],
        "extension_attributes": {},
        "shipping_address": {},
        "shipping_carrier_code": "",
        "shipping_method_code": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information"

payload <- "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\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/V1/negotiable-carts/:cartId/shipping-information') do |req|
  req.body = "{\n  \"addressInformation\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"custom_attributes\": [\n      {}\n    ],\n    \"extension_attributes\": {},\n    \"shipping_address\": {},\n    \"shipping_carrier_code\": \"\",\n    \"shipping_method_code\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information";

    let payload = json!({"addressInformation": json!({
            "billing_address": json!({
                "city": "",
                "company": "",
                "country_id": "",
                "custom_attributes": (
                    json!({
                        "attribute_code": "",
                        "value": ""
                    })
                ),
                "customer_address_id": 0,
                "customer_id": 0,
                "email": "",
                "extension_attributes": json!({
                    "checkout_fields": (json!({})),
                    "gift_registry_id": 0
                }),
                "fax": "",
                "firstname": "",
                "id": 0,
                "lastname": "",
                "middlename": "",
                "postcode": "",
                "prefix": "",
                "region": "",
                "region_code": "",
                "region_id": 0,
                "same_as_billing": 0,
                "save_in_address_book": 0,
                "street": (),
                "suffix": "",
                "telephone": "",
                "vat_id": ""
            }),
            "custom_attributes": (json!({})),
            "extension_attributes": json!({}),
            "shipping_address": json!({}),
            "shipping_carrier_code": "",
            "shipping_method_code": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information \
  --header 'content-type: application/json' \
  --data '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}'
echo '{
  "addressInformation": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "custom_attributes": [
      {}
    ],
    "extension_attributes": {},
    "shipping_address": {},
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "addressInformation": {\n    "billing_address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "custom_attributes": [\n      {}\n    ],\n    "extension_attributes": {},\n    "shipping_address": {},\n    "shipping_carrier_code": "",\n    "shipping_method_code": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["addressInformation": [
    "billing_address": [
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        [
          "attribute_code": "",
          "value": ""
        ]
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": [
        "checkout_fields": [[]],
        "gift_registry_id": 0
      ],
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    ],
    "custom_attributes": [[]],
    "extension_attributes": [],
    "shipping_address": [],
    "shipping_carrier_code": "",
    "shipping_method_code": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiable-carts/:cartId/shipping-information")! 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 negotiable-carts-{cartId}-totals
{{baseUrl}}/V1/negotiable-carts/:cartId/totals
QUERY PARAMS

cartId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiable-carts/:cartId/totals");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/negotiable-carts/:cartId/totals")
require "http/client"

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/totals"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/negotiable-carts/:cartId/totals"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/negotiable-carts/:cartId/totals");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiable-carts/:cartId/totals"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/negotiable-carts/:cartId/totals HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/negotiable-carts/:cartId/totals")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiable-carts/:cartId/totals"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/totals")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/negotiable-carts/:cartId/totals")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/negotiable-carts/:cartId/totals');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/totals'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/totals';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/totals',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiable-carts/:cartId/totals")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiable-carts/:cartId/totals',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/totals'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/negotiable-carts/:cartId/totals');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/negotiable-carts/:cartId/totals'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiable-carts/:cartId/totals';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiable-carts/:cartId/totals"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/negotiable-carts/:cartId/totals" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiable-carts/:cartId/totals",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/negotiable-carts/:cartId/totals');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/totals');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/negotiable-carts/:cartId/totals');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/totals' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiable-carts/:cartId/totals' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/negotiable-carts/:cartId/totals")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiable-carts/:cartId/totals"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiable-carts/:cartId/totals"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiable-carts/:cartId/totals")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/negotiable-carts/:cartId/totals') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiable-carts/:cartId/totals";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/negotiable-carts/:cartId/totals
http GET {{baseUrl}}/V1/negotiable-carts/:cartId/totals
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/negotiable-carts/:cartId/totals
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiable-carts/:cartId/totals")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT negotiableQuote-{quoteId}
{{baseUrl}}/V1/negotiableQuote/:quoteId
QUERY PARAMS

quoteId
BODY json

{
  "quote": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "converted_at": "",
    "created_at": "",
    "currency": {
      "base_currency_code": "",
      "base_to_global_rate": "",
      "base_to_quote_rate": "",
      "extension_attributes": {},
      "global_currency_code": "",
      "quote_currency_code": "",
      "store_currency_code": "",
      "store_to_base_rate": "",
      "store_to_quote_rate": ""
    },
    "customer": {
      "addresses": [
        {
          "city": "",
          "company": "",
          "country_id": "",
          "custom_attributes": [
            {}
          ],
          "customer_id": 0,
          "default_billing": false,
          "default_shipping": false,
          "extension_attributes": {},
          "fax": "",
          "firstname": "",
          "id": 0,
          "lastname": "",
          "middlename": "",
          "postcode": "",
          "prefix": "",
          "region": {
            "extension_attributes": {},
            "region": "",
            "region_code": "",
            "region_id": 0
          },
          "region_id": 0,
          "street": [],
          "suffix": "",
          "telephone": "",
          "vat_id": ""
        }
      ],
      "confirmation": "",
      "created_at": "",
      "created_in": "",
      "custom_attributes": [
        {}
      ],
      "default_billing": "",
      "default_shipping": "",
      "disable_auto_group_change": 0,
      "dob": "",
      "email": "",
      "extension_attributes": {
        "amazon_id": "",
        "company_attributes": {
          "company_id": 0,
          "customer_id": 0,
          "extension_attributes": {},
          "job_title": "",
          "status": 0,
          "telephone": ""
        },
        "is_subscribed": false,
        "vertex_customer_code": ""
      },
      "firstname": "",
      "gender": 0,
      "group_id": 0,
      "id": 0,
      "lastname": "",
      "middlename": "",
      "prefix": "",
      "store_id": 0,
      "suffix": "",
      "taxvat": "",
      "updated_at": "",
      "website_id": 0
    },
    "customer_is_guest": false,
    "customer_note": "",
    "customer_note_notify": false,
    "customer_tax_class_id": 0,
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "negotiable_quote": {
        "applied_rule_ids": "",
        "base_negotiated_total_price": "",
        "base_original_total_price": "",
        "creator_id": 0,
        "creator_type": 0,
        "deleted_sku": "",
        "email_notification_status": 0,
        "expiration_period": "",
        "extension_attributes": {},
        "has_unconfirmed_changes": false,
        "is_address_draft": false,
        "is_customer_price_changed": false,
        "is_regular_quote": false,
        "is_shipping_tax_changed": false,
        "negotiated_price_type": 0,
        "negotiated_price_value": "",
        "negotiated_total_price": "",
        "notifications": 0,
        "original_total_price": "",
        "quote_id": 0,
        "quote_name": "",
        "shipping_price": "",
        "status": ""
      },
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "extension_attributes": {
                "negotiable_quote_item": {
                  "extension_attributes": {},
                  "item_id": 0,
                  "original_discount_amount": "",
                  "original_price": "",
                  "original_tax_amount": ""
                }
              },
              "item_id": 0,
              "name": "",
              "price": "",
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty": "",
              "quote_id": "",
              "sku": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {},
            "method": ""
          }
        }
      ]
    },
    "id": 0,
    "is_active": false,
    "is_virtual": false,
    "items": [
      {}
    ],
    "items_count": 0,
    "items_qty": "",
    "orig_order_id": 0,
    "reserved_order_id": "",
    "store_id": 0,
    "updated_at": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiableQuote/:quoteId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/negotiableQuote/:quoteId" {:content-type :json
                                                                       :form-params {:quote {:billing_address {:city ""
                                                                                                               :company ""
                                                                                                               :country_id ""
                                                                                                               :custom_attributes [{:attribute_code ""
                                                                                                                                    :value ""}]
                                                                                                               :customer_address_id 0
                                                                                                               :customer_id 0
                                                                                                               :email ""
                                                                                                               :extension_attributes {:checkout_fields [{}]
                                                                                                                                      :gift_registry_id 0}
                                                                                                               :fax ""
                                                                                                               :firstname ""
                                                                                                               :id 0
                                                                                                               :lastname ""
                                                                                                               :middlename ""
                                                                                                               :postcode ""
                                                                                                               :prefix ""
                                                                                                               :region ""
                                                                                                               :region_code ""
                                                                                                               :region_id 0
                                                                                                               :same_as_billing 0
                                                                                                               :save_in_address_book 0
                                                                                                               :street []
                                                                                                               :suffix ""
                                                                                                               :telephone ""
                                                                                                               :vat_id ""}
                                                                                             :converted_at ""
                                                                                             :created_at ""
                                                                                             :currency {:base_currency_code ""
                                                                                                        :base_to_global_rate ""
                                                                                                        :base_to_quote_rate ""
                                                                                                        :extension_attributes {}
                                                                                                        :global_currency_code ""
                                                                                                        :quote_currency_code ""
                                                                                                        :store_currency_code ""
                                                                                                        :store_to_base_rate ""
                                                                                                        :store_to_quote_rate ""}
                                                                                             :customer {:addresses [{:city ""
                                                                                                                     :company ""
                                                                                                                     :country_id ""
                                                                                                                     :custom_attributes [{}]
                                                                                                                     :customer_id 0
                                                                                                                     :default_billing false
                                                                                                                     :default_shipping false
                                                                                                                     :extension_attributes {}
                                                                                                                     :fax ""
                                                                                                                     :firstname ""
                                                                                                                     :id 0
                                                                                                                     :lastname ""
                                                                                                                     :middlename ""
                                                                                                                     :postcode ""
                                                                                                                     :prefix ""
                                                                                                                     :region {:extension_attributes {}
                                                                                                                              :region ""
                                                                                                                              :region_code ""
                                                                                                                              :region_id 0}
                                                                                                                     :region_id 0
                                                                                                                     :street []
                                                                                                                     :suffix ""
                                                                                                                     :telephone ""
                                                                                                                     :vat_id ""}]
                                                                                                        :confirmation ""
                                                                                                        :created_at ""
                                                                                                        :created_in ""
                                                                                                        :custom_attributes [{}]
                                                                                                        :default_billing ""
                                                                                                        :default_shipping ""
                                                                                                        :disable_auto_group_change 0
                                                                                                        :dob ""
                                                                                                        :email ""
                                                                                                        :extension_attributes {:amazon_id ""
                                                                                                                               :company_attributes {:company_id 0
                                                                                                                                                    :customer_id 0
                                                                                                                                                    :extension_attributes {}
                                                                                                                                                    :job_title ""
                                                                                                                                                    :status 0
                                                                                                                                                    :telephone ""}
                                                                                                                               :is_subscribed false
                                                                                                                               :vertex_customer_code ""}
                                                                                                        :firstname ""
                                                                                                        :gender 0
                                                                                                        :group_id 0
                                                                                                        :id 0
                                                                                                        :lastname ""
                                                                                                        :middlename ""
                                                                                                        :prefix ""
                                                                                                        :store_id 0
                                                                                                        :suffix ""
                                                                                                        :taxvat ""
                                                                                                        :updated_at ""
                                                                                                        :website_id 0}
                                                                                             :customer_is_guest false
                                                                                             :customer_note ""
                                                                                             :customer_note_notify false
                                                                                             :customer_tax_class_id 0
                                                                                             :extension_attributes {:amazon_order_reference_id ""
                                                                                                                    :negotiable_quote {:applied_rule_ids ""
                                                                                                                                       :base_negotiated_total_price ""
                                                                                                                                       :base_original_total_price ""
                                                                                                                                       :creator_id 0
                                                                                                                                       :creator_type 0
                                                                                                                                       :deleted_sku ""
                                                                                                                                       :email_notification_status 0
                                                                                                                                       :expiration_period ""
                                                                                                                                       :extension_attributes {}
                                                                                                                                       :has_unconfirmed_changes false
                                                                                                                                       :is_address_draft false
                                                                                                                                       :is_customer_price_changed false
                                                                                                                                       :is_regular_quote false
                                                                                                                                       :is_shipping_tax_changed false
                                                                                                                                       :negotiated_price_type 0
                                                                                                                                       :negotiated_price_value ""
                                                                                                                                       :negotiated_total_price ""
                                                                                                                                       :notifications 0
                                                                                                                                       :original_total_price ""
                                                                                                                                       :quote_id 0
                                                                                                                                       :quote_name ""
                                                                                                                                       :shipping_price ""
                                                                                                                                       :status ""}
                                                                                                                    :shipping_assignments [{:extension_attributes {}
                                                                                                                                            :items [{:extension_attributes {:negotiable_quote_item {:extension_attributes {}
                                                                                                                                                                                                    :item_id 0
                                                                                                                                                                                                    :original_discount_amount ""
                                                                                                                                                                                                    :original_price ""
                                                                                                                                                                                                    :original_tax_amount ""}}
                                                                                                                                                     :item_id 0
                                                                                                                                                     :name ""
                                                                                                                                                     :price ""
                                                                                                                                                     :product_option {:extension_attributes {:bundle_options [{:extension_attributes {}
                                                                                                                                                                                                               :option_id 0
                                                                                                                                                                                                               :option_qty 0
                                                                                                                                                                                                               :option_selections []}]
                                                                                                                                                                                             :configurable_item_options [{:extension_attributes {}
                                                                                                                                                                                                                          :option_id ""
                                                                                                                                                                                                                          :option_value 0}]
                                                                                                                                                                                             :custom_options [{:extension_attributes {:file_info {:base64_encoded_data ""
                                                                                                                                                                                                                                                  :name ""
                                                                                                                                                                                                                                                  :type ""}}
                                                                                                                                                                                                               :option_id ""
                                                                                                                                                                                                               :option_value ""}]
                                                                                                                                                                                             :downloadable_option {:downloadable_links []}
                                                                                                                                                                                             :giftcard_item_option {:custom_giftcard_amount ""
                                                                                                                                                                                                                    :extension_attributes {}
                                                                                                                                                                                                                    :giftcard_amount ""
                                                                                                                                                                                                                    :giftcard_message ""
                                                                                                                                                                                                                    :giftcard_recipient_email ""
                                                                                                                                                                                                                    :giftcard_recipient_name ""
                                                                                                                                                                                                                    :giftcard_sender_email ""
                                                                                                                                                                                                                    :giftcard_sender_name ""}}}
                                                                                                                                                     :product_type ""
                                                                                                                                                     :qty ""
                                                                                                                                                     :quote_id ""
                                                                                                                                                     :sku ""}]
                                                                                                                                            :shipping {:address {}
                                                                                                                                                       :extension_attributes {}
                                                                                                                                                       :method ""}}]}
                                                                                             :id 0
                                                                                             :is_active false
                                                                                             :is_virtual false
                                                                                             :items [{}]
                                                                                             :items_count 0
                                                                                             :items_qty ""
                                                                                             :orig_order_id 0
                                                                                             :reserved_order_id ""
                                                                                             :store_id 0
                                                                                             :updated_at ""}}})
require "http/client"

url = "{{baseUrl}}/V1/negotiableQuote/:quoteId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\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}}/V1/negotiableQuote/:quoteId"),
    Content = new StringContent("{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\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}}/V1/negotiableQuote/:quoteId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiableQuote/:quoteId"

	payload := strings.NewReader("{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/negotiableQuote/:quoteId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 6493

{
  "quote": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "converted_at": "",
    "created_at": "",
    "currency": {
      "base_currency_code": "",
      "base_to_global_rate": "",
      "base_to_quote_rate": "",
      "extension_attributes": {},
      "global_currency_code": "",
      "quote_currency_code": "",
      "store_currency_code": "",
      "store_to_base_rate": "",
      "store_to_quote_rate": ""
    },
    "customer": {
      "addresses": [
        {
          "city": "",
          "company": "",
          "country_id": "",
          "custom_attributes": [
            {}
          ],
          "customer_id": 0,
          "default_billing": false,
          "default_shipping": false,
          "extension_attributes": {},
          "fax": "",
          "firstname": "",
          "id": 0,
          "lastname": "",
          "middlename": "",
          "postcode": "",
          "prefix": "",
          "region": {
            "extension_attributes": {},
            "region": "",
            "region_code": "",
            "region_id": 0
          },
          "region_id": 0,
          "street": [],
          "suffix": "",
          "telephone": "",
          "vat_id": ""
        }
      ],
      "confirmation": "",
      "created_at": "",
      "created_in": "",
      "custom_attributes": [
        {}
      ],
      "default_billing": "",
      "default_shipping": "",
      "disable_auto_group_change": 0,
      "dob": "",
      "email": "",
      "extension_attributes": {
        "amazon_id": "",
        "company_attributes": {
          "company_id": 0,
          "customer_id": 0,
          "extension_attributes": {},
          "job_title": "",
          "status": 0,
          "telephone": ""
        },
        "is_subscribed": false,
        "vertex_customer_code": ""
      },
      "firstname": "",
      "gender": 0,
      "group_id": 0,
      "id": 0,
      "lastname": "",
      "middlename": "",
      "prefix": "",
      "store_id": 0,
      "suffix": "",
      "taxvat": "",
      "updated_at": "",
      "website_id": 0
    },
    "customer_is_guest": false,
    "customer_note": "",
    "customer_note_notify": false,
    "customer_tax_class_id": 0,
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "negotiable_quote": {
        "applied_rule_ids": "",
        "base_negotiated_total_price": "",
        "base_original_total_price": "",
        "creator_id": 0,
        "creator_type": 0,
        "deleted_sku": "",
        "email_notification_status": 0,
        "expiration_period": "",
        "extension_attributes": {},
        "has_unconfirmed_changes": false,
        "is_address_draft": false,
        "is_customer_price_changed": false,
        "is_regular_quote": false,
        "is_shipping_tax_changed": false,
        "negotiated_price_type": 0,
        "negotiated_price_value": "",
        "negotiated_total_price": "",
        "notifications": 0,
        "original_total_price": "",
        "quote_id": 0,
        "quote_name": "",
        "shipping_price": "",
        "status": ""
      },
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "extension_attributes": {
                "negotiable_quote_item": {
                  "extension_attributes": {},
                  "item_id": 0,
                  "original_discount_amount": "",
                  "original_price": "",
                  "original_tax_amount": ""
                }
              },
              "item_id": 0,
              "name": "",
              "price": "",
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty": "",
              "quote_id": "",
              "sku": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {},
            "method": ""
          }
        }
      ]
    },
    "id": 0,
    "is_active": false,
    "is_virtual": false,
    "items": [
      {}
    ],
    "items_count": 0,
    "items_qty": "",
    "orig_order_id": 0,
    "reserved_order_id": "",
    "store_id": 0,
    "updated_at": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/negotiableQuote/:quoteId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiableQuote/:quoteId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\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  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiableQuote/:quoteId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/negotiableQuote/:quoteId")
  .header("content-type", "application/json")
  .body("{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  quote: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    converted_at: '',
    created_at: '',
    currency: {
      base_currency_code: '',
      base_to_global_rate: '',
      base_to_quote_rate: '',
      extension_attributes: {},
      global_currency_code: '',
      quote_currency_code: '',
      store_currency_code: '',
      store_to_base_rate: '',
      store_to_quote_rate: ''
    },
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [
            {}
          ],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {
            extension_attributes: {},
            region: '',
            region_code: '',
            region_id: 0
          },
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [
        {}
      ],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_id: 0
    },
    customer_is_guest: false,
    customer_note: '',
    customer_note_notify: false,
    customer_tax_class_id: 0,
    extension_attributes: {
      amazon_order_reference_id: '',
      negotiable_quote: {
        applied_rule_ids: '',
        base_negotiated_total_price: '',
        base_original_total_price: '',
        creator_id: 0,
        creator_type: 0,
        deleted_sku: '',
        email_notification_status: 0,
        expiration_period: '',
        extension_attributes: {},
        has_unconfirmed_changes: false,
        is_address_draft: false,
        is_customer_price_changed: false,
        is_regular_quote: false,
        is_shipping_tax_changed: false,
        negotiated_price_type: 0,
        negotiated_price_value: '',
        negotiated_total_price: '',
        notifications: 0,
        original_total_price: '',
        quote_id: 0,
        quote_name: '',
        shipping_price: '',
        status: ''
      },
      shipping_assignments: [
        {
          extension_attributes: {},
          items: [
            {
              extension_attributes: {
                negotiable_quote_item: {
                  extension_attributes: {},
                  item_id: 0,
                  original_discount_amount: '',
                  original_price: '',
                  original_tax_amount: ''
                }
              },
              item_id: 0,
              name: '',
              price: '',
              product_option: {
                extension_attributes: {
                  bundle_options: [
                    {
                      extension_attributes: {},
                      option_id: 0,
                      option_qty: 0,
                      option_selections: []
                    }
                  ],
                  configurable_item_options: [
                    {
                      extension_attributes: {},
                      option_id: '',
                      option_value: 0
                    }
                  ],
                  custom_options: [
                    {
                      extension_attributes: {
                        file_info: {
                          base64_encoded_data: '',
                          name: '',
                          type: ''
                        }
                      },
                      option_id: '',
                      option_value: ''
                    }
                  ],
                  downloadable_option: {
                    downloadable_links: []
                  },
                  giftcard_item_option: {
                    custom_giftcard_amount: '',
                    extension_attributes: {},
                    giftcard_amount: '',
                    giftcard_message: '',
                    giftcard_recipient_email: '',
                    giftcard_recipient_name: '',
                    giftcard_sender_email: '',
                    giftcard_sender_name: ''
                  }
                }
              },
              product_type: '',
              qty: '',
              quote_id: '',
              sku: ''
            }
          ],
          shipping: {
            address: {},
            extension_attributes: {},
            method: ''
          }
        }
      ]
    },
    id: 0,
    is_active: false,
    is_virtual: false,
    items: [
      {}
    ],
    items_count: 0,
    items_qty: '',
    orig_order_id: 0,
    reserved_order_id: '',
    store_id: 0,
    updated_at: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/negotiableQuote/:quoteId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/negotiableQuote/:quoteId',
  headers: {'content-type': 'application/json'},
  data: {
    quote: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      converted_at: '',
      created_at: '',
      currency: {
        base_currency_code: '',
        base_to_global_rate: '',
        base_to_quote_rate: '',
        extension_attributes: {},
        global_currency_code: '',
        quote_currency_code: '',
        store_currency_code: '',
        store_to_base_rate: '',
        store_to_quote_rate: ''
      },
      customer: {
        addresses: [
          {
            city: '',
            company: '',
            country_id: '',
            custom_attributes: [{}],
            customer_id: 0,
            default_billing: false,
            default_shipping: false,
            extension_attributes: {},
            fax: '',
            firstname: '',
            id: 0,
            lastname: '',
            middlename: '',
            postcode: '',
            prefix: '',
            region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
            region_id: 0,
            street: [],
            suffix: '',
            telephone: '',
            vat_id: ''
          }
        ],
        confirmation: '',
        created_at: '',
        created_in: '',
        custom_attributes: [{}],
        default_billing: '',
        default_shipping: '',
        disable_auto_group_change: 0,
        dob: '',
        email: '',
        extension_attributes: {
          amazon_id: '',
          company_attributes: {
            company_id: 0,
            customer_id: 0,
            extension_attributes: {},
            job_title: '',
            status: 0,
            telephone: ''
          },
          is_subscribed: false,
          vertex_customer_code: ''
        },
        firstname: '',
        gender: 0,
        group_id: 0,
        id: 0,
        lastname: '',
        middlename: '',
        prefix: '',
        store_id: 0,
        suffix: '',
        taxvat: '',
        updated_at: '',
        website_id: 0
      },
      customer_is_guest: false,
      customer_note: '',
      customer_note_notify: false,
      customer_tax_class_id: 0,
      extension_attributes: {
        amazon_order_reference_id: '',
        negotiable_quote: {
          applied_rule_ids: '',
          base_negotiated_total_price: '',
          base_original_total_price: '',
          creator_id: 0,
          creator_type: 0,
          deleted_sku: '',
          email_notification_status: 0,
          expiration_period: '',
          extension_attributes: {},
          has_unconfirmed_changes: false,
          is_address_draft: false,
          is_customer_price_changed: false,
          is_regular_quote: false,
          is_shipping_tax_changed: false,
          negotiated_price_type: 0,
          negotiated_price_value: '',
          negotiated_total_price: '',
          notifications: 0,
          original_total_price: '',
          quote_id: 0,
          quote_name: '',
          shipping_price: '',
          status: ''
        },
        shipping_assignments: [
          {
            extension_attributes: {},
            items: [
              {
                extension_attributes: {
                  negotiable_quote_item: {
                    extension_attributes: {},
                    item_id: 0,
                    original_discount_amount: '',
                    original_price: '',
                    original_tax_amount: ''
                  }
                },
                item_id: 0,
                name: '',
                price: '',
                product_option: {
                  extension_attributes: {
                    bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                    configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                    custom_options: [
                      {
                        extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                        option_id: '',
                        option_value: ''
                      }
                    ],
                    downloadable_option: {downloadable_links: []},
                    giftcard_item_option: {
                      custom_giftcard_amount: '',
                      extension_attributes: {},
                      giftcard_amount: '',
                      giftcard_message: '',
                      giftcard_recipient_email: '',
                      giftcard_recipient_name: '',
                      giftcard_sender_email: '',
                      giftcard_sender_name: ''
                    }
                  }
                },
                product_type: '',
                qty: '',
                quote_id: '',
                sku: ''
              }
            ],
            shipping: {address: {}, extension_attributes: {}, method: ''}
          }
        ]
      },
      id: 0,
      is_active: false,
      is_virtual: false,
      items: [{}],
      items_count: 0,
      items_qty: '',
      orig_order_id: 0,
      reserved_order_id: '',
      store_id: 0,
      updated_at: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiableQuote/:quoteId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"quote":{"billing_address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"converted_at":"","created_at":"","currency":{"base_currency_code":"","base_to_global_rate":"","base_to_quote_rate":"","extension_attributes":{},"global_currency_code":"","quote_currency_code":"","store_currency_code":"","store_to_base_rate":"","store_to_quote_rate":""},"customer":{"addresses":[{"city":"","company":"","country_id":"","custom_attributes":[{}],"customer_id":0,"default_billing":false,"default_shipping":false,"extension_attributes":{},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":{"extension_attributes":{},"region":"","region_code":"","region_id":0},"region_id":0,"street":[],"suffix":"","telephone":"","vat_id":""}],"confirmation":"","created_at":"","created_in":"","custom_attributes":[{}],"default_billing":"","default_shipping":"","disable_auto_group_change":0,"dob":"","email":"","extension_attributes":{"amazon_id":"","company_attributes":{"company_id":0,"customer_id":0,"extension_attributes":{},"job_title":"","status":0,"telephone":""},"is_subscribed":false,"vertex_customer_code":""},"firstname":"","gender":0,"group_id":0,"id":0,"lastname":"","middlename":"","prefix":"","store_id":0,"suffix":"","taxvat":"","updated_at":"","website_id":0},"customer_is_guest":false,"customer_note":"","customer_note_notify":false,"customer_tax_class_id":0,"extension_attributes":{"amazon_order_reference_id":"","negotiable_quote":{"applied_rule_ids":"","base_negotiated_total_price":"","base_original_total_price":"","creator_id":0,"creator_type":0,"deleted_sku":"","email_notification_status":0,"expiration_period":"","extension_attributes":{},"has_unconfirmed_changes":false,"is_address_draft":false,"is_customer_price_changed":false,"is_regular_quote":false,"is_shipping_tax_changed":false,"negotiated_price_type":0,"negotiated_price_value":"","negotiated_total_price":"","notifications":0,"original_total_price":"","quote_id":0,"quote_name":"","shipping_price":"","status":""},"shipping_assignments":[{"extension_attributes":{},"items":[{"extension_attributes":{"negotiable_quote_item":{"extension_attributes":{},"item_id":0,"original_discount_amount":"","original_price":"","original_tax_amount":""}},"item_id":0,"name":"","price":"","product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty":"","quote_id":"","sku":""}],"shipping":{"address":{},"extension_attributes":{},"method":""}}]},"id":0,"is_active":false,"is_virtual":false,"items":[{}],"items_count":0,"items_qty":"","orig_order_id":0,"reserved_order_id":"","store_id":0,"updated_at":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/negotiableQuote/:quoteId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "quote": {\n    "billing_address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "converted_at": "",\n    "created_at": "",\n    "currency": {\n      "base_currency_code": "",\n      "base_to_global_rate": "",\n      "base_to_quote_rate": "",\n      "extension_attributes": {},\n      "global_currency_code": "",\n      "quote_currency_code": "",\n      "store_currency_code": "",\n      "store_to_base_rate": "",\n      "store_to_quote_rate": ""\n    },\n    "customer": {\n      "addresses": [\n        {\n          "city": "",\n          "company": "",\n          "country_id": "",\n          "custom_attributes": [\n            {}\n          ],\n          "customer_id": 0,\n          "default_billing": false,\n          "default_shipping": false,\n          "extension_attributes": {},\n          "fax": "",\n          "firstname": "",\n          "id": 0,\n          "lastname": "",\n          "middlename": "",\n          "postcode": "",\n          "prefix": "",\n          "region": {\n            "extension_attributes": {},\n            "region": "",\n            "region_code": "",\n            "region_id": 0\n          },\n          "region_id": 0,\n          "street": [],\n          "suffix": "",\n          "telephone": "",\n          "vat_id": ""\n        }\n      ],\n      "confirmation": "",\n      "created_at": "",\n      "created_in": "",\n      "custom_attributes": [\n        {}\n      ],\n      "default_billing": "",\n      "default_shipping": "",\n      "disable_auto_group_change": 0,\n      "dob": "",\n      "email": "",\n      "extension_attributes": {\n        "amazon_id": "",\n        "company_attributes": {\n          "company_id": 0,\n          "customer_id": 0,\n          "extension_attributes": {},\n          "job_title": "",\n          "status": 0,\n          "telephone": ""\n        },\n        "is_subscribed": false,\n        "vertex_customer_code": ""\n      },\n      "firstname": "",\n      "gender": 0,\n      "group_id": 0,\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "prefix": "",\n      "store_id": 0,\n      "suffix": "",\n      "taxvat": "",\n      "updated_at": "",\n      "website_id": 0\n    },\n    "customer_is_guest": false,\n    "customer_note": "",\n    "customer_note_notify": false,\n    "customer_tax_class_id": 0,\n    "extension_attributes": {\n      "amazon_order_reference_id": "",\n      "negotiable_quote": {\n        "applied_rule_ids": "",\n        "base_negotiated_total_price": "",\n        "base_original_total_price": "",\n        "creator_id": 0,\n        "creator_type": 0,\n        "deleted_sku": "",\n        "email_notification_status": 0,\n        "expiration_period": "",\n        "extension_attributes": {},\n        "has_unconfirmed_changes": false,\n        "is_address_draft": false,\n        "is_customer_price_changed": false,\n        "is_regular_quote": false,\n        "is_shipping_tax_changed": false,\n        "negotiated_price_type": 0,\n        "negotiated_price_value": "",\n        "negotiated_total_price": "",\n        "notifications": 0,\n        "original_total_price": "",\n        "quote_id": 0,\n        "quote_name": "",\n        "shipping_price": "",\n        "status": ""\n      },\n      "shipping_assignments": [\n        {\n          "extension_attributes": {},\n          "items": [\n            {\n              "extension_attributes": {\n                "negotiable_quote_item": {\n                  "extension_attributes": {},\n                  "item_id": 0,\n                  "original_discount_amount": "",\n                  "original_price": "",\n                  "original_tax_amount": ""\n                }\n              },\n              "item_id": 0,\n              "name": "",\n              "price": "",\n              "product_option": {\n                "extension_attributes": {\n                  "bundle_options": [\n                    {\n                      "extension_attributes": {},\n                      "option_id": 0,\n                      "option_qty": 0,\n                      "option_selections": []\n                    }\n                  ],\n                  "configurable_item_options": [\n                    {\n                      "extension_attributes": {},\n                      "option_id": "",\n                      "option_value": 0\n                    }\n                  ],\n                  "custom_options": [\n                    {\n                      "extension_attributes": {\n                        "file_info": {\n                          "base64_encoded_data": "",\n                          "name": "",\n                          "type": ""\n                        }\n                      },\n                      "option_id": "",\n                      "option_value": ""\n                    }\n                  ],\n                  "downloadable_option": {\n                    "downloadable_links": []\n                  },\n                  "giftcard_item_option": {\n                    "custom_giftcard_amount": "",\n                    "extension_attributes": {},\n                    "giftcard_amount": "",\n                    "giftcard_message": "",\n                    "giftcard_recipient_email": "",\n                    "giftcard_recipient_name": "",\n                    "giftcard_sender_email": "",\n                    "giftcard_sender_name": ""\n                  }\n                }\n              },\n              "product_type": "",\n              "qty": "",\n              "quote_id": "",\n              "sku": ""\n            }\n          ],\n          "shipping": {\n            "address": {},\n            "extension_attributes": {},\n            "method": ""\n          }\n        }\n      ]\n    },\n    "id": 0,\n    "is_active": false,\n    "is_virtual": false,\n    "items": [\n      {}\n    ],\n    "items_count": 0,\n    "items_qty": "",\n    "orig_order_id": 0,\n    "reserved_order_id": "",\n    "store_id": 0,\n    "updated_at": ""\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  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiableQuote/:quoteId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiableQuote/:quoteId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  quote: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    converted_at: '',
    created_at: '',
    currency: {
      base_currency_code: '',
      base_to_global_rate: '',
      base_to_quote_rate: '',
      extension_attributes: {},
      global_currency_code: '',
      quote_currency_code: '',
      store_currency_code: '',
      store_to_base_rate: '',
      store_to_quote_rate: ''
    },
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [{}],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [{}],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_id: 0
    },
    customer_is_guest: false,
    customer_note: '',
    customer_note_notify: false,
    customer_tax_class_id: 0,
    extension_attributes: {
      amazon_order_reference_id: '',
      negotiable_quote: {
        applied_rule_ids: '',
        base_negotiated_total_price: '',
        base_original_total_price: '',
        creator_id: 0,
        creator_type: 0,
        deleted_sku: '',
        email_notification_status: 0,
        expiration_period: '',
        extension_attributes: {},
        has_unconfirmed_changes: false,
        is_address_draft: false,
        is_customer_price_changed: false,
        is_regular_quote: false,
        is_shipping_tax_changed: false,
        negotiated_price_type: 0,
        negotiated_price_value: '',
        negotiated_total_price: '',
        notifications: 0,
        original_total_price: '',
        quote_id: 0,
        quote_name: '',
        shipping_price: '',
        status: ''
      },
      shipping_assignments: [
        {
          extension_attributes: {},
          items: [
            {
              extension_attributes: {
                negotiable_quote_item: {
                  extension_attributes: {},
                  item_id: 0,
                  original_discount_amount: '',
                  original_price: '',
                  original_tax_amount: ''
                }
              },
              item_id: 0,
              name: '',
              price: '',
              product_option: {
                extension_attributes: {
                  bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                  configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                  custom_options: [
                    {
                      extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                      option_id: '',
                      option_value: ''
                    }
                  ],
                  downloadable_option: {downloadable_links: []},
                  giftcard_item_option: {
                    custom_giftcard_amount: '',
                    extension_attributes: {},
                    giftcard_amount: '',
                    giftcard_message: '',
                    giftcard_recipient_email: '',
                    giftcard_recipient_name: '',
                    giftcard_sender_email: '',
                    giftcard_sender_name: ''
                  }
                }
              },
              product_type: '',
              qty: '',
              quote_id: '',
              sku: ''
            }
          ],
          shipping: {address: {}, extension_attributes: {}, method: ''}
        }
      ]
    },
    id: 0,
    is_active: false,
    is_virtual: false,
    items: [{}],
    items_count: 0,
    items_qty: '',
    orig_order_id: 0,
    reserved_order_id: '',
    store_id: 0,
    updated_at: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/negotiableQuote/:quoteId',
  headers: {'content-type': 'application/json'},
  body: {
    quote: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      converted_at: '',
      created_at: '',
      currency: {
        base_currency_code: '',
        base_to_global_rate: '',
        base_to_quote_rate: '',
        extension_attributes: {},
        global_currency_code: '',
        quote_currency_code: '',
        store_currency_code: '',
        store_to_base_rate: '',
        store_to_quote_rate: ''
      },
      customer: {
        addresses: [
          {
            city: '',
            company: '',
            country_id: '',
            custom_attributes: [{}],
            customer_id: 0,
            default_billing: false,
            default_shipping: false,
            extension_attributes: {},
            fax: '',
            firstname: '',
            id: 0,
            lastname: '',
            middlename: '',
            postcode: '',
            prefix: '',
            region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
            region_id: 0,
            street: [],
            suffix: '',
            telephone: '',
            vat_id: ''
          }
        ],
        confirmation: '',
        created_at: '',
        created_in: '',
        custom_attributes: [{}],
        default_billing: '',
        default_shipping: '',
        disable_auto_group_change: 0,
        dob: '',
        email: '',
        extension_attributes: {
          amazon_id: '',
          company_attributes: {
            company_id: 0,
            customer_id: 0,
            extension_attributes: {},
            job_title: '',
            status: 0,
            telephone: ''
          },
          is_subscribed: false,
          vertex_customer_code: ''
        },
        firstname: '',
        gender: 0,
        group_id: 0,
        id: 0,
        lastname: '',
        middlename: '',
        prefix: '',
        store_id: 0,
        suffix: '',
        taxvat: '',
        updated_at: '',
        website_id: 0
      },
      customer_is_guest: false,
      customer_note: '',
      customer_note_notify: false,
      customer_tax_class_id: 0,
      extension_attributes: {
        amazon_order_reference_id: '',
        negotiable_quote: {
          applied_rule_ids: '',
          base_negotiated_total_price: '',
          base_original_total_price: '',
          creator_id: 0,
          creator_type: 0,
          deleted_sku: '',
          email_notification_status: 0,
          expiration_period: '',
          extension_attributes: {},
          has_unconfirmed_changes: false,
          is_address_draft: false,
          is_customer_price_changed: false,
          is_regular_quote: false,
          is_shipping_tax_changed: false,
          negotiated_price_type: 0,
          negotiated_price_value: '',
          negotiated_total_price: '',
          notifications: 0,
          original_total_price: '',
          quote_id: 0,
          quote_name: '',
          shipping_price: '',
          status: ''
        },
        shipping_assignments: [
          {
            extension_attributes: {},
            items: [
              {
                extension_attributes: {
                  negotiable_quote_item: {
                    extension_attributes: {},
                    item_id: 0,
                    original_discount_amount: '',
                    original_price: '',
                    original_tax_amount: ''
                  }
                },
                item_id: 0,
                name: '',
                price: '',
                product_option: {
                  extension_attributes: {
                    bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                    configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                    custom_options: [
                      {
                        extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                        option_id: '',
                        option_value: ''
                      }
                    ],
                    downloadable_option: {downloadable_links: []},
                    giftcard_item_option: {
                      custom_giftcard_amount: '',
                      extension_attributes: {},
                      giftcard_amount: '',
                      giftcard_message: '',
                      giftcard_recipient_email: '',
                      giftcard_recipient_name: '',
                      giftcard_sender_email: '',
                      giftcard_sender_name: ''
                    }
                  }
                },
                product_type: '',
                qty: '',
                quote_id: '',
                sku: ''
              }
            ],
            shipping: {address: {}, extension_attributes: {}, method: ''}
          }
        ]
      },
      id: 0,
      is_active: false,
      is_virtual: false,
      items: [{}],
      items_count: 0,
      items_qty: '',
      orig_order_id: 0,
      reserved_order_id: '',
      store_id: 0,
      updated_at: ''
    }
  },
  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}}/V1/negotiableQuote/:quoteId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  quote: {
    billing_address: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {
        checkout_fields: [
          {}
        ],
        gift_registry_id: 0
      },
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    converted_at: '',
    created_at: '',
    currency: {
      base_currency_code: '',
      base_to_global_rate: '',
      base_to_quote_rate: '',
      extension_attributes: {},
      global_currency_code: '',
      quote_currency_code: '',
      store_currency_code: '',
      store_to_base_rate: '',
      store_to_quote_rate: ''
    },
    customer: {
      addresses: [
        {
          city: '',
          company: '',
          country_id: '',
          custom_attributes: [
            {}
          ],
          customer_id: 0,
          default_billing: false,
          default_shipping: false,
          extension_attributes: {},
          fax: '',
          firstname: '',
          id: 0,
          lastname: '',
          middlename: '',
          postcode: '',
          prefix: '',
          region: {
            extension_attributes: {},
            region: '',
            region_code: '',
            region_id: 0
          },
          region_id: 0,
          street: [],
          suffix: '',
          telephone: '',
          vat_id: ''
        }
      ],
      confirmation: '',
      created_at: '',
      created_in: '',
      custom_attributes: [
        {}
      ],
      default_billing: '',
      default_shipping: '',
      disable_auto_group_change: 0,
      dob: '',
      email: '',
      extension_attributes: {
        amazon_id: '',
        company_attributes: {
          company_id: 0,
          customer_id: 0,
          extension_attributes: {},
          job_title: '',
          status: 0,
          telephone: ''
        },
        is_subscribed: false,
        vertex_customer_code: ''
      },
      firstname: '',
      gender: 0,
      group_id: 0,
      id: 0,
      lastname: '',
      middlename: '',
      prefix: '',
      store_id: 0,
      suffix: '',
      taxvat: '',
      updated_at: '',
      website_id: 0
    },
    customer_is_guest: false,
    customer_note: '',
    customer_note_notify: false,
    customer_tax_class_id: 0,
    extension_attributes: {
      amazon_order_reference_id: '',
      negotiable_quote: {
        applied_rule_ids: '',
        base_negotiated_total_price: '',
        base_original_total_price: '',
        creator_id: 0,
        creator_type: 0,
        deleted_sku: '',
        email_notification_status: 0,
        expiration_period: '',
        extension_attributes: {},
        has_unconfirmed_changes: false,
        is_address_draft: false,
        is_customer_price_changed: false,
        is_regular_quote: false,
        is_shipping_tax_changed: false,
        negotiated_price_type: 0,
        negotiated_price_value: '',
        negotiated_total_price: '',
        notifications: 0,
        original_total_price: '',
        quote_id: 0,
        quote_name: '',
        shipping_price: '',
        status: ''
      },
      shipping_assignments: [
        {
          extension_attributes: {},
          items: [
            {
              extension_attributes: {
                negotiable_quote_item: {
                  extension_attributes: {},
                  item_id: 0,
                  original_discount_amount: '',
                  original_price: '',
                  original_tax_amount: ''
                }
              },
              item_id: 0,
              name: '',
              price: '',
              product_option: {
                extension_attributes: {
                  bundle_options: [
                    {
                      extension_attributes: {},
                      option_id: 0,
                      option_qty: 0,
                      option_selections: []
                    }
                  ],
                  configurable_item_options: [
                    {
                      extension_attributes: {},
                      option_id: '',
                      option_value: 0
                    }
                  ],
                  custom_options: [
                    {
                      extension_attributes: {
                        file_info: {
                          base64_encoded_data: '',
                          name: '',
                          type: ''
                        }
                      },
                      option_id: '',
                      option_value: ''
                    }
                  ],
                  downloadable_option: {
                    downloadable_links: []
                  },
                  giftcard_item_option: {
                    custom_giftcard_amount: '',
                    extension_attributes: {},
                    giftcard_amount: '',
                    giftcard_message: '',
                    giftcard_recipient_email: '',
                    giftcard_recipient_name: '',
                    giftcard_sender_email: '',
                    giftcard_sender_name: ''
                  }
                }
              },
              product_type: '',
              qty: '',
              quote_id: '',
              sku: ''
            }
          ],
          shipping: {
            address: {},
            extension_attributes: {},
            method: ''
          }
        }
      ]
    },
    id: 0,
    is_active: false,
    is_virtual: false,
    items: [
      {}
    ],
    items_count: 0,
    items_qty: '',
    orig_order_id: 0,
    reserved_order_id: '',
    store_id: 0,
    updated_at: ''
  }
});

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}}/V1/negotiableQuote/:quoteId',
  headers: {'content-type': 'application/json'},
  data: {
    quote: {
      billing_address: {
        city: '',
        company: '',
        country_id: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
        fax: '',
        firstname: '',
        id: 0,
        lastname: '',
        middlename: '',
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        same_as_billing: 0,
        save_in_address_book: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: ''
      },
      converted_at: '',
      created_at: '',
      currency: {
        base_currency_code: '',
        base_to_global_rate: '',
        base_to_quote_rate: '',
        extension_attributes: {},
        global_currency_code: '',
        quote_currency_code: '',
        store_currency_code: '',
        store_to_base_rate: '',
        store_to_quote_rate: ''
      },
      customer: {
        addresses: [
          {
            city: '',
            company: '',
            country_id: '',
            custom_attributes: [{}],
            customer_id: 0,
            default_billing: false,
            default_shipping: false,
            extension_attributes: {},
            fax: '',
            firstname: '',
            id: 0,
            lastname: '',
            middlename: '',
            postcode: '',
            prefix: '',
            region: {extension_attributes: {}, region: '', region_code: '', region_id: 0},
            region_id: 0,
            street: [],
            suffix: '',
            telephone: '',
            vat_id: ''
          }
        ],
        confirmation: '',
        created_at: '',
        created_in: '',
        custom_attributes: [{}],
        default_billing: '',
        default_shipping: '',
        disable_auto_group_change: 0,
        dob: '',
        email: '',
        extension_attributes: {
          amazon_id: '',
          company_attributes: {
            company_id: 0,
            customer_id: 0,
            extension_attributes: {},
            job_title: '',
            status: 0,
            telephone: ''
          },
          is_subscribed: false,
          vertex_customer_code: ''
        },
        firstname: '',
        gender: 0,
        group_id: 0,
        id: 0,
        lastname: '',
        middlename: '',
        prefix: '',
        store_id: 0,
        suffix: '',
        taxvat: '',
        updated_at: '',
        website_id: 0
      },
      customer_is_guest: false,
      customer_note: '',
      customer_note_notify: false,
      customer_tax_class_id: 0,
      extension_attributes: {
        amazon_order_reference_id: '',
        negotiable_quote: {
          applied_rule_ids: '',
          base_negotiated_total_price: '',
          base_original_total_price: '',
          creator_id: 0,
          creator_type: 0,
          deleted_sku: '',
          email_notification_status: 0,
          expiration_period: '',
          extension_attributes: {},
          has_unconfirmed_changes: false,
          is_address_draft: false,
          is_customer_price_changed: false,
          is_regular_quote: false,
          is_shipping_tax_changed: false,
          negotiated_price_type: 0,
          negotiated_price_value: '',
          negotiated_total_price: '',
          notifications: 0,
          original_total_price: '',
          quote_id: 0,
          quote_name: '',
          shipping_price: '',
          status: ''
        },
        shipping_assignments: [
          {
            extension_attributes: {},
            items: [
              {
                extension_attributes: {
                  negotiable_quote_item: {
                    extension_attributes: {},
                    item_id: 0,
                    original_discount_amount: '',
                    original_price: '',
                    original_tax_amount: ''
                  }
                },
                item_id: 0,
                name: '',
                price: '',
                product_option: {
                  extension_attributes: {
                    bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                    configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                    custom_options: [
                      {
                        extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                        option_id: '',
                        option_value: ''
                      }
                    ],
                    downloadable_option: {downloadable_links: []},
                    giftcard_item_option: {
                      custom_giftcard_amount: '',
                      extension_attributes: {},
                      giftcard_amount: '',
                      giftcard_message: '',
                      giftcard_recipient_email: '',
                      giftcard_recipient_name: '',
                      giftcard_sender_email: '',
                      giftcard_sender_name: ''
                    }
                  }
                },
                product_type: '',
                qty: '',
                quote_id: '',
                sku: ''
              }
            ],
            shipping: {address: {}, extension_attributes: {}, method: ''}
          }
        ]
      },
      id: 0,
      is_active: false,
      is_virtual: false,
      items: [{}],
      items_count: 0,
      items_qty: '',
      orig_order_id: 0,
      reserved_order_id: '',
      store_id: 0,
      updated_at: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiableQuote/:quoteId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"quote":{"billing_address":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"converted_at":"","created_at":"","currency":{"base_currency_code":"","base_to_global_rate":"","base_to_quote_rate":"","extension_attributes":{},"global_currency_code":"","quote_currency_code":"","store_currency_code":"","store_to_base_rate":"","store_to_quote_rate":""},"customer":{"addresses":[{"city":"","company":"","country_id":"","custom_attributes":[{}],"customer_id":0,"default_billing":false,"default_shipping":false,"extension_attributes":{},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":{"extension_attributes":{},"region":"","region_code":"","region_id":0},"region_id":0,"street":[],"suffix":"","telephone":"","vat_id":""}],"confirmation":"","created_at":"","created_in":"","custom_attributes":[{}],"default_billing":"","default_shipping":"","disable_auto_group_change":0,"dob":"","email":"","extension_attributes":{"amazon_id":"","company_attributes":{"company_id":0,"customer_id":0,"extension_attributes":{},"job_title":"","status":0,"telephone":""},"is_subscribed":false,"vertex_customer_code":""},"firstname":"","gender":0,"group_id":0,"id":0,"lastname":"","middlename":"","prefix":"","store_id":0,"suffix":"","taxvat":"","updated_at":"","website_id":0},"customer_is_guest":false,"customer_note":"","customer_note_notify":false,"customer_tax_class_id":0,"extension_attributes":{"amazon_order_reference_id":"","negotiable_quote":{"applied_rule_ids":"","base_negotiated_total_price":"","base_original_total_price":"","creator_id":0,"creator_type":0,"deleted_sku":"","email_notification_status":0,"expiration_period":"","extension_attributes":{},"has_unconfirmed_changes":false,"is_address_draft":false,"is_customer_price_changed":false,"is_regular_quote":false,"is_shipping_tax_changed":false,"negotiated_price_type":0,"negotiated_price_value":"","negotiated_total_price":"","notifications":0,"original_total_price":"","quote_id":0,"quote_name":"","shipping_price":"","status":""},"shipping_assignments":[{"extension_attributes":{},"items":[{"extension_attributes":{"negotiable_quote_item":{"extension_attributes":{},"item_id":0,"original_discount_amount":"","original_price":"","original_tax_amount":""}},"item_id":0,"name":"","price":"","product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty":"","quote_id":"","sku":""}],"shipping":{"address":{},"extension_attributes":{},"method":""}}]},"id":0,"is_active":false,"is_virtual":false,"items":[{}],"items_count":0,"items_qty":"","orig_order_id":0,"reserved_order_id":"","store_id":0,"updated_at":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"quote": @{ @"billing_address": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" }, @"converted_at": @"", @"created_at": @"", @"currency": @{ @"base_currency_code": @"", @"base_to_global_rate": @"", @"base_to_quote_rate": @"", @"extension_attributes": @{  }, @"global_currency_code": @"", @"quote_currency_code": @"", @"store_currency_code": @"", @"store_to_base_rate": @"", @"store_to_quote_rate": @"" }, @"customer": @{ @"addresses": @[ @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{  } ], @"customer_id": @0, @"default_billing": @NO, @"default_shipping": @NO, @"extension_attributes": @{  }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @{ @"extension_attributes": @{  }, @"region": @"", @"region_code": @"", @"region_id": @0 }, @"region_id": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" } ], @"confirmation": @"", @"created_at": @"", @"created_in": @"", @"custom_attributes": @[ @{  } ], @"default_billing": @"", @"default_shipping": @"", @"disable_auto_group_change": @0, @"dob": @"", @"email": @"", @"extension_attributes": @{ @"amazon_id": @"", @"company_attributes": @{ @"company_id": @0, @"customer_id": @0, @"extension_attributes": @{  }, @"job_title": @"", @"status": @0, @"telephone": @"" }, @"is_subscribed": @NO, @"vertex_customer_code": @"" }, @"firstname": @"", @"gender": @0, @"group_id": @0, @"id": @0, @"lastname": @"", @"middlename": @"", @"prefix": @"", @"store_id": @0, @"suffix": @"", @"taxvat": @"", @"updated_at": @"", @"website_id": @0 }, @"customer_is_guest": @NO, @"customer_note": @"", @"customer_note_notify": @NO, @"customer_tax_class_id": @0, @"extension_attributes": @{ @"amazon_order_reference_id": @"", @"negotiable_quote": @{ @"applied_rule_ids": @"", @"base_negotiated_total_price": @"", @"base_original_total_price": @"", @"creator_id": @0, @"creator_type": @0, @"deleted_sku": @"", @"email_notification_status": @0, @"expiration_period": @"", @"extension_attributes": @{  }, @"has_unconfirmed_changes": @NO, @"is_address_draft": @NO, @"is_customer_price_changed": @NO, @"is_regular_quote": @NO, @"is_shipping_tax_changed": @NO, @"negotiated_price_type": @0, @"negotiated_price_value": @"", @"negotiated_total_price": @"", @"notifications": @0, @"original_total_price": @"", @"quote_id": @0, @"quote_name": @"", @"shipping_price": @"", @"status": @"" }, @"shipping_assignments": @[ @{ @"extension_attributes": @{  }, @"items": @[ @{ @"extension_attributes": @{ @"negotiable_quote_item": @{ @"extension_attributes": @{  }, @"item_id": @0, @"original_discount_amount": @"", @"original_price": @"", @"original_tax_amount": @"" } }, @"item_id": @0, @"name": @"", @"price": @"", @"product_option": @{ @"extension_attributes": @{ @"bundle_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @0, @"option_qty": @0, @"option_selections": @[  ] } ], @"configurable_item_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @"", @"option_value": @0 } ], @"custom_options": @[ @{ @"extension_attributes": @{ @"file_info": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" } }, @"option_id": @"", @"option_value": @"" } ], @"downloadable_option": @{ @"downloadable_links": @[  ] }, @"giftcard_item_option": @{ @"custom_giftcard_amount": @"", @"extension_attributes": @{  }, @"giftcard_amount": @"", @"giftcard_message": @"", @"giftcard_recipient_email": @"", @"giftcard_recipient_name": @"", @"giftcard_sender_email": @"", @"giftcard_sender_name": @"" } } }, @"product_type": @"", @"qty": @"", @"quote_id": @"", @"sku": @"" } ], @"shipping": @{ @"address": @{  }, @"extension_attributes": @{  }, @"method": @"" } } ] }, @"id": @0, @"is_active": @NO, @"is_virtual": @NO, @"items": @[ @{  } ], @"items_count": @0, @"items_qty": @"", @"orig_order_id": @0, @"reserved_order_id": @"", @"store_id": @0, @"updated_at": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiableQuote/:quoteId"]
                                                       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}}/V1/negotiableQuote/:quoteId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiableQuote/:quoteId",
  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([
    'quote' => [
        'billing_address' => [
                'city' => '',
                'company' => '',
                'country_id' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_address_id' => 0,
                'customer_id' => 0,
                'email' => '',
                'extension_attributes' => [
                                'checkout_fields' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'gift_registry_id' => 0
                ],
                'fax' => '',
                'firstname' => '',
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'postcode' => '',
                'prefix' => '',
                'region' => '',
                'region_code' => '',
                'region_id' => 0,
                'same_as_billing' => 0,
                'save_in_address_book' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => ''
        ],
        'converted_at' => '',
        'created_at' => '',
        'currency' => [
                'base_currency_code' => '',
                'base_to_global_rate' => '',
                'base_to_quote_rate' => '',
                'extension_attributes' => [
                                
                ],
                'global_currency_code' => '',
                'quote_currency_code' => '',
                'store_currency_code' => '',
                'store_to_base_rate' => '',
                'store_to_quote_rate' => ''
        ],
        'customer' => [
                'addresses' => [
                                [
                                                                'city' => '',
                                                                'company' => '',
                                                                'country_id' => '',
                                                                'custom_attributes' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'customer_id' => 0,
                                                                'default_billing' => null,
                                                                'default_shipping' => null,
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'fax' => '',
                                                                'firstname' => '',
                                                                'id' => 0,
                                                                'lastname' => '',
                                                                'middlename' => '',
                                                                'postcode' => '',
                                                                'prefix' => '',
                                                                'region' => [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'region' => '',
                                                                                                                                'region_code' => '',
                                                                                                                                'region_id' => 0
                                                                ],
                                                                'region_id' => 0,
                                                                'street' => [
                                                                                                                                
                                                                ],
                                                                'suffix' => '',
                                                                'telephone' => '',
                                                                'vat_id' => ''
                                ]
                ],
                'confirmation' => '',
                'created_at' => '',
                'created_in' => '',
                'custom_attributes' => [
                                [
                                                                
                                ]
                ],
                'default_billing' => '',
                'default_shipping' => '',
                'disable_auto_group_change' => 0,
                'dob' => '',
                'email' => '',
                'extension_attributes' => [
                                'amazon_id' => '',
                                'company_attributes' => [
                                                                'company_id' => 0,
                                                                'customer_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'job_title' => '',
                                                                'status' => 0,
                                                                'telephone' => ''
                                ],
                                'is_subscribed' => null,
                                'vertex_customer_code' => ''
                ],
                'firstname' => '',
                'gender' => 0,
                'group_id' => 0,
                'id' => 0,
                'lastname' => '',
                'middlename' => '',
                'prefix' => '',
                'store_id' => 0,
                'suffix' => '',
                'taxvat' => '',
                'updated_at' => '',
                'website_id' => 0
        ],
        'customer_is_guest' => null,
        'customer_note' => '',
        'customer_note_notify' => null,
        'customer_tax_class_id' => 0,
        'extension_attributes' => [
                'amazon_order_reference_id' => '',
                'negotiable_quote' => [
                                'applied_rule_ids' => '',
                                'base_negotiated_total_price' => '',
                                'base_original_total_price' => '',
                                'creator_id' => 0,
                                'creator_type' => 0,
                                'deleted_sku' => '',
                                'email_notification_status' => 0,
                                'expiration_period' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'has_unconfirmed_changes' => null,
                                'is_address_draft' => null,
                                'is_customer_price_changed' => null,
                                'is_regular_quote' => null,
                                'is_shipping_tax_changed' => null,
                                'negotiated_price_type' => 0,
                                'negotiated_price_value' => '',
                                'negotiated_total_price' => '',
                                'notifications' => 0,
                                'original_total_price' => '',
                                'quote_id' => 0,
                                'quote_name' => '',
                                'shipping_price' => '',
                                'status' => ''
                ],
                'shipping_assignments' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'items' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'negotiable_quote_item' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'item_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_tax_amount' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'item_id' => 0,
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                'product_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'bundle_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_qty' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'configurable_item_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_links' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_item_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_message' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_name' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'product_type' => '',
                                                                                                                                                                                                                                                                'qty' => '',
                                                                                                                                                                                                                                                                'quote_id' => '',
                                                                                                                                                                                                                                                                'sku' => ''
                                                                                                                                ]
                                                                ],
                                                                'shipping' => [
                                                                                                                                'address' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'method' => ''
                                                                ]
                                ]
                ]
        ],
        'id' => 0,
        'is_active' => null,
        'is_virtual' => null,
        'items' => [
                [
                                
                ]
        ],
        'items_count' => 0,
        'items_qty' => '',
        'orig_order_id' => 0,
        'reserved_order_id' => '',
        'store_id' => 0,
        'updated_at' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/negotiableQuote/:quoteId', [
  'body' => '{
  "quote": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "converted_at": "",
    "created_at": "",
    "currency": {
      "base_currency_code": "",
      "base_to_global_rate": "",
      "base_to_quote_rate": "",
      "extension_attributes": {},
      "global_currency_code": "",
      "quote_currency_code": "",
      "store_currency_code": "",
      "store_to_base_rate": "",
      "store_to_quote_rate": ""
    },
    "customer": {
      "addresses": [
        {
          "city": "",
          "company": "",
          "country_id": "",
          "custom_attributes": [
            {}
          ],
          "customer_id": 0,
          "default_billing": false,
          "default_shipping": false,
          "extension_attributes": {},
          "fax": "",
          "firstname": "",
          "id": 0,
          "lastname": "",
          "middlename": "",
          "postcode": "",
          "prefix": "",
          "region": {
            "extension_attributes": {},
            "region": "",
            "region_code": "",
            "region_id": 0
          },
          "region_id": 0,
          "street": [],
          "suffix": "",
          "telephone": "",
          "vat_id": ""
        }
      ],
      "confirmation": "",
      "created_at": "",
      "created_in": "",
      "custom_attributes": [
        {}
      ],
      "default_billing": "",
      "default_shipping": "",
      "disable_auto_group_change": 0,
      "dob": "",
      "email": "",
      "extension_attributes": {
        "amazon_id": "",
        "company_attributes": {
          "company_id": 0,
          "customer_id": 0,
          "extension_attributes": {},
          "job_title": "",
          "status": 0,
          "telephone": ""
        },
        "is_subscribed": false,
        "vertex_customer_code": ""
      },
      "firstname": "",
      "gender": 0,
      "group_id": 0,
      "id": 0,
      "lastname": "",
      "middlename": "",
      "prefix": "",
      "store_id": 0,
      "suffix": "",
      "taxvat": "",
      "updated_at": "",
      "website_id": 0
    },
    "customer_is_guest": false,
    "customer_note": "",
    "customer_note_notify": false,
    "customer_tax_class_id": 0,
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "negotiable_quote": {
        "applied_rule_ids": "",
        "base_negotiated_total_price": "",
        "base_original_total_price": "",
        "creator_id": 0,
        "creator_type": 0,
        "deleted_sku": "",
        "email_notification_status": 0,
        "expiration_period": "",
        "extension_attributes": {},
        "has_unconfirmed_changes": false,
        "is_address_draft": false,
        "is_customer_price_changed": false,
        "is_regular_quote": false,
        "is_shipping_tax_changed": false,
        "negotiated_price_type": 0,
        "negotiated_price_value": "",
        "negotiated_total_price": "",
        "notifications": 0,
        "original_total_price": "",
        "quote_id": 0,
        "quote_name": "",
        "shipping_price": "",
        "status": ""
      },
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "extension_attributes": {
                "negotiable_quote_item": {
                  "extension_attributes": {},
                  "item_id": 0,
                  "original_discount_amount": "",
                  "original_price": "",
                  "original_tax_amount": ""
                }
              },
              "item_id": 0,
              "name": "",
              "price": "",
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty": "",
              "quote_id": "",
              "sku": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {},
            "method": ""
          }
        }
      ]
    },
    "id": 0,
    "is_active": false,
    "is_virtual": false,
    "items": [
      {}
    ],
    "items_count": 0,
    "items_qty": "",
    "orig_order_id": 0,
    "reserved_order_id": "",
    "store_id": 0,
    "updated_at": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiableQuote/:quoteId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'quote' => [
    'billing_address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'converted_at' => '',
    'created_at' => '',
    'currency' => [
        'base_currency_code' => '',
        'base_to_global_rate' => '',
        'base_to_quote_rate' => '',
        'extension_attributes' => [
                
        ],
        'global_currency_code' => '',
        'quote_currency_code' => '',
        'store_currency_code' => '',
        'store_to_base_rate' => '',
        'store_to_quote_rate' => ''
    ],
    'customer' => [
        'addresses' => [
                [
                                'city' => '',
                                'company' => '',
                                'country_id' => '',
                                'custom_attributes' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'customer_id' => 0,
                                'default_billing' => null,
                                'default_shipping' => null,
                                'extension_attributes' => [
                                                                
                                ],
                                'fax' => '',
                                'firstname' => '',
                                'id' => 0,
                                'lastname' => '',
                                'middlename' => '',
                                'postcode' => '',
                                'prefix' => '',
                                'region' => [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'region' => '',
                                                                'region_code' => '',
                                                                'region_id' => 0
                                ],
                                'region_id' => 0,
                                'street' => [
                                                                
                                ],
                                'suffix' => '',
                                'telephone' => '',
                                'vat_id' => ''
                ]
        ],
        'confirmation' => '',
        'created_at' => '',
        'created_in' => '',
        'custom_attributes' => [
                [
                                
                ]
        ],
        'default_billing' => '',
        'default_shipping' => '',
        'disable_auto_group_change' => 0,
        'dob' => '',
        'email' => '',
        'extension_attributes' => [
                'amazon_id' => '',
                'company_attributes' => [
                                'company_id' => 0,
                                'customer_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'job_title' => '',
                                'status' => 0,
                                'telephone' => ''
                ],
                'is_subscribed' => null,
                'vertex_customer_code' => ''
        ],
        'firstname' => '',
        'gender' => 0,
        'group_id' => 0,
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'prefix' => '',
        'store_id' => 0,
        'suffix' => '',
        'taxvat' => '',
        'updated_at' => '',
        'website_id' => 0
    ],
    'customer_is_guest' => null,
    'customer_note' => '',
    'customer_note_notify' => null,
    'customer_tax_class_id' => 0,
    'extension_attributes' => [
        'amazon_order_reference_id' => '',
        'negotiable_quote' => [
                'applied_rule_ids' => '',
                'base_negotiated_total_price' => '',
                'base_original_total_price' => '',
                'creator_id' => 0,
                'creator_type' => 0,
                'deleted_sku' => '',
                'email_notification_status' => 0,
                'expiration_period' => '',
                'extension_attributes' => [
                                
                ],
                'has_unconfirmed_changes' => null,
                'is_address_draft' => null,
                'is_customer_price_changed' => null,
                'is_regular_quote' => null,
                'is_shipping_tax_changed' => null,
                'negotiated_price_type' => 0,
                'negotiated_price_value' => '',
                'negotiated_total_price' => '',
                'notifications' => 0,
                'original_total_price' => '',
                'quote_id' => 0,
                'quote_name' => '',
                'shipping_price' => '',
                'status' => ''
        ],
        'shipping_assignments' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'items' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'negotiable_quote_item' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'item_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_tax_amount' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'item_id' => 0,
                                                                                                                                'name' => '',
                                                                                                                                'price' => '',
                                                                                                                                'product_option' => [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'bundle_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_qty' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'configurable_item_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_links' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_item_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_message' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_name' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'product_type' => '',
                                                                                                                                'qty' => '',
                                                                                                                                'quote_id' => '',
                                                                                                                                'sku' => ''
                                                                ]
                                ],
                                'shipping' => [
                                                                'address' => [
                                                                                                                                
                                                                ],
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'method' => ''
                                ]
                ]
        ]
    ],
    'id' => 0,
    'is_active' => null,
    'is_virtual' => null,
    'items' => [
        [
                
        ]
    ],
    'items_count' => 0,
    'items_qty' => '',
    'orig_order_id' => 0,
    'reserved_order_id' => '',
    'store_id' => 0,
    'updated_at' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'quote' => [
    'billing_address' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'converted_at' => '',
    'created_at' => '',
    'currency' => [
        'base_currency_code' => '',
        'base_to_global_rate' => '',
        'base_to_quote_rate' => '',
        'extension_attributes' => [
                
        ],
        'global_currency_code' => '',
        'quote_currency_code' => '',
        'store_currency_code' => '',
        'store_to_base_rate' => '',
        'store_to_quote_rate' => ''
    ],
    'customer' => [
        'addresses' => [
                [
                                'city' => '',
                                'company' => '',
                                'country_id' => '',
                                'custom_attributes' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'customer_id' => 0,
                                'default_billing' => null,
                                'default_shipping' => null,
                                'extension_attributes' => [
                                                                
                                ],
                                'fax' => '',
                                'firstname' => '',
                                'id' => 0,
                                'lastname' => '',
                                'middlename' => '',
                                'postcode' => '',
                                'prefix' => '',
                                'region' => [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'region' => '',
                                                                'region_code' => '',
                                                                'region_id' => 0
                                ],
                                'region_id' => 0,
                                'street' => [
                                                                
                                ],
                                'suffix' => '',
                                'telephone' => '',
                                'vat_id' => ''
                ]
        ],
        'confirmation' => '',
        'created_at' => '',
        'created_in' => '',
        'custom_attributes' => [
                [
                                
                ]
        ],
        'default_billing' => '',
        'default_shipping' => '',
        'disable_auto_group_change' => 0,
        'dob' => '',
        'email' => '',
        'extension_attributes' => [
                'amazon_id' => '',
                'company_attributes' => [
                                'company_id' => 0,
                                'customer_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'job_title' => '',
                                'status' => 0,
                                'telephone' => ''
                ],
                'is_subscribed' => null,
                'vertex_customer_code' => ''
        ],
        'firstname' => '',
        'gender' => 0,
        'group_id' => 0,
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'prefix' => '',
        'store_id' => 0,
        'suffix' => '',
        'taxvat' => '',
        'updated_at' => '',
        'website_id' => 0
    ],
    'customer_is_guest' => null,
    'customer_note' => '',
    'customer_note_notify' => null,
    'customer_tax_class_id' => 0,
    'extension_attributes' => [
        'amazon_order_reference_id' => '',
        'negotiable_quote' => [
                'applied_rule_ids' => '',
                'base_negotiated_total_price' => '',
                'base_original_total_price' => '',
                'creator_id' => 0,
                'creator_type' => 0,
                'deleted_sku' => '',
                'email_notification_status' => 0,
                'expiration_period' => '',
                'extension_attributes' => [
                                
                ],
                'has_unconfirmed_changes' => null,
                'is_address_draft' => null,
                'is_customer_price_changed' => null,
                'is_regular_quote' => null,
                'is_shipping_tax_changed' => null,
                'negotiated_price_type' => 0,
                'negotiated_price_value' => '',
                'negotiated_total_price' => '',
                'notifications' => 0,
                'original_total_price' => '',
                'quote_id' => 0,
                'quote_name' => '',
                'shipping_price' => '',
                'status' => ''
        ],
        'shipping_assignments' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'items' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'negotiable_quote_item' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'item_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_discount_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'original_tax_amount' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'item_id' => 0,
                                                                                                                                'name' => '',
                                                                                                                                'price' => '',
                                                                                                                                'product_option' => [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'bundle_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_qty' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'configurable_item_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_links' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_item_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_message' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_name' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'product_type' => '',
                                                                                                                                'qty' => '',
                                                                                                                                'quote_id' => '',
                                                                                                                                'sku' => ''
                                                                ]
                                ],
                                'shipping' => [
                                                                'address' => [
                                                                                                                                
                                                                ],
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'method' => ''
                                ]
                ]
        ]
    ],
    'id' => 0,
    'is_active' => null,
    'is_virtual' => null,
    'items' => [
        [
                
        ]
    ],
    'items_count' => 0,
    'items_qty' => '',
    'orig_order_id' => 0,
    'reserved_order_id' => '',
    'store_id' => 0,
    'updated_at' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/negotiableQuote/:quoteId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiableQuote/:quoteId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "quote": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "converted_at": "",
    "created_at": "",
    "currency": {
      "base_currency_code": "",
      "base_to_global_rate": "",
      "base_to_quote_rate": "",
      "extension_attributes": {},
      "global_currency_code": "",
      "quote_currency_code": "",
      "store_currency_code": "",
      "store_to_base_rate": "",
      "store_to_quote_rate": ""
    },
    "customer": {
      "addresses": [
        {
          "city": "",
          "company": "",
          "country_id": "",
          "custom_attributes": [
            {}
          ],
          "customer_id": 0,
          "default_billing": false,
          "default_shipping": false,
          "extension_attributes": {},
          "fax": "",
          "firstname": "",
          "id": 0,
          "lastname": "",
          "middlename": "",
          "postcode": "",
          "prefix": "",
          "region": {
            "extension_attributes": {},
            "region": "",
            "region_code": "",
            "region_id": 0
          },
          "region_id": 0,
          "street": [],
          "suffix": "",
          "telephone": "",
          "vat_id": ""
        }
      ],
      "confirmation": "",
      "created_at": "",
      "created_in": "",
      "custom_attributes": [
        {}
      ],
      "default_billing": "",
      "default_shipping": "",
      "disable_auto_group_change": 0,
      "dob": "",
      "email": "",
      "extension_attributes": {
        "amazon_id": "",
        "company_attributes": {
          "company_id": 0,
          "customer_id": 0,
          "extension_attributes": {},
          "job_title": "",
          "status": 0,
          "telephone": ""
        },
        "is_subscribed": false,
        "vertex_customer_code": ""
      },
      "firstname": "",
      "gender": 0,
      "group_id": 0,
      "id": 0,
      "lastname": "",
      "middlename": "",
      "prefix": "",
      "store_id": 0,
      "suffix": "",
      "taxvat": "",
      "updated_at": "",
      "website_id": 0
    },
    "customer_is_guest": false,
    "customer_note": "",
    "customer_note_notify": false,
    "customer_tax_class_id": 0,
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "negotiable_quote": {
        "applied_rule_ids": "",
        "base_negotiated_total_price": "",
        "base_original_total_price": "",
        "creator_id": 0,
        "creator_type": 0,
        "deleted_sku": "",
        "email_notification_status": 0,
        "expiration_period": "",
        "extension_attributes": {},
        "has_unconfirmed_changes": false,
        "is_address_draft": false,
        "is_customer_price_changed": false,
        "is_regular_quote": false,
        "is_shipping_tax_changed": false,
        "negotiated_price_type": 0,
        "negotiated_price_value": "",
        "negotiated_total_price": "",
        "notifications": 0,
        "original_total_price": "",
        "quote_id": 0,
        "quote_name": "",
        "shipping_price": "",
        "status": ""
      },
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "extension_attributes": {
                "negotiable_quote_item": {
                  "extension_attributes": {},
                  "item_id": 0,
                  "original_discount_amount": "",
                  "original_price": "",
                  "original_tax_amount": ""
                }
              },
              "item_id": 0,
              "name": "",
              "price": "",
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty": "",
              "quote_id": "",
              "sku": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {},
            "method": ""
          }
        }
      ]
    },
    "id": 0,
    "is_active": false,
    "is_virtual": false,
    "items": [
      {}
    ],
    "items_count": 0,
    "items_qty": "",
    "orig_order_id": 0,
    "reserved_order_id": "",
    "store_id": 0,
    "updated_at": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiableQuote/:quoteId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "quote": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "converted_at": "",
    "created_at": "",
    "currency": {
      "base_currency_code": "",
      "base_to_global_rate": "",
      "base_to_quote_rate": "",
      "extension_attributes": {},
      "global_currency_code": "",
      "quote_currency_code": "",
      "store_currency_code": "",
      "store_to_base_rate": "",
      "store_to_quote_rate": ""
    },
    "customer": {
      "addresses": [
        {
          "city": "",
          "company": "",
          "country_id": "",
          "custom_attributes": [
            {}
          ],
          "customer_id": 0,
          "default_billing": false,
          "default_shipping": false,
          "extension_attributes": {},
          "fax": "",
          "firstname": "",
          "id": 0,
          "lastname": "",
          "middlename": "",
          "postcode": "",
          "prefix": "",
          "region": {
            "extension_attributes": {},
            "region": "",
            "region_code": "",
            "region_id": 0
          },
          "region_id": 0,
          "street": [],
          "suffix": "",
          "telephone": "",
          "vat_id": ""
        }
      ],
      "confirmation": "",
      "created_at": "",
      "created_in": "",
      "custom_attributes": [
        {}
      ],
      "default_billing": "",
      "default_shipping": "",
      "disable_auto_group_change": 0,
      "dob": "",
      "email": "",
      "extension_attributes": {
        "amazon_id": "",
        "company_attributes": {
          "company_id": 0,
          "customer_id": 0,
          "extension_attributes": {},
          "job_title": "",
          "status": 0,
          "telephone": ""
        },
        "is_subscribed": false,
        "vertex_customer_code": ""
      },
      "firstname": "",
      "gender": 0,
      "group_id": 0,
      "id": 0,
      "lastname": "",
      "middlename": "",
      "prefix": "",
      "store_id": 0,
      "suffix": "",
      "taxvat": "",
      "updated_at": "",
      "website_id": 0
    },
    "customer_is_guest": false,
    "customer_note": "",
    "customer_note_notify": false,
    "customer_tax_class_id": 0,
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "negotiable_quote": {
        "applied_rule_ids": "",
        "base_negotiated_total_price": "",
        "base_original_total_price": "",
        "creator_id": 0,
        "creator_type": 0,
        "deleted_sku": "",
        "email_notification_status": 0,
        "expiration_period": "",
        "extension_attributes": {},
        "has_unconfirmed_changes": false,
        "is_address_draft": false,
        "is_customer_price_changed": false,
        "is_regular_quote": false,
        "is_shipping_tax_changed": false,
        "negotiated_price_type": 0,
        "negotiated_price_value": "",
        "negotiated_total_price": "",
        "notifications": 0,
        "original_total_price": "",
        "quote_id": 0,
        "quote_name": "",
        "shipping_price": "",
        "status": ""
      },
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "extension_attributes": {
                "negotiable_quote_item": {
                  "extension_attributes": {},
                  "item_id": 0,
                  "original_discount_amount": "",
                  "original_price": "",
                  "original_tax_amount": ""
                }
              },
              "item_id": 0,
              "name": "",
              "price": "",
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty": "",
              "quote_id": "",
              "sku": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {},
            "method": ""
          }
        }
      ]
    },
    "id": 0,
    "is_active": false,
    "is_virtual": false,
    "items": [
      {}
    ],
    "items_count": 0,
    "items_qty": "",
    "orig_order_id": 0,
    "reserved_order_id": "",
    "store_id": 0,
    "updated_at": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/negotiableQuote/:quoteId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiableQuote/:quoteId"

payload = { "quote": {
        "billing_address": {
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": [
                {
                    "attribute_code": "",
                    "value": ""
                }
            ],
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": {
                "checkout_fields": [{}],
                "gift_registry_id": 0
            },
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": [],
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        },
        "converted_at": "",
        "created_at": "",
        "currency": {
            "base_currency_code": "",
            "base_to_global_rate": "",
            "base_to_quote_rate": "",
            "extension_attributes": {},
            "global_currency_code": "",
            "quote_currency_code": "",
            "store_currency_code": "",
            "store_to_base_rate": "",
            "store_to_quote_rate": ""
        },
        "customer": {
            "addresses": [
                {
                    "city": "",
                    "company": "",
                    "country_id": "",
                    "custom_attributes": [{}],
                    "customer_id": 0,
                    "default_billing": False,
                    "default_shipping": False,
                    "extension_attributes": {},
                    "fax": "",
                    "firstname": "",
                    "id": 0,
                    "lastname": "",
                    "middlename": "",
                    "postcode": "",
                    "prefix": "",
                    "region": {
                        "extension_attributes": {},
                        "region": "",
                        "region_code": "",
                        "region_id": 0
                    },
                    "region_id": 0,
                    "street": [],
                    "suffix": "",
                    "telephone": "",
                    "vat_id": ""
                }
            ],
            "confirmation": "",
            "created_at": "",
            "created_in": "",
            "custom_attributes": [{}],
            "default_billing": "",
            "default_shipping": "",
            "disable_auto_group_change": 0,
            "dob": "",
            "email": "",
            "extension_attributes": {
                "amazon_id": "",
                "company_attributes": {
                    "company_id": 0,
                    "customer_id": 0,
                    "extension_attributes": {},
                    "job_title": "",
                    "status": 0,
                    "telephone": ""
                },
                "is_subscribed": False,
                "vertex_customer_code": ""
            },
            "firstname": "",
            "gender": 0,
            "group_id": 0,
            "id": 0,
            "lastname": "",
            "middlename": "",
            "prefix": "",
            "store_id": 0,
            "suffix": "",
            "taxvat": "",
            "updated_at": "",
            "website_id": 0
        },
        "customer_is_guest": False,
        "customer_note": "",
        "customer_note_notify": False,
        "customer_tax_class_id": 0,
        "extension_attributes": {
            "amazon_order_reference_id": "",
            "negotiable_quote": {
                "applied_rule_ids": "",
                "base_negotiated_total_price": "",
                "base_original_total_price": "",
                "creator_id": 0,
                "creator_type": 0,
                "deleted_sku": "",
                "email_notification_status": 0,
                "expiration_period": "",
                "extension_attributes": {},
                "has_unconfirmed_changes": False,
                "is_address_draft": False,
                "is_customer_price_changed": False,
                "is_regular_quote": False,
                "is_shipping_tax_changed": False,
                "negotiated_price_type": 0,
                "negotiated_price_value": "",
                "negotiated_total_price": "",
                "notifications": 0,
                "original_total_price": "",
                "quote_id": 0,
                "quote_name": "",
                "shipping_price": "",
                "status": ""
            },
            "shipping_assignments": [
                {
                    "extension_attributes": {},
                    "items": [
                        {
                            "extension_attributes": { "negotiable_quote_item": {
                                    "extension_attributes": {},
                                    "item_id": 0,
                                    "original_discount_amount": "",
                                    "original_price": "",
                                    "original_tax_amount": ""
                                } },
                            "item_id": 0,
                            "name": "",
                            "price": "",
                            "product_option": { "extension_attributes": {
                                    "bundle_options": [
                                        {
                                            "extension_attributes": {},
                                            "option_id": 0,
                                            "option_qty": 0,
                                            "option_selections": []
                                        }
                                    ],
                                    "configurable_item_options": [
                                        {
                                            "extension_attributes": {},
                                            "option_id": "",
                                            "option_value": 0
                                        }
                                    ],
                                    "custom_options": [
                                        {
                                            "extension_attributes": { "file_info": {
                                                    "base64_encoded_data": "",
                                                    "name": "",
                                                    "type": ""
                                                } },
                                            "option_id": "",
                                            "option_value": ""
                                        }
                                    ],
                                    "downloadable_option": { "downloadable_links": [] },
                                    "giftcard_item_option": {
                                        "custom_giftcard_amount": "",
                                        "extension_attributes": {},
                                        "giftcard_amount": "",
                                        "giftcard_message": "",
                                        "giftcard_recipient_email": "",
                                        "giftcard_recipient_name": "",
                                        "giftcard_sender_email": "",
                                        "giftcard_sender_name": ""
                                    }
                                } },
                            "product_type": "",
                            "qty": "",
                            "quote_id": "",
                            "sku": ""
                        }
                    ],
                    "shipping": {
                        "address": {},
                        "extension_attributes": {},
                        "method": ""
                    }
                }
            ]
        },
        "id": 0,
        "is_active": False,
        "is_virtual": False,
        "items": [{}],
        "items_count": 0,
        "items_qty": "",
        "orig_order_id": 0,
        "reserved_order_id": "",
        "store_id": 0,
        "updated_at": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiableQuote/:quoteId"

payload <- "{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiableQuote/:quoteId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\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/V1/negotiableQuote/:quoteId') do |req|
  req.body = "{\n  \"quote\": {\n    \"billing_address\": {\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {}\n        ],\n        \"gift_registry_id\": 0\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"same_as_billing\": 0,\n      \"save_in_address_book\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\"\n    },\n    \"converted_at\": \"\",\n    \"created_at\": \"\",\n    \"currency\": {\n      \"base_currency_code\": \"\",\n      \"base_to_global_rate\": \"\",\n      \"base_to_quote_rate\": \"\",\n      \"extension_attributes\": {},\n      \"global_currency_code\": \"\",\n      \"quote_currency_code\": \"\",\n      \"store_currency_code\": \"\",\n      \"store_to_base_rate\": \"\",\n      \"store_to_quote_rate\": \"\"\n    },\n    \"customer\": {\n      \"addresses\": [\n        {\n          \"city\": \"\",\n          \"company\": \"\",\n          \"country_id\": \"\",\n          \"custom_attributes\": [\n            {}\n          ],\n          \"customer_id\": 0,\n          \"default_billing\": false,\n          \"default_shipping\": false,\n          \"extension_attributes\": {},\n          \"fax\": \"\",\n          \"firstname\": \"\",\n          \"id\": 0,\n          \"lastname\": \"\",\n          \"middlename\": \"\",\n          \"postcode\": \"\",\n          \"prefix\": \"\",\n          \"region\": {\n            \"extension_attributes\": {},\n            \"region\": \"\",\n            \"region_code\": \"\",\n            \"region_id\": 0\n          },\n          \"region_id\": 0,\n          \"street\": [],\n          \"suffix\": \"\",\n          \"telephone\": \"\",\n          \"vat_id\": \"\"\n        }\n      ],\n      \"confirmation\": \"\",\n      \"created_at\": \"\",\n      \"created_in\": \"\",\n      \"custom_attributes\": [\n        {}\n      ],\n      \"default_billing\": \"\",\n      \"default_shipping\": \"\",\n      \"disable_auto_group_change\": 0,\n      \"dob\": \"\",\n      \"email\": \"\",\n      \"extension_attributes\": {\n        \"amazon_id\": \"\",\n        \"company_attributes\": {\n          \"company_id\": 0,\n          \"customer_id\": 0,\n          \"extension_attributes\": {},\n          \"job_title\": \"\",\n          \"status\": 0,\n          \"telephone\": \"\"\n        },\n        \"is_subscribed\": false,\n        \"vertex_customer_code\": \"\"\n      },\n      \"firstname\": \"\",\n      \"gender\": 0,\n      \"group_id\": 0,\n      \"id\": 0,\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"prefix\": \"\",\n      \"store_id\": 0,\n      \"suffix\": \"\",\n      \"taxvat\": \"\",\n      \"updated_at\": \"\",\n      \"website_id\": 0\n    },\n    \"customer_is_guest\": false,\n    \"customer_note\": \"\",\n    \"customer_note_notify\": false,\n    \"customer_tax_class_id\": 0,\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"negotiable_quote\": {\n        \"applied_rule_ids\": \"\",\n        \"base_negotiated_total_price\": \"\",\n        \"base_original_total_price\": \"\",\n        \"creator_id\": 0,\n        \"creator_type\": 0,\n        \"deleted_sku\": \"\",\n        \"email_notification_status\": 0,\n        \"expiration_period\": \"\",\n        \"extension_attributes\": {},\n        \"has_unconfirmed_changes\": false,\n        \"is_address_draft\": false,\n        \"is_customer_price_changed\": false,\n        \"is_regular_quote\": false,\n        \"is_shipping_tax_changed\": false,\n        \"negotiated_price_type\": 0,\n        \"negotiated_price_value\": \"\",\n        \"negotiated_total_price\": \"\",\n        \"notifications\": 0,\n        \"original_total_price\": \"\",\n        \"quote_id\": 0,\n        \"quote_name\": \"\",\n        \"shipping_price\": \"\",\n        \"status\": \"\"\n      },\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"extension_attributes\": {\n                \"negotiable_quote_item\": {\n                  \"extension_attributes\": {},\n                  \"item_id\": 0,\n                  \"original_discount_amount\": \"\",\n                  \"original_price\": \"\",\n                  \"original_tax_amount\": \"\"\n                }\n              },\n              \"item_id\": 0,\n              \"name\": \"\",\n              \"price\": \"\",\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty\": \"\",\n              \"quote_id\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {},\n            \"method\": \"\"\n          }\n        }\n      ]\n    },\n    \"id\": 0,\n    \"is_active\": false,\n    \"is_virtual\": false,\n    \"items\": [\n      {}\n    ],\n    \"items_count\": 0,\n    \"items_qty\": \"\",\n    \"orig_order_id\": 0,\n    \"reserved_order_id\": \"\",\n    \"store_id\": 0,\n    \"updated_at\": \"\"\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}}/V1/negotiableQuote/:quoteId";

    let payload = json!({"quote": json!({
            "billing_address": json!({
                "city": "",
                "company": "",
                "country_id": "",
                "custom_attributes": (
                    json!({
                        "attribute_code": "",
                        "value": ""
                    })
                ),
                "customer_address_id": 0,
                "customer_id": 0,
                "email": "",
                "extension_attributes": json!({
                    "checkout_fields": (json!({})),
                    "gift_registry_id": 0
                }),
                "fax": "",
                "firstname": "",
                "id": 0,
                "lastname": "",
                "middlename": "",
                "postcode": "",
                "prefix": "",
                "region": "",
                "region_code": "",
                "region_id": 0,
                "same_as_billing": 0,
                "save_in_address_book": 0,
                "street": (),
                "suffix": "",
                "telephone": "",
                "vat_id": ""
            }),
            "converted_at": "",
            "created_at": "",
            "currency": json!({
                "base_currency_code": "",
                "base_to_global_rate": "",
                "base_to_quote_rate": "",
                "extension_attributes": json!({}),
                "global_currency_code": "",
                "quote_currency_code": "",
                "store_currency_code": "",
                "store_to_base_rate": "",
                "store_to_quote_rate": ""
            }),
            "customer": json!({
                "addresses": (
                    json!({
                        "city": "",
                        "company": "",
                        "country_id": "",
                        "custom_attributes": (json!({})),
                        "customer_id": 0,
                        "default_billing": false,
                        "default_shipping": false,
                        "extension_attributes": json!({}),
                        "fax": "",
                        "firstname": "",
                        "id": 0,
                        "lastname": "",
                        "middlename": "",
                        "postcode": "",
                        "prefix": "",
                        "region": json!({
                            "extension_attributes": json!({}),
                            "region": "",
                            "region_code": "",
                            "region_id": 0
                        }),
                        "region_id": 0,
                        "street": (),
                        "suffix": "",
                        "telephone": "",
                        "vat_id": ""
                    })
                ),
                "confirmation": "",
                "created_at": "",
                "created_in": "",
                "custom_attributes": (json!({})),
                "default_billing": "",
                "default_shipping": "",
                "disable_auto_group_change": 0,
                "dob": "",
                "email": "",
                "extension_attributes": json!({
                    "amazon_id": "",
                    "company_attributes": json!({
                        "company_id": 0,
                        "customer_id": 0,
                        "extension_attributes": json!({}),
                        "job_title": "",
                        "status": 0,
                        "telephone": ""
                    }),
                    "is_subscribed": false,
                    "vertex_customer_code": ""
                }),
                "firstname": "",
                "gender": 0,
                "group_id": 0,
                "id": 0,
                "lastname": "",
                "middlename": "",
                "prefix": "",
                "store_id": 0,
                "suffix": "",
                "taxvat": "",
                "updated_at": "",
                "website_id": 0
            }),
            "customer_is_guest": false,
            "customer_note": "",
            "customer_note_notify": false,
            "customer_tax_class_id": 0,
            "extension_attributes": json!({
                "amazon_order_reference_id": "",
                "negotiable_quote": json!({
                    "applied_rule_ids": "",
                    "base_negotiated_total_price": "",
                    "base_original_total_price": "",
                    "creator_id": 0,
                    "creator_type": 0,
                    "deleted_sku": "",
                    "email_notification_status": 0,
                    "expiration_period": "",
                    "extension_attributes": json!({}),
                    "has_unconfirmed_changes": false,
                    "is_address_draft": false,
                    "is_customer_price_changed": false,
                    "is_regular_quote": false,
                    "is_shipping_tax_changed": false,
                    "negotiated_price_type": 0,
                    "negotiated_price_value": "",
                    "negotiated_total_price": "",
                    "notifications": 0,
                    "original_total_price": "",
                    "quote_id": 0,
                    "quote_name": "",
                    "shipping_price": "",
                    "status": ""
                }),
                "shipping_assignments": (
                    json!({
                        "extension_attributes": json!({}),
                        "items": (
                            json!({
                                "extension_attributes": json!({"negotiable_quote_item": json!({
                                        "extension_attributes": json!({}),
                                        "item_id": 0,
                                        "original_discount_amount": "",
                                        "original_price": "",
                                        "original_tax_amount": ""
                                    })}),
                                "item_id": 0,
                                "name": "",
                                "price": "",
                                "product_option": json!({"extension_attributes": json!({
                                        "bundle_options": (
                                            json!({
                                                "extension_attributes": json!({}),
                                                "option_id": 0,
                                                "option_qty": 0,
                                                "option_selections": ()
                                            })
                                        ),
                                        "configurable_item_options": (
                                            json!({
                                                "extension_attributes": json!({}),
                                                "option_id": "",
                                                "option_value": 0
                                            })
                                        ),
                                        "custom_options": (
                                            json!({
                                                "extension_attributes": json!({"file_info": json!({
                                                        "base64_encoded_data": "",
                                                        "name": "",
                                                        "type": ""
                                                    })}),
                                                "option_id": "",
                                                "option_value": ""
                                            })
                                        ),
                                        "downloadable_option": json!({"downloadable_links": ()}),
                                        "giftcard_item_option": json!({
                                            "custom_giftcard_amount": "",
                                            "extension_attributes": json!({}),
                                            "giftcard_amount": "",
                                            "giftcard_message": "",
                                            "giftcard_recipient_email": "",
                                            "giftcard_recipient_name": "",
                                            "giftcard_sender_email": "",
                                            "giftcard_sender_name": ""
                                        })
                                    })}),
                                "product_type": "",
                                "qty": "",
                                "quote_id": "",
                                "sku": ""
                            })
                        ),
                        "shipping": json!({
                            "address": json!({}),
                            "extension_attributes": json!({}),
                            "method": ""
                        })
                    })
                )
            }),
            "id": 0,
            "is_active": false,
            "is_virtual": false,
            "items": (json!({})),
            "items_count": 0,
            "items_qty": "",
            "orig_order_id": 0,
            "reserved_order_id": "",
            "store_id": 0,
            "updated_at": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/negotiableQuote/:quoteId \
  --header 'content-type: application/json' \
  --data '{
  "quote": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "converted_at": "",
    "created_at": "",
    "currency": {
      "base_currency_code": "",
      "base_to_global_rate": "",
      "base_to_quote_rate": "",
      "extension_attributes": {},
      "global_currency_code": "",
      "quote_currency_code": "",
      "store_currency_code": "",
      "store_to_base_rate": "",
      "store_to_quote_rate": ""
    },
    "customer": {
      "addresses": [
        {
          "city": "",
          "company": "",
          "country_id": "",
          "custom_attributes": [
            {}
          ],
          "customer_id": 0,
          "default_billing": false,
          "default_shipping": false,
          "extension_attributes": {},
          "fax": "",
          "firstname": "",
          "id": 0,
          "lastname": "",
          "middlename": "",
          "postcode": "",
          "prefix": "",
          "region": {
            "extension_attributes": {},
            "region": "",
            "region_code": "",
            "region_id": 0
          },
          "region_id": 0,
          "street": [],
          "suffix": "",
          "telephone": "",
          "vat_id": ""
        }
      ],
      "confirmation": "",
      "created_at": "",
      "created_in": "",
      "custom_attributes": [
        {}
      ],
      "default_billing": "",
      "default_shipping": "",
      "disable_auto_group_change": 0,
      "dob": "",
      "email": "",
      "extension_attributes": {
        "amazon_id": "",
        "company_attributes": {
          "company_id": 0,
          "customer_id": 0,
          "extension_attributes": {},
          "job_title": "",
          "status": 0,
          "telephone": ""
        },
        "is_subscribed": false,
        "vertex_customer_code": ""
      },
      "firstname": "",
      "gender": 0,
      "group_id": 0,
      "id": 0,
      "lastname": "",
      "middlename": "",
      "prefix": "",
      "store_id": 0,
      "suffix": "",
      "taxvat": "",
      "updated_at": "",
      "website_id": 0
    },
    "customer_is_guest": false,
    "customer_note": "",
    "customer_note_notify": false,
    "customer_tax_class_id": 0,
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "negotiable_quote": {
        "applied_rule_ids": "",
        "base_negotiated_total_price": "",
        "base_original_total_price": "",
        "creator_id": 0,
        "creator_type": 0,
        "deleted_sku": "",
        "email_notification_status": 0,
        "expiration_period": "",
        "extension_attributes": {},
        "has_unconfirmed_changes": false,
        "is_address_draft": false,
        "is_customer_price_changed": false,
        "is_regular_quote": false,
        "is_shipping_tax_changed": false,
        "negotiated_price_type": 0,
        "negotiated_price_value": "",
        "negotiated_total_price": "",
        "notifications": 0,
        "original_total_price": "",
        "quote_id": 0,
        "quote_name": "",
        "shipping_price": "",
        "status": ""
      },
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "extension_attributes": {
                "negotiable_quote_item": {
                  "extension_attributes": {},
                  "item_id": 0,
                  "original_discount_amount": "",
                  "original_price": "",
                  "original_tax_amount": ""
                }
              },
              "item_id": 0,
              "name": "",
              "price": "",
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty": "",
              "quote_id": "",
              "sku": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {},
            "method": ""
          }
        }
      ]
    },
    "id": 0,
    "is_active": false,
    "is_virtual": false,
    "items": [
      {}
    ],
    "items_count": 0,
    "items_qty": "",
    "orig_order_id": 0,
    "reserved_order_id": "",
    "store_id": 0,
    "updated_at": ""
  }
}'
echo '{
  "quote": {
    "billing_address": {
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": {
        "checkout_fields": [
          {}
        ],
        "gift_registry_id": 0
      },
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    },
    "converted_at": "",
    "created_at": "",
    "currency": {
      "base_currency_code": "",
      "base_to_global_rate": "",
      "base_to_quote_rate": "",
      "extension_attributes": {},
      "global_currency_code": "",
      "quote_currency_code": "",
      "store_currency_code": "",
      "store_to_base_rate": "",
      "store_to_quote_rate": ""
    },
    "customer": {
      "addresses": [
        {
          "city": "",
          "company": "",
          "country_id": "",
          "custom_attributes": [
            {}
          ],
          "customer_id": 0,
          "default_billing": false,
          "default_shipping": false,
          "extension_attributes": {},
          "fax": "",
          "firstname": "",
          "id": 0,
          "lastname": "",
          "middlename": "",
          "postcode": "",
          "prefix": "",
          "region": {
            "extension_attributes": {},
            "region": "",
            "region_code": "",
            "region_id": 0
          },
          "region_id": 0,
          "street": [],
          "suffix": "",
          "telephone": "",
          "vat_id": ""
        }
      ],
      "confirmation": "",
      "created_at": "",
      "created_in": "",
      "custom_attributes": [
        {}
      ],
      "default_billing": "",
      "default_shipping": "",
      "disable_auto_group_change": 0,
      "dob": "",
      "email": "",
      "extension_attributes": {
        "amazon_id": "",
        "company_attributes": {
          "company_id": 0,
          "customer_id": 0,
          "extension_attributes": {},
          "job_title": "",
          "status": 0,
          "telephone": ""
        },
        "is_subscribed": false,
        "vertex_customer_code": ""
      },
      "firstname": "",
      "gender": 0,
      "group_id": 0,
      "id": 0,
      "lastname": "",
      "middlename": "",
      "prefix": "",
      "store_id": 0,
      "suffix": "",
      "taxvat": "",
      "updated_at": "",
      "website_id": 0
    },
    "customer_is_guest": false,
    "customer_note": "",
    "customer_note_notify": false,
    "customer_tax_class_id": 0,
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "negotiable_quote": {
        "applied_rule_ids": "",
        "base_negotiated_total_price": "",
        "base_original_total_price": "",
        "creator_id": 0,
        "creator_type": 0,
        "deleted_sku": "",
        "email_notification_status": 0,
        "expiration_period": "",
        "extension_attributes": {},
        "has_unconfirmed_changes": false,
        "is_address_draft": false,
        "is_customer_price_changed": false,
        "is_regular_quote": false,
        "is_shipping_tax_changed": false,
        "negotiated_price_type": 0,
        "negotiated_price_value": "",
        "negotiated_total_price": "",
        "notifications": 0,
        "original_total_price": "",
        "quote_id": 0,
        "quote_name": "",
        "shipping_price": "",
        "status": ""
      },
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "extension_attributes": {
                "negotiable_quote_item": {
                  "extension_attributes": {},
                  "item_id": 0,
                  "original_discount_amount": "",
                  "original_price": "",
                  "original_tax_amount": ""
                }
              },
              "item_id": 0,
              "name": "",
              "price": "",
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty": "",
              "quote_id": "",
              "sku": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {},
            "method": ""
          }
        }
      ]
    },
    "id": 0,
    "is_active": false,
    "is_virtual": false,
    "items": [
      {}
    ],
    "items_count": 0,
    "items_qty": "",
    "orig_order_id": 0,
    "reserved_order_id": "",
    "store_id": 0,
    "updated_at": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/negotiableQuote/:quoteId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "quote": {\n    "billing_address": {\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "extension_attributes": {\n        "checkout_fields": [\n          {}\n        ],\n        "gift_registry_id": 0\n      },\n      "fax": "",\n      "firstname": "",\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "same_as_billing": 0,\n      "save_in_address_book": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": ""\n    },\n    "converted_at": "",\n    "created_at": "",\n    "currency": {\n      "base_currency_code": "",\n      "base_to_global_rate": "",\n      "base_to_quote_rate": "",\n      "extension_attributes": {},\n      "global_currency_code": "",\n      "quote_currency_code": "",\n      "store_currency_code": "",\n      "store_to_base_rate": "",\n      "store_to_quote_rate": ""\n    },\n    "customer": {\n      "addresses": [\n        {\n          "city": "",\n          "company": "",\n          "country_id": "",\n          "custom_attributes": [\n            {}\n          ],\n          "customer_id": 0,\n          "default_billing": false,\n          "default_shipping": false,\n          "extension_attributes": {},\n          "fax": "",\n          "firstname": "",\n          "id": 0,\n          "lastname": "",\n          "middlename": "",\n          "postcode": "",\n          "prefix": "",\n          "region": {\n            "extension_attributes": {},\n            "region": "",\n            "region_code": "",\n            "region_id": 0\n          },\n          "region_id": 0,\n          "street": [],\n          "suffix": "",\n          "telephone": "",\n          "vat_id": ""\n        }\n      ],\n      "confirmation": "",\n      "created_at": "",\n      "created_in": "",\n      "custom_attributes": [\n        {}\n      ],\n      "default_billing": "",\n      "default_shipping": "",\n      "disable_auto_group_change": 0,\n      "dob": "",\n      "email": "",\n      "extension_attributes": {\n        "amazon_id": "",\n        "company_attributes": {\n          "company_id": 0,\n          "customer_id": 0,\n          "extension_attributes": {},\n          "job_title": "",\n          "status": 0,\n          "telephone": ""\n        },\n        "is_subscribed": false,\n        "vertex_customer_code": ""\n      },\n      "firstname": "",\n      "gender": 0,\n      "group_id": 0,\n      "id": 0,\n      "lastname": "",\n      "middlename": "",\n      "prefix": "",\n      "store_id": 0,\n      "suffix": "",\n      "taxvat": "",\n      "updated_at": "",\n      "website_id": 0\n    },\n    "customer_is_guest": false,\n    "customer_note": "",\n    "customer_note_notify": false,\n    "customer_tax_class_id": 0,\n    "extension_attributes": {\n      "amazon_order_reference_id": "",\n      "negotiable_quote": {\n        "applied_rule_ids": "",\n        "base_negotiated_total_price": "",\n        "base_original_total_price": "",\n        "creator_id": 0,\n        "creator_type": 0,\n        "deleted_sku": "",\n        "email_notification_status": 0,\n        "expiration_period": "",\n        "extension_attributes": {},\n        "has_unconfirmed_changes": false,\n        "is_address_draft": false,\n        "is_customer_price_changed": false,\n        "is_regular_quote": false,\n        "is_shipping_tax_changed": false,\n        "negotiated_price_type": 0,\n        "negotiated_price_value": "",\n        "negotiated_total_price": "",\n        "notifications": 0,\n        "original_total_price": "",\n        "quote_id": 0,\n        "quote_name": "",\n        "shipping_price": "",\n        "status": ""\n      },\n      "shipping_assignments": [\n        {\n          "extension_attributes": {},\n          "items": [\n            {\n              "extension_attributes": {\n                "negotiable_quote_item": {\n                  "extension_attributes": {},\n                  "item_id": 0,\n                  "original_discount_amount": "",\n                  "original_price": "",\n                  "original_tax_amount": ""\n                }\n              },\n              "item_id": 0,\n              "name": "",\n              "price": "",\n              "product_option": {\n                "extension_attributes": {\n                  "bundle_options": [\n                    {\n                      "extension_attributes": {},\n                      "option_id": 0,\n                      "option_qty": 0,\n                      "option_selections": []\n                    }\n                  ],\n                  "configurable_item_options": [\n                    {\n                      "extension_attributes": {},\n                      "option_id": "",\n                      "option_value": 0\n                    }\n                  ],\n                  "custom_options": [\n                    {\n                      "extension_attributes": {\n                        "file_info": {\n                          "base64_encoded_data": "",\n                          "name": "",\n                          "type": ""\n                        }\n                      },\n                      "option_id": "",\n                      "option_value": ""\n                    }\n                  ],\n                  "downloadable_option": {\n                    "downloadable_links": []\n                  },\n                  "giftcard_item_option": {\n                    "custom_giftcard_amount": "",\n                    "extension_attributes": {},\n                    "giftcard_amount": "",\n                    "giftcard_message": "",\n                    "giftcard_recipient_email": "",\n                    "giftcard_recipient_name": "",\n                    "giftcard_sender_email": "",\n                    "giftcard_sender_name": ""\n                  }\n                }\n              },\n              "product_type": "",\n              "qty": "",\n              "quote_id": "",\n              "sku": ""\n            }\n          ],\n          "shipping": {\n            "address": {},\n            "extension_attributes": {},\n            "method": ""\n          }\n        }\n      ]\n    },\n    "id": 0,\n    "is_active": false,\n    "is_virtual": false,\n    "items": [\n      {}\n    ],\n    "items_count": 0,\n    "items_qty": "",\n    "orig_order_id": 0,\n    "reserved_order_id": "",\n    "store_id": 0,\n    "updated_at": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/negotiableQuote/:quoteId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["quote": [
    "billing_address": [
      "city": "",
      "company": "",
      "country_id": "",
      "custom_attributes": [
        [
          "attribute_code": "",
          "value": ""
        ]
      ],
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "extension_attributes": [
        "checkout_fields": [[]],
        "gift_registry_id": 0
      ],
      "fax": "",
      "firstname": "",
      "id": 0,
      "lastname": "",
      "middlename": "",
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "same_as_billing": 0,
      "save_in_address_book": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": ""
    ],
    "converted_at": "",
    "created_at": "",
    "currency": [
      "base_currency_code": "",
      "base_to_global_rate": "",
      "base_to_quote_rate": "",
      "extension_attributes": [],
      "global_currency_code": "",
      "quote_currency_code": "",
      "store_currency_code": "",
      "store_to_base_rate": "",
      "store_to_quote_rate": ""
    ],
    "customer": [
      "addresses": [
        [
          "city": "",
          "company": "",
          "country_id": "",
          "custom_attributes": [[]],
          "customer_id": 0,
          "default_billing": false,
          "default_shipping": false,
          "extension_attributes": [],
          "fax": "",
          "firstname": "",
          "id": 0,
          "lastname": "",
          "middlename": "",
          "postcode": "",
          "prefix": "",
          "region": [
            "extension_attributes": [],
            "region": "",
            "region_code": "",
            "region_id": 0
          ],
          "region_id": 0,
          "street": [],
          "suffix": "",
          "telephone": "",
          "vat_id": ""
        ]
      ],
      "confirmation": "",
      "created_at": "",
      "created_in": "",
      "custom_attributes": [[]],
      "default_billing": "",
      "default_shipping": "",
      "disable_auto_group_change": 0,
      "dob": "",
      "email": "",
      "extension_attributes": [
        "amazon_id": "",
        "company_attributes": [
          "company_id": 0,
          "customer_id": 0,
          "extension_attributes": [],
          "job_title": "",
          "status": 0,
          "telephone": ""
        ],
        "is_subscribed": false,
        "vertex_customer_code": ""
      ],
      "firstname": "",
      "gender": 0,
      "group_id": 0,
      "id": 0,
      "lastname": "",
      "middlename": "",
      "prefix": "",
      "store_id": 0,
      "suffix": "",
      "taxvat": "",
      "updated_at": "",
      "website_id": 0
    ],
    "customer_is_guest": false,
    "customer_note": "",
    "customer_note_notify": false,
    "customer_tax_class_id": 0,
    "extension_attributes": [
      "amazon_order_reference_id": "",
      "negotiable_quote": [
        "applied_rule_ids": "",
        "base_negotiated_total_price": "",
        "base_original_total_price": "",
        "creator_id": 0,
        "creator_type": 0,
        "deleted_sku": "",
        "email_notification_status": 0,
        "expiration_period": "",
        "extension_attributes": [],
        "has_unconfirmed_changes": false,
        "is_address_draft": false,
        "is_customer_price_changed": false,
        "is_regular_quote": false,
        "is_shipping_tax_changed": false,
        "negotiated_price_type": 0,
        "negotiated_price_value": "",
        "negotiated_total_price": "",
        "notifications": 0,
        "original_total_price": "",
        "quote_id": 0,
        "quote_name": "",
        "shipping_price": "",
        "status": ""
      ],
      "shipping_assignments": [
        [
          "extension_attributes": [],
          "items": [
            [
              "extension_attributes": ["negotiable_quote_item": [
                  "extension_attributes": [],
                  "item_id": 0,
                  "original_discount_amount": "",
                  "original_price": "",
                  "original_tax_amount": ""
                ]],
              "item_id": 0,
              "name": "",
              "price": "",
              "product_option": ["extension_attributes": [
                  "bundle_options": [
                    [
                      "extension_attributes": [],
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    ]
                  ],
                  "configurable_item_options": [
                    [
                      "extension_attributes": [],
                      "option_id": "",
                      "option_value": 0
                    ]
                  ],
                  "custom_options": [
                    [
                      "extension_attributes": ["file_info": [
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        ]],
                      "option_id": "",
                      "option_value": ""
                    ]
                  ],
                  "downloadable_option": ["downloadable_links": []],
                  "giftcard_item_option": [
                    "custom_giftcard_amount": "",
                    "extension_attributes": [],
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  ]
                ]],
              "product_type": "",
              "qty": "",
              "quote_id": "",
              "sku": ""
            ]
          ],
          "shipping": [
            "address": [],
            "extension_attributes": [],
            "method": ""
          ]
        ]
      ]
    ],
    "id": 0,
    "is_active": false,
    "is_virtual": false,
    "items": [[]],
    "items_count": 0,
    "items_qty": "",
    "orig_order_id": 0,
    "reserved_order_id": "",
    "store_id": 0,
    "updated_at": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiableQuote/:quoteId")! 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 negotiableQuote-{quoteId}-comments
{{baseUrl}}/V1/negotiableQuote/:quoteId/comments
QUERY PARAMS

quoteId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiableQuote/:quoteId/comments");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/negotiableQuote/:quoteId/comments")
require "http/client"

url = "{{baseUrl}}/V1/negotiableQuote/:quoteId/comments"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/negotiableQuote/:quoteId/comments"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/negotiableQuote/:quoteId/comments");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiableQuote/:quoteId/comments"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/negotiableQuote/:quoteId/comments HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/negotiableQuote/:quoteId/comments")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiableQuote/:quoteId/comments"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiableQuote/:quoteId/comments")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/negotiableQuote/:quoteId/comments")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/negotiableQuote/:quoteId/comments');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/negotiableQuote/:quoteId/comments'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiableQuote/:quoteId/comments';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/negotiableQuote/:quoteId/comments',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiableQuote/:quoteId/comments")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiableQuote/:quoteId/comments',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/negotiableQuote/:quoteId/comments'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/negotiableQuote/:quoteId/comments');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/negotiableQuote/:quoteId/comments'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiableQuote/:quoteId/comments';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiableQuote/:quoteId/comments"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/negotiableQuote/:quoteId/comments" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiableQuote/:quoteId/comments",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/negotiableQuote/:quoteId/comments');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiableQuote/:quoteId/comments');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/negotiableQuote/:quoteId/comments');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiableQuote/:quoteId/comments' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiableQuote/:quoteId/comments' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/negotiableQuote/:quoteId/comments")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiableQuote/:quoteId/comments"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiableQuote/:quoteId/comments"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiableQuote/:quoteId/comments")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/negotiableQuote/:quoteId/comments') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiableQuote/:quoteId/comments";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/negotiableQuote/:quoteId/comments
http GET {{baseUrl}}/V1/negotiableQuote/:quoteId/comments
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/negotiableQuote/:quoteId/comments
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiableQuote/:quoteId/comments")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT negotiableQuote-{quoteId}-shippingMethod
{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod
QUERY PARAMS

quoteId
BODY json

{
  "shippingMethod": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"shippingMethod\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod" {:content-type :json
                                                                                      :form-params {:shippingMethod ""}})
require "http/client"

url = "{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"shippingMethod\": \"\"\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}}/V1/negotiableQuote/:quoteId/shippingMethod"),
    Content = new StringContent("{\n  \"shippingMethod\": \"\"\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}}/V1/negotiableQuote/:quoteId/shippingMethod");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"shippingMethod\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod"

	payload := strings.NewReader("{\n  \"shippingMethod\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/negotiableQuote/:quoteId/shippingMethod HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 26

{
  "shippingMethod": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"shippingMethod\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"shippingMethod\": \"\"\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  \"shippingMethod\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod")
  .header("content-type", "application/json")
  .body("{\n  \"shippingMethod\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  shippingMethod: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod',
  headers: {'content-type': 'application/json'},
  data: {shippingMethod: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"shippingMethod":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "shippingMethod": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"shippingMethod\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiableQuote/:quoteId/shippingMethod',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({shippingMethod: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod',
  headers: {'content-type': 'application/json'},
  body: {shippingMethod: ''},
  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}}/V1/negotiableQuote/:quoteId/shippingMethod');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  shippingMethod: ''
});

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}}/V1/negotiableQuote/:quoteId/shippingMethod',
  headers: {'content-type': 'application/json'},
  data: {shippingMethod: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"shippingMethod":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"shippingMethod": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod"]
                                                       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}}/V1/negotiableQuote/:quoteId/shippingMethod" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"shippingMethod\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod",
  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([
    'shippingMethod' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod', [
  'body' => '{
  "shippingMethod": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'shippingMethod' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'shippingMethod' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "shippingMethod": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "shippingMethod": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"shippingMethod\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/negotiableQuote/:quoteId/shippingMethod", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod"

payload = { "shippingMethod": "" }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod"

payload <- "{\n  \"shippingMethod\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"shippingMethod\": \"\"\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/V1/negotiableQuote/:quoteId/shippingMethod') do |req|
  req.body = "{\n  \"shippingMethod\": \"\"\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}}/V1/negotiableQuote/:quoteId/shippingMethod";

    let payload = json!({"shippingMethod": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod \
  --header 'content-type: application/json' \
  --data '{
  "shippingMethod": ""
}'
echo '{
  "shippingMethod": ""
}' |  \
  http PUT {{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "shippingMethod": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["shippingMethod": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiableQuote/:quoteId/shippingMethod")! 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 negotiableQuote-attachmentContent
{{baseUrl}}/V1/negotiableQuote/attachmentContent
QUERY PARAMS

attachmentIds
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds=");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/negotiableQuote/attachmentContent" {:query-params {:attachmentIds ""}})
require "http/client"

url = "{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds="

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds="),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds=");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds="

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/negotiableQuote/attachmentContent?attachmentIds= HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds=")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds="))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds=")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds=")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds=');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/negotiableQuote/attachmentContent',
  params: {attachmentIds: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds=';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds=',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds=")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiableQuote/attachmentContent?attachmentIds=',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/negotiableQuote/attachmentContent',
  qs: {attachmentIds: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/negotiableQuote/attachmentContent');

req.query({
  attachmentIds: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/negotiableQuote/attachmentContent',
  params: {attachmentIds: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds=';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds="]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds=" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds=');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiableQuote/attachmentContent');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'attachmentIds' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/negotiableQuote/attachmentContent');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'attachmentIds' => ''
]));

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds=' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds=' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/negotiableQuote/attachmentContent?attachmentIds=")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiableQuote/attachmentContent"

querystring = {"attachmentIds":""}

response = requests.get(url, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiableQuote/attachmentContent"

queryString <- list(attachmentIds = "")

response <- VERB("GET", url, query = queryString, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/negotiableQuote/attachmentContent') do |req|
  req.params['attachmentIds'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiableQuote/attachmentContent";

    let querystring = [
        ("attachmentIds", ""),
    ];

    let client = reqwest::Client::new();
    let response = client.get(url)
        .query(&querystring)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url '{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds='
http GET '{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds='
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds='
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiableQuote/attachmentContent?attachmentIds=")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST negotiableQuote-decline
{{baseUrl}}/V1/negotiableQuote/decline
BODY json

{
  "quoteId": 0,
  "reason": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiableQuote/decline");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"quoteId\": 0,\n  \"reason\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/negotiableQuote/decline" {:content-type :json
                                                                       :form-params {:quoteId 0
                                                                                     :reason ""}})
require "http/client"

url = "{{baseUrl}}/V1/negotiableQuote/decline"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"quoteId\": 0,\n  \"reason\": \"\"\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}}/V1/negotiableQuote/decline"),
    Content = new StringContent("{\n  \"quoteId\": 0,\n  \"reason\": \"\"\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}}/V1/negotiableQuote/decline");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"quoteId\": 0,\n  \"reason\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiableQuote/decline"

	payload := strings.NewReader("{\n  \"quoteId\": 0,\n  \"reason\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/negotiableQuote/decline HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 34

{
  "quoteId": 0,
  "reason": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/negotiableQuote/decline")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"quoteId\": 0,\n  \"reason\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiableQuote/decline"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"quoteId\": 0,\n  \"reason\": \"\"\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  \"quoteId\": 0,\n  \"reason\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiableQuote/decline")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/negotiableQuote/decline")
  .header("content-type", "application/json")
  .body("{\n  \"quoteId\": 0,\n  \"reason\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  quoteId: 0,
  reason: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/negotiableQuote/decline');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiableQuote/decline',
  headers: {'content-type': 'application/json'},
  data: {quoteId: 0, reason: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiableQuote/decline';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"quoteId":0,"reason":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/negotiableQuote/decline',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "quoteId": 0,\n  "reason": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"quoteId\": 0,\n  \"reason\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiableQuote/decline")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiableQuote/decline',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({quoteId: 0, reason: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiableQuote/decline',
  headers: {'content-type': 'application/json'},
  body: {quoteId: 0, reason: ''},
  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}}/V1/negotiableQuote/decline');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  quoteId: 0,
  reason: ''
});

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}}/V1/negotiableQuote/decline',
  headers: {'content-type': 'application/json'},
  data: {quoteId: 0, reason: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiableQuote/decline';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"quoteId":0,"reason":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"quoteId": @0,
                              @"reason": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiableQuote/decline"]
                                                       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}}/V1/negotiableQuote/decline" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"quoteId\": 0,\n  \"reason\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiableQuote/decline",
  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([
    'quoteId' => 0,
    'reason' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/negotiableQuote/decline', [
  'body' => '{
  "quoteId": 0,
  "reason": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiableQuote/decline');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'quoteId' => 0,
  'reason' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'quoteId' => 0,
  'reason' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/negotiableQuote/decline');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiableQuote/decline' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "quoteId": 0,
  "reason": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiableQuote/decline' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "quoteId": 0,
  "reason": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"quoteId\": 0,\n  \"reason\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/negotiableQuote/decline", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiableQuote/decline"

payload = {
    "quoteId": 0,
    "reason": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiableQuote/decline"

payload <- "{\n  \"quoteId\": 0,\n  \"reason\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiableQuote/decline")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"quoteId\": 0,\n  \"reason\": \"\"\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/V1/negotiableQuote/decline') do |req|
  req.body = "{\n  \"quoteId\": 0,\n  \"reason\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiableQuote/decline";

    let payload = json!({
        "quoteId": 0,
        "reason": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/negotiableQuote/decline \
  --header 'content-type: application/json' \
  --data '{
  "quoteId": 0,
  "reason": ""
}'
echo '{
  "quoteId": 0,
  "reason": ""
}' |  \
  http POST {{baseUrl}}/V1/negotiableQuote/decline \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "quoteId": 0,\n  "reason": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/negotiableQuote/decline
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "quoteId": 0,
  "reason": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiableQuote/decline")! 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 negotiableQuote-pricesUpdated
{{baseUrl}}/V1/negotiableQuote/pricesUpdated
BODY json

{
  "quoteIds": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiableQuote/pricesUpdated");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"quoteIds\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/negotiableQuote/pricesUpdated" {:content-type :json
                                                                             :form-params {:quoteIds []}})
require "http/client"

url = "{{baseUrl}}/V1/negotiableQuote/pricesUpdated"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"quoteIds\": []\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}}/V1/negotiableQuote/pricesUpdated"),
    Content = new StringContent("{\n  \"quoteIds\": []\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}}/V1/negotiableQuote/pricesUpdated");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"quoteIds\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiableQuote/pricesUpdated"

	payload := strings.NewReader("{\n  \"quoteIds\": []\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/negotiableQuote/pricesUpdated HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 20

{
  "quoteIds": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/negotiableQuote/pricesUpdated")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"quoteIds\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiableQuote/pricesUpdated"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"quoteIds\": []\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  \"quoteIds\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiableQuote/pricesUpdated")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/negotiableQuote/pricesUpdated")
  .header("content-type", "application/json")
  .body("{\n  \"quoteIds\": []\n}")
  .asString();
const data = JSON.stringify({
  quoteIds: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/negotiableQuote/pricesUpdated');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiableQuote/pricesUpdated',
  headers: {'content-type': 'application/json'},
  data: {quoteIds: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiableQuote/pricesUpdated';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"quoteIds":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/negotiableQuote/pricesUpdated',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "quoteIds": []\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"quoteIds\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiableQuote/pricesUpdated")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiableQuote/pricesUpdated',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({quoteIds: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiableQuote/pricesUpdated',
  headers: {'content-type': 'application/json'},
  body: {quoteIds: []},
  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}}/V1/negotiableQuote/pricesUpdated');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  quoteIds: []
});

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}}/V1/negotiableQuote/pricesUpdated',
  headers: {'content-type': 'application/json'},
  data: {quoteIds: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiableQuote/pricesUpdated';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"quoteIds":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"quoteIds": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiableQuote/pricesUpdated"]
                                                       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}}/V1/negotiableQuote/pricesUpdated" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"quoteIds\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiableQuote/pricesUpdated",
  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([
    'quoteIds' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/negotiableQuote/pricesUpdated', [
  'body' => '{
  "quoteIds": []
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiableQuote/pricesUpdated');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'quoteIds' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'quoteIds' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/negotiableQuote/pricesUpdated');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiableQuote/pricesUpdated' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "quoteIds": []
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiableQuote/pricesUpdated' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "quoteIds": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"quoteIds\": []\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/negotiableQuote/pricesUpdated", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiableQuote/pricesUpdated"

payload = { "quoteIds": [] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiableQuote/pricesUpdated"

payload <- "{\n  \"quoteIds\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiableQuote/pricesUpdated")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"quoteIds\": []\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/V1/negotiableQuote/pricesUpdated') do |req|
  req.body = "{\n  \"quoteIds\": []\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiableQuote/pricesUpdated";

    let payload = json!({"quoteIds": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/negotiableQuote/pricesUpdated \
  --header 'content-type: application/json' \
  --data '{
  "quoteIds": []
}'
echo '{
  "quoteIds": []
}' |  \
  http POST {{baseUrl}}/V1/negotiableQuote/pricesUpdated \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "quoteIds": []\n}' \
  --output-document \
  - {{baseUrl}}/V1/negotiableQuote/pricesUpdated
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["quoteIds": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiableQuote/pricesUpdated")! 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 negotiableQuote-request
{{baseUrl}}/V1/negotiableQuote/request
BODY json

{
  "comment": "",
  "files": [
    {
      "base64_encoded_data": "",
      "extension_attributes": {},
      "name": "",
      "type": ""
    }
  ],
  "quoteId": 0,
  "quoteName": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiableQuote/request");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0,\n  \"quoteName\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/negotiableQuote/request" {:content-type :json
                                                                       :form-params {:comment ""
                                                                                     :files [{:base64_encoded_data ""
                                                                                              :extension_attributes {}
                                                                                              :name ""
                                                                                              :type ""}]
                                                                                     :quoteId 0
                                                                                     :quoteName ""}})
require "http/client"

url = "{{baseUrl}}/V1/negotiableQuote/request"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0,\n  \"quoteName\": \"\"\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}}/V1/negotiableQuote/request"),
    Content = new StringContent("{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0,\n  \"quoteName\": \"\"\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}}/V1/negotiableQuote/request");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0,\n  \"quoteName\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiableQuote/request"

	payload := strings.NewReader("{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0,\n  \"quoteName\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/negotiableQuote/request HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 186

{
  "comment": "",
  "files": [
    {
      "base64_encoded_data": "",
      "extension_attributes": {},
      "name": "",
      "type": ""
    }
  ],
  "quoteId": 0,
  "quoteName": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/negotiableQuote/request")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0,\n  \"quoteName\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiableQuote/request"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0,\n  \"quoteName\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0,\n  \"quoteName\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiableQuote/request")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/negotiableQuote/request")
  .header("content-type", "application/json")
  .body("{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0,\n  \"quoteName\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  comment: '',
  files: [
    {
      base64_encoded_data: '',
      extension_attributes: {},
      name: '',
      type: ''
    }
  ],
  quoteId: 0,
  quoteName: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/negotiableQuote/request');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiableQuote/request',
  headers: {'content-type': 'application/json'},
  data: {
    comment: '',
    files: [{base64_encoded_data: '', extension_attributes: {}, name: '', type: ''}],
    quoteId: 0,
    quoteName: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiableQuote/request';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"comment":"","files":[{"base64_encoded_data":"","extension_attributes":{},"name":"","type":""}],"quoteId":0,"quoteName":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/negotiableQuote/request',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "comment": "",\n  "files": [\n    {\n      "base64_encoded_data": "",\n      "extension_attributes": {},\n      "name": "",\n      "type": ""\n    }\n  ],\n  "quoteId": 0,\n  "quoteName": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0,\n  \"quoteName\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiableQuote/request")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiableQuote/request',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  comment: '',
  files: [{base64_encoded_data: '', extension_attributes: {}, name: '', type: ''}],
  quoteId: 0,
  quoteName: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiableQuote/request',
  headers: {'content-type': 'application/json'},
  body: {
    comment: '',
    files: [{base64_encoded_data: '', extension_attributes: {}, name: '', type: ''}],
    quoteId: 0,
    quoteName: ''
  },
  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}}/V1/negotiableQuote/request');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  comment: '',
  files: [
    {
      base64_encoded_data: '',
      extension_attributes: {},
      name: '',
      type: ''
    }
  ],
  quoteId: 0,
  quoteName: ''
});

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}}/V1/negotiableQuote/request',
  headers: {'content-type': 'application/json'},
  data: {
    comment: '',
    files: [{base64_encoded_data: '', extension_attributes: {}, name: '', type: ''}],
    quoteId: 0,
    quoteName: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiableQuote/request';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"comment":"","files":[{"base64_encoded_data":"","extension_attributes":{},"name":"","type":""}],"quoteId":0,"quoteName":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"comment": @"",
                              @"files": @[ @{ @"base64_encoded_data": @"", @"extension_attributes": @{  }, @"name": @"", @"type": @"" } ],
                              @"quoteId": @0,
                              @"quoteName": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiableQuote/request"]
                                                       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}}/V1/negotiableQuote/request" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0,\n  \"quoteName\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiableQuote/request",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'comment' => '',
    'files' => [
        [
                'base64_encoded_data' => '',
                'extension_attributes' => [
                                
                ],
                'name' => '',
                'type' => ''
        ]
    ],
    'quoteId' => 0,
    'quoteName' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/negotiableQuote/request', [
  'body' => '{
  "comment": "",
  "files": [
    {
      "base64_encoded_data": "",
      "extension_attributes": {},
      "name": "",
      "type": ""
    }
  ],
  "quoteId": 0,
  "quoteName": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiableQuote/request');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'comment' => '',
  'files' => [
    [
        'base64_encoded_data' => '',
        'extension_attributes' => [
                
        ],
        'name' => '',
        'type' => ''
    ]
  ],
  'quoteId' => 0,
  'quoteName' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'comment' => '',
  'files' => [
    [
        'base64_encoded_data' => '',
        'extension_attributes' => [
                
        ],
        'name' => '',
        'type' => ''
    ]
  ],
  'quoteId' => 0,
  'quoteName' => ''
]));
$request->setRequestUrl('{{baseUrl}}/V1/negotiableQuote/request');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiableQuote/request' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "comment": "",
  "files": [
    {
      "base64_encoded_data": "",
      "extension_attributes": {},
      "name": "",
      "type": ""
    }
  ],
  "quoteId": 0,
  "quoteName": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiableQuote/request' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "comment": "",
  "files": [
    {
      "base64_encoded_data": "",
      "extension_attributes": {},
      "name": "",
      "type": ""
    }
  ],
  "quoteId": 0,
  "quoteName": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0,\n  \"quoteName\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/negotiableQuote/request", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiableQuote/request"

payload = {
    "comment": "",
    "files": [
        {
            "base64_encoded_data": "",
            "extension_attributes": {},
            "name": "",
            "type": ""
        }
    ],
    "quoteId": 0,
    "quoteName": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiableQuote/request"

payload <- "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0,\n  \"quoteName\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiableQuote/request")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0,\n  \"quoteName\": \"\"\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/V1/negotiableQuote/request') do |req|
  req.body = "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0,\n  \"quoteName\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiableQuote/request";

    let payload = json!({
        "comment": "",
        "files": (
            json!({
                "base64_encoded_data": "",
                "extension_attributes": json!({}),
                "name": "",
                "type": ""
            })
        ),
        "quoteId": 0,
        "quoteName": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/negotiableQuote/request \
  --header 'content-type: application/json' \
  --data '{
  "comment": "",
  "files": [
    {
      "base64_encoded_data": "",
      "extension_attributes": {},
      "name": "",
      "type": ""
    }
  ],
  "quoteId": 0,
  "quoteName": ""
}'
echo '{
  "comment": "",
  "files": [
    {
      "base64_encoded_data": "",
      "extension_attributes": {},
      "name": "",
      "type": ""
    }
  ],
  "quoteId": 0,
  "quoteName": ""
}' |  \
  http POST {{baseUrl}}/V1/negotiableQuote/request \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "comment": "",\n  "files": [\n    {\n      "base64_encoded_data": "",\n      "extension_attributes": {},\n      "name": "",\n      "type": ""\n    }\n  ],\n  "quoteId": 0,\n  "quoteName": ""\n}' \
  --output-document \
  - {{baseUrl}}/V1/negotiableQuote/request
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "comment": "",
  "files": [
    [
      "base64_encoded_data": "",
      "extension_attributes": [],
      "name": "",
      "type": ""
    ]
  ],
  "quoteId": 0,
  "quoteName": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiableQuote/request")! 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 negotiableQuote-submitToCustomer
{{baseUrl}}/V1/negotiableQuote/submitToCustomer
BODY json

{
  "comment": "",
  "files": [
    {
      "base64_encoded_data": "",
      "extension_attributes": {},
      "name": "",
      "type": ""
    }
  ],
  "quoteId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/negotiableQuote/submitToCustomer");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/negotiableQuote/submitToCustomer" {:content-type :json
                                                                                :form-params {:comment ""
                                                                                              :files [{:base64_encoded_data ""
                                                                                                       :extension_attributes {}
                                                                                                       :name ""
                                                                                                       :type ""}]
                                                                                              :quoteId 0}})
require "http/client"

url = "{{baseUrl}}/V1/negotiableQuote/submitToCustomer"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 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}}/V1/negotiableQuote/submitToCustomer"),
    Content = new StringContent("{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 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}}/V1/negotiableQuote/submitToCustomer");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/negotiableQuote/submitToCustomer"

	payload := strings.NewReader("{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/negotiableQuote/submitToCustomer HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 167

{
  "comment": "",
  "files": [
    {
      "base64_encoded_data": "",
      "extension_attributes": {},
      "name": "",
      "type": ""
    }
  ],
  "quoteId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/negotiableQuote/submitToCustomer")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/negotiableQuote/submitToCustomer"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/negotiableQuote/submitToCustomer")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/negotiableQuote/submitToCustomer")
  .header("content-type", "application/json")
  .body("{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0\n}")
  .asString();
const data = JSON.stringify({
  comment: '',
  files: [
    {
      base64_encoded_data: '',
      extension_attributes: {},
      name: '',
      type: ''
    }
  ],
  quoteId: 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}}/V1/negotiableQuote/submitToCustomer');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiableQuote/submitToCustomer',
  headers: {'content-type': 'application/json'},
  data: {
    comment: '',
    files: [{base64_encoded_data: '', extension_attributes: {}, name: '', type: ''}],
    quoteId: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/negotiableQuote/submitToCustomer';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"comment":"","files":[{"base64_encoded_data":"","extension_attributes":{},"name":"","type":""}],"quoteId":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}}/V1/negotiableQuote/submitToCustomer',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "comment": "",\n  "files": [\n    {\n      "base64_encoded_data": "",\n      "extension_attributes": {},\n      "name": "",\n      "type": ""\n    }\n  ],\n  "quoteId": 0\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/negotiableQuote/submitToCustomer")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/negotiableQuote/submitToCustomer',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  comment: '',
  files: [{base64_encoded_data: '', extension_attributes: {}, name: '', type: ''}],
  quoteId: 0
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/negotiableQuote/submitToCustomer',
  headers: {'content-type': 'application/json'},
  body: {
    comment: '',
    files: [{base64_encoded_data: '', extension_attributes: {}, name: '', type: ''}],
    quoteId: 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}}/V1/negotiableQuote/submitToCustomer');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  comment: '',
  files: [
    {
      base64_encoded_data: '',
      extension_attributes: {},
      name: '',
      type: ''
    }
  ],
  quoteId: 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}}/V1/negotiableQuote/submitToCustomer',
  headers: {'content-type': 'application/json'},
  data: {
    comment: '',
    files: [{base64_encoded_data: '', extension_attributes: {}, name: '', type: ''}],
    quoteId: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/negotiableQuote/submitToCustomer';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"comment":"","files":[{"base64_encoded_data":"","extension_attributes":{},"name":"","type":""}],"quoteId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"comment": @"",
                              @"files": @[ @{ @"base64_encoded_data": @"", @"extension_attributes": @{  }, @"name": @"", @"type": @"" } ],
                              @"quoteId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/negotiableQuote/submitToCustomer"]
                                                       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}}/V1/negotiableQuote/submitToCustomer" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/negotiableQuote/submitToCustomer",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'comment' => '',
    'files' => [
        [
                'base64_encoded_data' => '',
                'extension_attributes' => [
                                
                ],
                'name' => '',
                'type' => ''
        ]
    ],
    'quoteId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/negotiableQuote/submitToCustomer', [
  'body' => '{
  "comment": "",
  "files": [
    {
      "base64_encoded_data": "",
      "extension_attributes": {},
      "name": "",
      "type": ""
    }
  ],
  "quoteId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/negotiableQuote/submitToCustomer');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'comment' => '',
  'files' => [
    [
        'base64_encoded_data' => '',
        'extension_attributes' => [
                
        ],
        'name' => '',
        'type' => ''
    ]
  ],
  'quoteId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'comment' => '',
  'files' => [
    [
        'base64_encoded_data' => '',
        'extension_attributes' => [
                
        ],
        'name' => '',
        'type' => ''
    ]
  ],
  'quoteId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/negotiableQuote/submitToCustomer');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/negotiableQuote/submitToCustomer' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "comment": "",
  "files": [
    {
      "base64_encoded_data": "",
      "extension_attributes": {},
      "name": "",
      "type": ""
    }
  ],
  "quoteId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/negotiableQuote/submitToCustomer' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "comment": "",
  "files": [
    {
      "base64_encoded_data": "",
      "extension_attributes": {},
      "name": "",
      "type": ""
    }
  ],
  "quoteId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/negotiableQuote/submitToCustomer", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/negotiableQuote/submitToCustomer"

payload = {
    "comment": "",
    "files": [
        {
            "base64_encoded_data": "",
            "extension_attributes": {},
            "name": "",
            "type": ""
        }
    ],
    "quoteId": 0
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/negotiableQuote/submitToCustomer"

payload <- "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/negotiableQuote/submitToCustomer")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 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/V1/negotiableQuote/submitToCustomer') do |req|
  req.body = "{\n  \"comment\": \"\",\n  \"files\": [\n    {\n      \"base64_encoded_data\": \"\",\n      \"extension_attributes\": {},\n      \"name\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"quoteId\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/negotiableQuote/submitToCustomer";

    let payload = json!({
        "comment": "",
        "files": (
            json!({
                "base64_encoded_data": "",
                "extension_attributes": json!({}),
                "name": "",
                "type": ""
            })
        ),
        "quoteId": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/negotiableQuote/submitToCustomer \
  --header 'content-type: application/json' \
  --data '{
  "comment": "",
  "files": [
    {
      "base64_encoded_data": "",
      "extension_attributes": {},
      "name": "",
      "type": ""
    }
  ],
  "quoteId": 0
}'
echo '{
  "comment": "",
  "files": [
    {
      "base64_encoded_data": "",
      "extension_attributes": {},
      "name": "",
      "type": ""
    }
  ],
  "quoteId": 0
}' |  \
  http POST {{baseUrl}}/V1/negotiableQuote/submitToCustomer \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "comment": "",\n  "files": [\n    {\n      "base64_encoded_data": "",\n      "extension_attributes": {},\n      "name": "",\n      "type": ""\n    }\n  ],\n  "quoteId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/negotiableQuote/submitToCustomer
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "comment": "",
  "files": [
    [
      "base64_encoded_data": "",
      "extension_attributes": [],
      "name": "",
      "type": ""
    ]
  ],
  "quoteId": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/negotiableQuote/submitToCustomer")! 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 order-{orderId}-invoice
{{baseUrl}}/V1/order/:orderId/invoice
QUERY PARAMS

orderId
BODY json

{
  "appendComment": false,
  "arguments": {
    "extension_attributes": {}
  },
  "capture": false,
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/order/:orderId/invoice");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {}\n  },\n  \"capture\": false,\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/order/:orderId/invoice" {:content-type :json
                                                                      :form-params {:appendComment false
                                                                                    :arguments {:extension_attributes {}}
                                                                                    :capture false
                                                                                    :comment {:comment ""
                                                                                              :extension_attributes {}
                                                                                              :is_visible_on_front 0}
                                                                                    :items [{:extension_attributes {}
                                                                                             :order_item_id 0
                                                                                             :qty ""}]
                                                                                    :notify false}})
require "http/client"

url = "{{baseUrl}}/V1/order/:orderId/invoice"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {}\n  },\n  \"capture\": false,\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": 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}}/V1/order/:orderId/invoice"),
    Content = new StringContent("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {}\n  },\n  \"capture\": false,\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": 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}}/V1/order/:orderId/invoice");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {}\n  },\n  \"capture\": false,\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/order/:orderId/invoice"

	payload := strings.NewReader("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {}\n  },\n  \"capture\": false,\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/order/:orderId/invoice HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 326

{
  "appendComment": false,
  "arguments": {
    "extension_attributes": {}
  },
  "capture": false,
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/order/:orderId/invoice")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {}\n  },\n  \"capture\": false,\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/order/:orderId/invoice"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {}\n  },\n  \"capture\": false,\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": 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  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {}\n  },\n  \"capture\": false,\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/order/:orderId/invoice")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/order/:orderId/invoice")
  .header("content-type", "application/json")
  .body("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {}\n  },\n  \"capture\": false,\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}")
  .asString();
const data = JSON.stringify({
  appendComment: false,
  arguments: {
    extension_attributes: {}
  },
  capture: false,
  comment: {
    comment: '',
    extension_attributes: {},
    is_visible_on_front: 0
  },
  items: [
    {
      extension_attributes: {},
      order_item_id: 0,
      qty: ''
    }
  ],
  notify: 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}}/V1/order/:orderId/invoice');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/order/:orderId/invoice',
  headers: {'content-type': 'application/json'},
  data: {
    appendComment: false,
    arguments: {extension_attributes: {}},
    capture: false,
    comment: {comment: '', extension_attributes: {}, is_visible_on_front: 0},
    items: [{extension_attributes: {}, order_item_id: 0, qty: ''}],
    notify: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/order/:orderId/invoice';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"appendComment":false,"arguments":{"extension_attributes":{}},"capture":false,"comment":{"comment":"","extension_attributes":{},"is_visible_on_front":0},"items":[{"extension_attributes":{},"order_item_id":0,"qty":""}],"notify":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}}/V1/order/:orderId/invoice',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "appendComment": false,\n  "arguments": {\n    "extension_attributes": {}\n  },\n  "capture": false,\n  "comment": {\n    "comment": "",\n    "extension_attributes": {},\n    "is_visible_on_front": 0\n  },\n  "items": [\n    {\n      "extension_attributes": {},\n      "order_item_id": 0,\n      "qty": ""\n    }\n  ],\n  "notify": 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  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {}\n  },\n  \"capture\": false,\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/order/:orderId/invoice")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/order/:orderId/invoice',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  appendComment: false,
  arguments: {extension_attributes: {}},
  capture: false,
  comment: {comment: '', extension_attributes: {}, is_visible_on_front: 0},
  items: [{extension_attributes: {}, order_item_id: 0, qty: ''}],
  notify: false
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/order/:orderId/invoice',
  headers: {'content-type': 'application/json'},
  body: {
    appendComment: false,
    arguments: {extension_attributes: {}},
    capture: false,
    comment: {comment: '', extension_attributes: {}, is_visible_on_front: 0},
    items: [{extension_attributes: {}, order_item_id: 0, qty: ''}],
    notify: 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}}/V1/order/:orderId/invoice');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  appendComment: false,
  arguments: {
    extension_attributes: {}
  },
  capture: false,
  comment: {
    comment: '',
    extension_attributes: {},
    is_visible_on_front: 0
  },
  items: [
    {
      extension_attributes: {},
      order_item_id: 0,
      qty: ''
    }
  ],
  notify: 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}}/V1/order/:orderId/invoice',
  headers: {'content-type': 'application/json'},
  data: {
    appendComment: false,
    arguments: {extension_attributes: {}},
    capture: false,
    comment: {comment: '', extension_attributes: {}, is_visible_on_front: 0},
    items: [{extension_attributes: {}, order_item_id: 0, qty: ''}],
    notify: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/order/:orderId/invoice';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"appendComment":false,"arguments":{"extension_attributes":{}},"capture":false,"comment":{"comment":"","extension_attributes":{},"is_visible_on_front":0},"items":[{"extension_attributes":{},"order_item_id":0,"qty":""}],"notify":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"appendComment": @NO,
                              @"arguments": @{ @"extension_attributes": @{  } },
                              @"capture": @NO,
                              @"comment": @{ @"comment": @"", @"extension_attributes": @{  }, @"is_visible_on_front": @0 },
                              @"items": @[ @{ @"extension_attributes": @{  }, @"order_item_id": @0, @"qty": @"" } ],
                              @"notify": @NO };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/order/:orderId/invoice"]
                                                       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}}/V1/order/:orderId/invoice" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {}\n  },\n  \"capture\": false,\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/order/:orderId/invoice",
  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([
    'appendComment' => null,
    'arguments' => [
        'extension_attributes' => [
                
        ]
    ],
    'capture' => null,
    'comment' => [
        'comment' => '',
        'extension_attributes' => [
                
        ],
        'is_visible_on_front' => 0
    ],
    'items' => [
        [
                'extension_attributes' => [
                                
                ],
                'order_item_id' => 0,
                'qty' => ''
        ]
    ],
    'notify' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/order/:orderId/invoice', [
  'body' => '{
  "appendComment": false,
  "arguments": {
    "extension_attributes": {}
  },
  "capture": false,
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/order/:orderId/invoice');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'appendComment' => null,
  'arguments' => [
    'extension_attributes' => [
        
    ]
  ],
  'capture' => null,
  'comment' => [
    'comment' => '',
    'extension_attributes' => [
        
    ],
    'is_visible_on_front' => 0
  ],
  'items' => [
    [
        'extension_attributes' => [
                
        ],
        'order_item_id' => 0,
        'qty' => ''
    ]
  ],
  'notify' => null
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'appendComment' => null,
  'arguments' => [
    'extension_attributes' => [
        
    ]
  ],
  'capture' => null,
  'comment' => [
    'comment' => '',
    'extension_attributes' => [
        
    ],
    'is_visible_on_front' => 0
  ],
  'items' => [
    [
        'extension_attributes' => [
                
        ],
        'order_item_id' => 0,
        'qty' => ''
    ]
  ],
  'notify' => null
]));
$request->setRequestUrl('{{baseUrl}}/V1/order/:orderId/invoice');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/order/:orderId/invoice' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "appendComment": false,
  "arguments": {
    "extension_attributes": {}
  },
  "capture": false,
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/order/:orderId/invoice' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "appendComment": false,
  "arguments": {
    "extension_attributes": {}
  },
  "capture": false,
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {}\n  },\n  \"capture\": false,\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/order/:orderId/invoice", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/order/:orderId/invoice"

payload = {
    "appendComment": False,
    "arguments": { "extension_attributes": {} },
    "capture": False,
    "comment": {
        "comment": "",
        "extension_attributes": {},
        "is_visible_on_front": 0
    },
    "items": [
        {
            "extension_attributes": {},
            "order_item_id": 0,
            "qty": ""
        }
    ],
    "notify": False
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/order/:orderId/invoice"

payload <- "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {}\n  },\n  \"capture\": false,\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/order/:orderId/invoice")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {}\n  },\n  \"capture\": false,\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": 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/V1/order/:orderId/invoice') do |req|
  req.body = "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {}\n  },\n  \"capture\": false,\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/order/:orderId/invoice";

    let payload = json!({
        "appendComment": false,
        "arguments": json!({"extension_attributes": json!({})}),
        "capture": false,
        "comment": json!({
            "comment": "",
            "extension_attributes": json!({}),
            "is_visible_on_front": 0
        }),
        "items": (
            json!({
                "extension_attributes": json!({}),
                "order_item_id": 0,
                "qty": ""
            })
        ),
        "notify": false
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/order/:orderId/invoice \
  --header 'content-type: application/json' \
  --data '{
  "appendComment": false,
  "arguments": {
    "extension_attributes": {}
  },
  "capture": false,
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}'
echo '{
  "appendComment": false,
  "arguments": {
    "extension_attributes": {}
  },
  "capture": false,
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}' |  \
  http POST {{baseUrl}}/V1/order/:orderId/invoice \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "appendComment": false,\n  "arguments": {\n    "extension_attributes": {}\n  },\n  "capture": false,\n  "comment": {\n    "comment": "",\n    "extension_attributes": {},\n    "is_visible_on_front": 0\n  },\n  "items": [\n    {\n      "extension_attributes": {},\n      "order_item_id": 0,\n      "qty": ""\n    }\n  ],\n  "notify": false\n}' \
  --output-document \
  - {{baseUrl}}/V1/order/:orderId/invoice
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "appendComment": false,
  "arguments": ["extension_attributes": []],
  "capture": false,
  "comment": [
    "comment": "",
    "extension_attributes": [],
    "is_visible_on_front": 0
  ],
  "items": [
    [
      "extension_attributes": [],
      "order_item_id": 0,
      "qty": ""
    ]
  ],
  "notify": false
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/order/:orderId/invoice")! 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 order-{orderId}-refund
{{baseUrl}}/V1/order/:orderId/refund
QUERY PARAMS

orderId
BODY json

{
  "appendComment": false,
  "arguments": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "extension_attributes": {
      "return_to_stock_items": []
    },
    "shipping_amount": ""
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/order/:orderId/refund");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/order/:orderId/refund" {:content-type :json
                                                                     :form-params {:appendComment false
                                                                                   :arguments {:adjustment_negative ""
                                                                                               :adjustment_positive ""
                                                                                               :extension_attributes {:return_to_stock_items []}
                                                                                               :shipping_amount ""}
                                                                                   :comment {:comment ""
                                                                                             :extension_attributes {}
                                                                                             :is_visible_on_front 0}
                                                                                   :items [{:extension_attributes {}
                                                                                            :order_item_id 0
                                                                                            :qty ""}]
                                                                                   :notify false}})
require "http/client"

url = "{{baseUrl}}/V1/order/:orderId/refund"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": 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}}/V1/order/:orderId/refund"),
    Content = new StringContent("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": 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}}/V1/order/:orderId/refund");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/order/:orderId/refund"

	payload := strings.NewReader("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/order/:orderId/refund HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 434

{
  "appendComment": false,
  "arguments": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "extension_attributes": {
      "return_to_stock_items": []
    },
    "shipping_amount": ""
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/order/:orderId/refund")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/order/:orderId/refund"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": 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  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/order/:orderId/refund")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/order/:orderId/refund")
  .header("content-type", "application/json")
  .body("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}")
  .asString();
const data = JSON.stringify({
  appendComment: false,
  arguments: {
    adjustment_negative: '',
    adjustment_positive: '',
    extension_attributes: {
      return_to_stock_items: []
    },
    shipping_amount: ''
  },
  comment: {
    comment: '',
    extension_attributes: {},
    is_visible_on_front: 0
  },
  items: [
    {
      extension_attributes: {},
      order_item_id: 0,
      qty: ''
    }
  ],
  notify: 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}}/V1/order/:orderId/refund');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/order/:orderId/refund',
  headers: {'content-type': 'application/json'},
  data: {
    appendComment: false,
    arguments: {
      adjustment_negative: '',
      adjustment_positive: '',
      extension_attributes: {return_to_stock_items: []},
      shipping_amount: ''
    },
    comment: {comment: '', extension_attributes: {}, is_visible_on_front: 0},
    items: [{extension_attributes: {}, order_item_id: 0, qty: ''}],
    notify: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/order/:orderId/refund';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"appendComment":false,"arguments":{"adjustment_negative":"","adjustment_positive":"","extension_attributes":{"return_to_stock_items":[]},"shipping_amount":""},"comment":{"comment":"","extension_attributes":{},"is_visible_on_front":0},"items":[{"extension_attributes":{},"order_item_id":0,"qty":""}],"notify":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}}/V1/order/:orderId/refund',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "appendComment": false,\n  "arguments": {\n    "adjustment_negative": "",\n    "adjustment_positive": "",\n    "extension_attributes": {\n      "return_to_stock_items": []\n    },\n    "shipping_amount": ""\n  },\n  "comment": {\n    "comment": "",\n    "extension_attributes": {},\n    "is_visible_on_front": 0\n  },\n  "items": [\n    {\n      "extension_attributes": {},\n      "order_item_id": 0,\n      "qty": ""\n    }\n  ],\n  "notify": 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  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/order/:orderId/refund")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/order/:orderId/refund',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  appendComment: false,
  arguments: {
    adjustment_negative: '',
    adjustment_positive: '',
    extension_attributes: {return_to_stock_items: []},
    shipping_amount: ''
  },
  comment: {comment: '', extension_attributes: {}, is_visible_on_front: 0},
  items: [{extension_attributes: {}, order_item_id: 0, qty: ''}],
  notify: false
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/order/:orderId/refund',
  headers: {'content-type': 'application/json'},
  body: {
    appendComment: false,
    arguments: {
      adjustment_negative: '',
      adjustment_positive: '',
      extension_attributes: {return_to_stock_items: []},
      shipping_amount: ''
    },
    comment: {comment: '', extension_attributes: {}, is_visible_on_front: 0},
    items: [{extension_attributes: {}, order_item_id: 0, qty: ''}],
    notify: 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}}/V1/order/:orderId/refund');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  appendComment: false,
  arguments: {
    adjustment_negative: '',
    adjustment_positive: '',
    extension_attributes: {
      return_to_stock_items: []
    },
    shipping_amount: ''
  },
  comment: {
    comment: '',
    extension_attributes: {},
    is_visible_on_front: 0
  },
  items: [
    {
      extension_attributes: {},
      order_item_id: 0,
      qty: ''
    }
  ],
  notify: 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}}/V1/order/:orderId/refund',
  headers: {'content-type': 'application/json'},
  data: {
    appendComment: false,
    arguments: {
      adjustment_negative: '',
      adjustment_positive: '',
      extension_attributes: {return_to_stock_items: []},
      shipping_amount: ''
    },
    comment: {comment: '', extension_attributes: {}, is_visible_on_front: 0},
    items: [{extension_attributes: {}, order_item_id: 0, qty: ''}],
    notify: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/order/:orderId/refund';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"appendComment":false,"arguments":{"adjustment_negative":"","adjustment_positive":"","extension_attributes":{"return_to_stock_items":[]},"shipping_amount":""},"comment":{"comment":"","extension_attributes":{},"is_visible_on_front":0},"items":[{"extension_attributes":{},"order_item_id":0,"qty":""}],"notify":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"appendComment": @NO,
                              @"arguments": @{ @"adjustment_negative": @"", @"adjustment_positive": @"", @"extension_attributes": @{ @"return_to_stock_items": @[  ] }, @"shipping_amount": @"" },
                              @"comment": @{ @"comment": @"", @"extension_attributes": @{  }, @"is_visible_on_front": @0 },
                              @"items": @[ @{ @"extension_attributes": @{  }, @"order_item_id": @0, @"qty": @"" } ],
                              @"notify": @NO };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/order/:orderId/refund"]
                                                       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}}/V1/order/:orderId/refund" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/order/:orderId/refund",
  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([
    'appendComment' => null,
    'arguments' => [
        'adjustment_negative' => '',
        'adjustment_positive' => '',
        'extension_attributes' => [
                'return_to_stock_items' => [
                                
                ]
        ],
        'shipping_amount' => ''
    ],
    'comment' => [
        'comment' => '',
        'extension_attributes' => [
                
        ],
        'is_visible_on_front' => 0
    ],
    'items' => [
        [
                'extension_attributes' => [
                                
                ],
                'order_item_id' => 0,
                'qty' => ''
        ]
    ],
    'notify' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/order/:orderId/refund', [
  'body' => '{
  "appendComment": false,
  "arguments": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "extension_attributes": {
      "return_to_stock_items": []
    },
    "shipping_amount": ""
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/order/:orderId/refund');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'appendComment' => null,
  'arguments' => [
    'adjustment_negative' => '',
    'adjustment_positive' => '',
    'extension_attributes' => [
        'return_to_stock_items' => [
                
        ]
    ],
    'shipping_amount' => ''
  ],
  'comment' => [
    'comment' => '',
    'extension_attributes' => [
        
    ],
    'is_visible_on_front' => 0
  ],
  'items' => [
    [
        'extension_attributes' => [
                
        ],
        'order_item_id' => 0,
        'qty' => ''
    ]
  ],
  'notify' => null
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'appendComment' => null,
  'arguments' => [
    'adjustment_negative' => '',
    'adjustment_positive' => '',
    'extension_attributes' => [
        'return_to_stock_items' => [
                
        ]
    ],
    'shipping_amount' => ''
  ],
  'comment' => [
    'comment' => '',
    'extension_attributes' => [
        
    ],
    'is_visible_on_front' => 0
  ],
  'items' => [
    [
        'extension_attributes' => [
                
        ],
        'order_item_id' => 0,
        'qty' => ''
    ]
  ],
  'notify' => null
]));
$request->setRequestUrl('{{baseUrl}}/V1/order/:orderId/refund');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/order/:orderId/refund' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "appendComment": false,
  "arguments": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "extension_attributes": {
      "return_to_stock_items": []
    },
    "shipping_amount": ""
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/order/:orderId/refund' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "appendComment": false,
  "arguments": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "extension_attributes": {
      "return_to_stock_items": []
    },
    "shipping_amount": ""
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/order/:orderId/refund", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/order/:orderId/refund"

payload = {
    "appendComment": False,
    "arguments": {
        "adjustment_negative": "",
        "adjustment_positive": "",
        "extension_attributes": { "return_to_stock_items": [] },
        "shipping_amount": ""
    },
    "comment": {
        "comment": "",
        "extension_attributes": {},
        "is_visible_on_front": 0
    },
    "items": [
        {
            "extension_attributes": {},
            "order_item_id": 0,
            "qty": ""
        }
    ],
    "notify": False
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/order/:orderId/refund"

payload <- "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/order/:orderId/refund")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": 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/V1/order/:orderId/refund') do |req|
  req.body = "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"extension_attributes\": {\n      \"return_to_stock_items\": []\n    },\n    \"shipping_amount\": \"\"\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/order/:orderId/refund";

    let payload = json!({
        "appendComment": false,
        "arguments": json!({
            "adjustment_negative": "",
            "adjustment_positive": "",
            "extension_attributes": json!({"return_to_stock_items": ()}),
            "shipping_amount": ""
        }),
        "comment": json!({
            "comment": "",
            "extension_attributes": json!({}),
            "is_visible_on_front": 0
        }),
        "items": (
            json!({
                "extension_attributes": json!({}),
                "order_item_id": 0,
                "qty": ""
            })
        ),
        "notify": false
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/order/:orderId/refund \
  --header 'content-type: application/json' \
  --data '{
  "appendComment": false,
  "arguments": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "extension_attributes": {
      "return_to_stock_items": []
    },
    "shipping_amount": ""
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}'
echo '{
  "appendComment": false,
  "arguments": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "extension_attributes": {
      "return_to_stock_items": []
    },
    "shipping_amount": ""
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false
}' |  \
  http POST {{baseUrl}}/V1/order/:orderId/refund \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "appendComment": false,\n  "arguments": {\n    "adjustment_negative": "",\n    "adjustment_positive": "",\n    "extension_attributes": {\n      "return_to_stock_items": []\n    },\n    "shipping_amount": ""\n  },\n  "comment": {\n    "comment": "",\n    "extension_attributes": {},\n    "is_visible_on_front": 0\n  },\n  "items": [\n    {\n      "extension_attributes": {},\n      "order_item_id": 0,\n      "qty": ""\n    }\n  ],\n  "notify": false\n}' \
  --output-document \
  - {{baseUrl}}/V1/order/:orderId/refund
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "appendComment": false,
  "arguments": [
    "adjustment_negative": "",
    "adjustment_positive": "",
    "extension_attributes": ["return_to_stock_items": []],
    "shipping_amount": ""
  ],
  "comment": [
    "comment": "",
    "extension_attributes": [],
    "is_visible_on_front": 0
  ],
  "items": [
    [
      "extension_attributes": [],
      "order_item_id": 0,
      "qty": ""
    ]
  ],
  "notify": false
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/order/:orderId/refund")! 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 order-{orderId}-ship
{{baseUrl}}/V1/order/:orderId/ship
QUERY PARAMS

orderId
BODY json

{
  "appendComment": false,
  "arguments": {
    "extension_attributes": {
      "ext_location_id": "",
      "ext_return_shipment_id": "",
      "ext_shipment_id": "",
      "ext_tracking_reference": "",
      "ext_tracking_url": "",
      "shipping_label": ""
    }
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false,
  "packages": [
    {
      "extension_attributes": {}
    }
  ],
  "tracks": [
    {
      "carrier_code": "",
      "extension_attributes": {},
      "title": "",
      "track_number": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/order/:orderId/ship");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\",\n      \"shipping_label\": \"\"\n    }\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false,\n  \"packages\": [\n    {\n      \"extension_attributes\": {}\n    }\n  ],\n  \"tracks\": [\n    {\n      \"carrier_code\": \"\",\n      \"extension_attributes\": {},\n      \"title\": \"\",\n      \"track_number\": \"\"\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/order/:orderId/ship" {:content-type :json
                                                                   :form-params {:appendComment false
                                                                                 :arguments {:extension_attributes {:ext_location_id ""
                                                                                                                    :ext_return_shipment_id ""
                                                                                                                    :ext_shipment_id ""
                                                                                                                    :ext_tracking_reference ""
                                                                                                                    :ext_tracking_url ""
                                                                                                                    :shipping_label ""}}
                                                                                 :comment {:comment ""
                                                                                           :extension_attributes {}
                                                                                           :is_visible_on_front 0}
                                                                                 :items [{:extension_attributes {}
                                                                                          :order_item_id 0
                                                                                          :qty ""}]
                                                                                 :notify false
                                                                                 :packages [{:extension_attributes {}}]
                                                                                 :tracks [{:carrier_code ""
                                                                                           :extension_attributes {}
                                                                                           :title ""
                                                                                           :track_number ""}]}})
require "http/client"

url = "{{baseUrl}}/V1/order/:orderId/ship"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\",\n      \"shipping_label\": \"\"\n    }\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false,\n  \"packages\": [\n    {\n      \"extension_attributes\": {}\n    }\n  ],\n  \"tracks\": [\n    {\n      \"carrier_code\": \"\",\n      \"extension_attributes\": {},\n      \"title\": \"\",\n      \"track_number\": \"\"\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}}/V1/order/:orderId/ship"),
    Content = new StringContent("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\",\n      \"shipping_label\": \"\"\n    }\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false,\n  \"packages\": [\n    {\n      \"extension_attributes\": {}\n    }\n  ],\n  \"tracks\": [\n    {\n      \"carrier_code\": \"\",\n      \"extension_attributes\": {},\n      \"title\": \"\",\n      \"track_number\": \"\"\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}}/V1/order/:orderId/ship");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\",\n      \"shipping_label\": \"\"\n    }\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false,\n  \"packages\": [\n    {\n      \"extension_attributes\": {}\n    }\n  ],\n  \"tracks\": [\n    {\n      \"carrier_code\": \"\",\n      \"extension_attributes\": {},\n      \"title\": \"\",\n      \"track_number\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/order/:orderId/ship"

	payload := strings.NewReader("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\",\n      \"shipping_label\": \"\"\n    }\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false,\n  \"packages\": [\n    {\n      \"extension_attributes\": {}\n    }\n  ],\n  \"tracks\": [\n    {\n      \"carrier_code\": \"\",\n      \"extension_attributes\": {},\n      \"title\": \"\",\n      \"track_number\": \"\"\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/order/:orderId/ship HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 699

{
  "appendComment": false,
  "arguments": {
    "extension_attributes": {
      "ext_location_id": "",
      "ext_return_shipment_id": "",
      "ext_shipment_id": "",
      "ext_tracking_reference": "",
      "ext_tracking_url": "",
      "shipping_label": ""
    }
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false,
  "packages": [
    {
      "extension_attributes": {}
    }
  ],
  "tracks": [
    {
      "carrier_code": "",
      "extension_attributes": {},
      "title": "",
      "track_number": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/order/:orderId/ship")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\",\n      \"shipping_label\": \"\"\n    }\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false,\n  \"packages\": [\n    {\n      \"extension_attributes\": {}\n    }\n  ],\n  \"tracks\": [\n    {\n      \"carrier_code\": \"\",\n      \"extension_attributes\": {},\n      \"title\": \"\",\n      \"track_number\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/order/:orderId/ship"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\",\n      \"shipping_label\": \"\"\n    }\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false,\n  \"packages\": [\n    {\n      \"extension_attributes\": {}\n    }\n  ],\n  \"tracks\": [\n    {\n      \"carrier_code\": \"\",\n      \"extension_attributes\": {},\n      \"title\": \"\",\n      \"track_number\": \"\"\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  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\",\n      \"shipping_label\": \"\"\n    }\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false,\n  \"packages\": [\n    {\n      \"extension_attributes\": {}\n    }\n  ],\n  \"tracks\": [\n    {\n      \"carrier_code\": \"\",\n      \"extension_attributes\": {},\n      \"title\": \"\",\n      \"track_number\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/order/:orderId/ship")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/order/:orderId/ship")
  .header("content-type", "application/json")
  .body("{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\",\n      \"shipping_label\": \"\"\n    }\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false,\n  \"packages\": [\n    {\n      \"extension_attributes\": {}\n    }\n  ],\n  \"tracks\": [\n    {\n      \"carrier_code\": \"\",\n      \"extension_attributes\": {},\n      \"title\": \"\",\n      \"track_number\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  appendComment: false,
  arguments: {
    extension_attributes: {
      ext_location_id: '',
      ext_return_shipment_id: '',
      ext_shipment_id: '',
      ext_tracking_reference: '',
      ext_tracking_url: '',
      shipping_label: ''
    }
  },
  comment: {
    comment: '',
    extension_attributes: {},
    is_visible_on_front: 0
  },
  items: [
    {
      extension_attributes: {},
      order_item_id: 0,
      qty: ''
    }
  ],
  notify: false,
  packages: [
    {
      extension_attributes: {}
    }
  ],
  tracks: [
    {
      carrier_code: '',
      extension_attributes: {},
      title: '',
      track_number: ''
    }
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/order/:orderId/ship');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/order/:orderId/ship',
  headers: {'content-type': 'application/json'},
  data: {
    appendComment: false,
    arguments: {
      extension_attributes: {
        ext_location_id: '',
        ext_return_shipment_id: '',
        ext_shipment_id: '',
        ext_tracking_reference: '',
        ext_tracking_url: '',
        shipping_label: ''
      }
    },
    comment: {comment: '', extension_attributes: {}, is_visible_on_front: 0},
    items: [{extension_attributes: {}, order_item_id: 0, qty: ''}],
    notify: false,
    packages: [{extension_attributes: {}}],
    tracks: [{carrier_code: '', extension_attributes: {}, title: '', track_number: ''}]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/order/:orderId/ship';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"appendComment":false,"arguments":{"extension_attributes":{"ext_location_id":"","ext_return_shipment_id":"","ext_shipment_id":"","ext_tracking_reference":"","ext_tracking_url":"","shipping_label":""}},"comment":{"comment":"","extension_attributes":{},"is_visible_on_front":0},"items":[{"extension_attributes":{},"order_item_id":0,"qty":""}],"notify":false,"packages":[{"extension_attributes":{}}],"tracks":[{"carrier_code":"","extension_attributes":{},"title":"","track_number":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/order/:orderId/ship',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "appendComment": false,\n  "arguments": {\n    "extension_attributes": {\n      "ext_location_id": "",\n      "ext_return_shipment_id": "",\n      "ext_shipment_id": "",\n      "ext_tracking_reference": "",\n      "ext_tracking_url": "",\n      "shipping_label": ""\n    }\n  },\n  "comment": {\n    "comment": "",\n    "extension_attributes": {},\n    "is_visible_on_front": 0\n  },\n  "items": [\n    {\n      "extension_attributes": {},\n      "order_item_id": 0,\n      "qty": ""\n    }\n  ],\n  "notify": false,\n  "packages": [\n    {\n      "extension_attributes": {}\n    }\n  ],\n  "tracks": [\n    {\n      "carrier_code": "",\n      "extension_attributes": {},\n      "title": "",\n      "track_number": ""\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  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\",\n      \"shipping_label\": \"\"\n    }\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false,\n  \"packages\": [\n    {\n      \"extension_attributes\": {}\n    }\n  ],\n  \"tracks\": [\n    {\n      \"carrier_code\": \"\",\n      \"extension_attributes\": {},\n      \"title\": \"\",\n      \"track_number\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/order/:orderId/ship")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/order/:orderId/ship',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  appendComment: false,
  arguments: {
    extension_attributes: {
      ext_location_id: '',
      ext_return_shipment_id: '',
      ext_shipment_id: '',
      ext_tracking_reference: '',
      ext_tracking_url: '',
      shipping_label: ''
    }
  },
  comment: {comment: '', extension_attributes: {}, is_visible_on_front: 0},
  items: [{extension_attributes: {}, order_item_id: 0, qty: ''}],
  notify: false,
  packages: [{extension_attributes: {}}],
  tracks: [{carrier_code: '', extension_attributes: {}, title: '', track_number: ''}]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/order/:orderId/ship',
  headers: {'content-type': 'application/json'},
  body: {
    appendComment: false,
    arguments: {
      extension_attributes: {
        ext_location_id: '',
        ext_return_shipment_id: '',
        ext_shipment_id: '',
        ext_tracking_reference: '',
        ext_tracking_url: '',
        shipping_label: ''
      }
    },
    comment: {comment: '', extension_attributes: {}, is_visible_on_front: 0},
    items: [{extension_attributes: {}, order_item_id: 0, qty: ''}],
    notify: false,
    packages: [{extension_attributes: {}}],
    tracks: [{carrier_code: '', extension_attributes: {}, title: '', track_number: ''}]
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/order/:orderId/ship');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  appendComment: false,
  arguments: {
    extension_attributes: {
      ext_location_id: '',
      ext_return_shipment_id: '',
      ext_shipment_id: '',
      ext_tracking_reference: '',
      ext_tracking_url: '',
      shipping_label: ''
    }
  },
  comment: {
    comment: '',
    extension_attributes: {},
    is_visible_on_front: 0
  },
  items: [
    {
      extension_attributes: {},
      order_item_id: 0,
      qty: ''
    }
  ],
  notify: false,
  packages: [
    {
      extension_attributes: {}
    }
  ],
  tracks: [
    {
      carrier_code: '',
      extension_attributes: {},
      title: '',
      track_number: ''
    }
  ]
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/order/:orderId/ship',
  headers: {'content-type': 'application/json'},
  data: {
    appendComment: false,
    arguments: {
      extension_attributes: {
        ext_location_id: '',
        ext_return_shipment_id: '',
        ext_shipment_id: '',
        ext_tracking_reference: '',
        ext_tracking_url: '',
        shipping_label: ''
      }
    },
    comment: {comment: '', extension_attributes: {}, is_visible_on_front: 0},
    items: [{extension_attributes: {}, order_item_id: 0, qty: ''}],
    notify: false,
    packages: [{extension_attributes: {}}],
    tracks: [{carrier_code: '', extension_attributes: {}, title: '', track_number: ''}]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/order/:orderId/ship';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"appendComment":false,"arguments":{"extension_attributes":{"ext_location_id":"","ext_return_shipment_id":"","ext_shipment_id":"","ext_tracking_reference":"","ext_tracking_url":"","shipping_label":""}},"comment":{"comment":"","extension_attributes":{},"is_visible_on_front":0},"items":[{"extension_attributes":{},"order_item_id":0,"qty":""}],"notify":false,"packages":[{"extension_attributes":{}}],"tracks":[{"carrier_code":"","extension_attributes":{},"title":"","track_number":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"appendComment": @NO,
                              @"arguments": @{ @"extension_attributes": @{ @"ext_location_id": @"", @"ext_return_shipment_id": @"", @"ext_shipment_id": @"", @"ext_tracking_reference": @"", @"ext_tracking_url": @"", @"shipping_label": @"" } },
                              @"comment": @{ @"comment": @"", @"extension_attributes": @{  }, @"is_visible_on_front": @0 },
                              @"items": @[ @{ @"extension_attributes": @{  }, @"order_item_id": @0, @"qty": @"" } ],
                              @"notify": @NO,
                              @"packages": @[ @{ @"extension_attributes": @{  } } ],
                              @"tracks": @[ @{ @"carrier_code": @"", @"extension_attributes": @{  }, @"title": @"", @"track_number": @"" } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/order/:orderId/ship"]
                                                       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}}/V1/order/:orderId/ship" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\",\n      \"shipping_label\": \"\"\n    }\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false,\n  \"packages\": [\n    {\n      \"extension_attributes\": {}\n    }\n  ],\n  \"tracks\": [\n    {\n      \"carrier_code\": \"\",\n      \"extension_attributes\": {},\n      \"title\": \"\",\n      \"track_number\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/order/:orderId/ship",
  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([
    'appendComment' => null,
    'arguments' => [
        'extension_attributes' => [
                'ext_location_id' => '',
                'ext_return_shipment_id' => '',
                'ext_shipment_id' => '',
                'ext_tracking_reference' => '',
                'ext_tracking_url' => '',
                'shipping_label' => ''
        ]
    ],
    'comment' => [
        'comment' => '',
        'extension_attributes' => [
                
        ],
        'is_visible_on_front' => 0
    ],
    'items' => [
        [
                'extension_attributes' => [
                                
                ],
                'order_item_id' => 0,
                'qty' => ''
        ]
    ],
    'notify' => null,
    'packages' => [
        [
                'extension_attributes' => [
                                
                ]
        ]
    ],
    'tracks' => [
        [
                'carrier_code' => '',
                'extension_attributes' => [
                                
                ],
                'title' => '',
                'track_number' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/order/:orderId/ship', [
  'body' => '{
  "appendComment": false,
  "arguments": {
    "extension_attributes": {
      "ext_location_id": "",
      "ext_return_shipment_id": "",
      "ext_shipment_id": "",
      "ext_tracking_reference": "",
      "ext_tracking_url": "",
      "shipping_label": ""
    }
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false,
  "packages": [
    {
      "extension_attributes": {}
    }
  ],
  "tracks": [
    {
      "carrier_code": "",
      "extension_attributes": {},
      "title": "",
      "track_number": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/order/:orderId/ship');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'appendComment' => null,
  'arguments' => [
    'extension_attributes' => [
        'ext_location_id' => '',
        'ext_return_shipment_id' => '',
        'ext_shipment_id' => '',
        'ext_tracking_reference' => '',
        'ext_tracking_url' => '',
        'shipping_label' => ''
    ]
  ],
  'comment' => [
    'comment' => '',
    'extension_attributes' => [
        
    ],
    'is_visible_on_front' => 0
  ],
  'items' => [
    [
        'extension_attributes' => [
                
        ],
        'order_item_id' => 0,
        'qty' => ''
    ]
  ],
  'notify' => null,
  'packages' => [
    [
        'extension_attributes' => [
                
        ]
    ]
  ],
  'tracks' => [
    [
        'carrier_code' => '',
        'extension_attributes' => [
                
        ],
        'title' => '',
        'track_number' => ''
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'appendComment' => null,
  'arguments' => [
    'extension_attributes' => [
        'ext_location_id' => '',
        'ext_return_shipment_id' => '',
        'ext_shipment_id' => '',
        'ext_tracking_reference' => '',
        'ext_tracking_url' => '',
        'shipping_label' => ''
    ]
  ],
  'comment' => [
    'comment' => '',
    'extension_attributes' => [
        
    ],
    'is_visible_on_front' => 0
  ],
  'items' => [
    [
        'extension_attributes' => [
                
        ],
        'order_item_id' => 0,
        'qty' => ''
    ]
  ],
  'notify' => null,
  'packages' => [
    [
        'extension_attributes' => [
                
        ]
    ]
  ],
  'tracks' => [
    [
        'carrier_code' => '',
        'extension_attributes' => [
                
        ],
        'title' => '',
        'track_number' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/order/:orderId/ship');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/order/:orderId/ship' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "appendComment": false,
  "arguments": {
    "extension_attributes": {
      "ext_location_id": "",
      "ext_return_shipment_id": "",
      "ext_shipment_id": "",
      "ext_tracking_reference": "",
      "ext_tracking_url": "",
      "shipping_label": ""
    }
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false,
  "packages": [
    {
      "extension_attributes": {}
    }
  ],
  "tracks": [
    {
      "carrier_code": "",
      "extension_attributes": {},
      "title": "",
      "track_number": ""
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/order/:orderId/ship' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "appendComment": false,
  "arguments": {
    "extension_attributes": {
      "ext_location_id": "",
      "ext_return_shipment_id": "",
      "ext_shipment_id": "",
      "ext_tracking_reference": "",
      "ext_tracking_url": "",
      "shipping_label": ""
    }
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false,
  "packages": [
    {
      "extension_attributes": {}
    }
  ],
  "tracks": [
    {
      "carrier_code": "",
      "extension_attributes": {},
      "title": "",
      "track_number": ""
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\",\n      \"shipping_label\": \"\"\n    }\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false,\n  \"packages\": [\n    {\n      \"extension_attributes\": {}\n    }\n  ],\n  \"tracks\": [\n    {\n      \"carrier_code\": \"\",\n      \"extension_attributes\": {},\n      \"title\": \"\",\n      \"track_number\": \"\"\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/order/:orderId/ship", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/order/:orderId/ship"

payload = {
    "appendComment": False,
    "arguments": { "extension_attributes": {
            "ext_location_id": "",
            "ext_return_shipment_id": "",
            "ext_shipment_id": "",
            "ext_tracking_reference": "",
            "ext_tracking_url": "",
            "shipping_label": ""
        } },
    "comment": {
        "comment": "",
        "extension_attributes": {},
        "is_visible_on_front": 0
    },
    "items": [
        {
            "extension_attributes": {},
            "order_item_id": 0,
            "qty": ""
        }
    ],
    "notify": False,
    "packages": [{ "extension_attributes": {} }],
    "tracks": [
        {
            "carrier_code": "",
            "extension_attributes": {},
            "title": "",
            "track_number": ""
        }
    ]
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/order/:orderId/ship"

payload <- "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\",\n      \"shipping_label\": \"\"\n    }\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false,\n  \"packages\": [\n    {\n      \"extension_attributes\": {}\n    }\n  ],\n  \"tracks\": [\n    {\n      \"carrier_code\": \"\",\n      \"extension_attributes\": {},\n      \"title\": \"\",\n      \"track_number\": \"\"\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/order/:orderId/ship")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\",\n      \"shipping_label\": \"\"\n    }\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false,\n  \"packages\": [\n    {\n      \"extension_attributes\": {}\n    }\n  ],\n  \"tracks\": [\n    {\n      \"carrier_code\": \"\",\n      \"extension_attributes\": {},\n      \"title\": \"\",\n      \"track_number\": \"\"\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/V1/order/:orderId/ship') do |req|
  req.body = "{\n  \"appendComment\": false,\n  \"arguments\": {\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\",\n      \"shipping_label\": \"\"\n    }\n  },\n  \"comment\": {\n    \"comment\": \"\",\n    \"extension_attributes\": {},\n    \"is_visible_on_front\": 0\n  },\n  \"items\": [\n    {\n      \"extension_attributes\": {},\n      \"order_item_id\": 0,\n      \"qty\": \"\"\n    }\n  ],\n  \"notify\": false,\n  \"packages\": [\n    {\n      \"extension_attributes\": {}\n    }\n  ],\n  \"tracks\": [\n    {\n      \"carrier_code\": \"\",\n      \"extension_attributes\": {},\n      \"title\": \"\",\n      \"track_number\": \"\"\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}}/V1/order/:orderId/ship";

    let payload = json!({
        "appendComment": false,
        "arguments": json!({"extension_attributes": json!({
                "ext_location_id": "",
                "ext_return_shipment_id": "",
                "ext_shipment_id": "",
                "ext_tracking_reference": "",
                "ext_tracking_url": "",
                "shipping_label": ""
            })}),
        "comment": json!({
            "comment": "",
            "extension_attributes": json!({}),
            "is_visible_on_front": 0
        }),
        "items": (
            json!({
                "extension_attributes": json!({}),
                "order_item_id": 0,
                "qty": ""
            })
        ),
        "notify": false,
        "packages": (json!({"extension_attributes": json!({})})),
        "tracks": (
            json!({
                "carrier_code": "",
                "extension_attributes": json!({}),
                "title": "",
                "track_number": ""
            })
        )
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/order/:orderId/ship \
  --header 'content-type: application/json' \
  --data '{
  "appendComment": false,
  "arguments": {
    "extension_attributes": {
      "ext_location_id": "",
      "ext_return_shipment_id": "",
      "ext_shipment_id": "",
      "ext_tracking_reference": "",
      "ext_tracking_url": "",
      "shipping_label": ""
    }
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false,
  "packages": [
    {
      "extension_attributes": {}
    }
  ],
  "tracks": [
    {
      "carrier_code": "",
      "extension_attributes": {},
      "title": "",
      "track_number": ""
    }
  ]
}'
echo '{
  "appendComment": false,
  "arguments": {
    "extension_attributes": {
      "ext_location_id": "",
      "ext_return_shipment_id": "",
      "ext_shipment_id": "",
      "ext_tracking_reference": "",
      "ext_tracking_url": "",
      "shipping_label": ""
    }
  },
  "comment": {
    "comment": "",
    "extension_attributes": {},
    "is_visible_on_front": 0
  },
  "items": [
    {
      "extension_attributes": {},
      "order_item_id": 0,
      "qty": ""
    }
  ],
  "notify": false,
  "packages": [
    {
      "extension_attributes": {}
    }
  ],
  "tracks": [
    {
      "carrier_code": "",
      "extension_attributes": {},
      "title": "",
      "track_number": ""
    }
  ]
}' |  \
  http POST {{baseUrl}}/V1/order/:orderId/ship \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "appendComment": false,\n  "arguments": {\n    "extension_attributes": {\n      "ext_location_id": "",\n      "ext_return_shipment_id": "",\n      "ext_shipment_id": "",\n      "ext_tracking_reference": "",\n      "ext_tracking_url": "",\n      "shipping_label": ""\n    }\n  },\n  "comment": {\n    "comment": "",\n    "extension_attributes": {},\n    "is_visible_on_front": 0\n  },\n  "items": [\n    {\n      "extension_attributes": {},\n      "order_item_id": 0,\n      "qty": ""\n    }\n  ],\n  "notify": false,\n  "packages": [\n    {\n      "extension_attributes": {}\n    }\n  ],\n  "tracks": [\n    {\n      "carrier_code": "",\n      "extension_attributes": {},\n      "title": "",\n      "track_number": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/V1/order/:orderId/ship
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "appendComment": false,
  "arguments": ["extension_attributes": [
      "ext_location_id": "",
      "ext_return_shipment_id": "",
      "ext_shipment_id": "",
      "ext_tracking_reference": "",
      "ext_tracking_url": "",
      "shipping_label": ""
    ]],
  "comment": [
    "comment": "",
    "extension_attributes": [],
    "is_visible_on_front": 0
  ],
  "items": [
    [
      "extension_attributes": [],
      "order_item_id": 0,
      "qty": ""
    ]
  ],
  "notify": false,
  "packages": [["extension_attributes": []]],
  "tracks": [
    [
      "carrier_code": "",
      "extension_attributes": [],
      "title": "",
      "track_number": ""
    ]
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/order/:orderId/ship")! 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 orders
{{baseUrl}}/V1/orders
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/orders");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/orders")
require "http/client"

url = "{{baseUrl}}/V1/orders"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/orders"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/orders");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/orders"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/orders HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/orders")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/orders"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/orders")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/orders")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/orders');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/orders';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/orders',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/orders")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/orders',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/orders');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/orders';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/orders"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/orders" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/orders",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/orders');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/orders');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/orders');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/orders' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/orders' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/orders")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/orders"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/orders"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/orders")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/orders') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/orders";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/orders
http GET {{baseUrl}}/V1/orders
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/orders
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/orders")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST orders-
{{baseUrl}}/V1/orders/
BODY json

{
  "entity": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "applied_rule_ids": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_canceled": "",
    "base_discount_invoiced": "",
    "base_discount_refunded": "",
    "base_discount_tax_compensation_amount": "",
    "base_discount_tax_compensation_invoiced": "",
    "base_discount_tax_compensation_refunded": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_canceled": "",
    "base_shipping_discount_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_invoiced": "",
    "base_shipping_refunded": "",
    "base_shipping_tax_amount": "",
    "base_shipping_tax_refunded": "",
    "base_subtotal": "",
    "base_subtotal_canceled": "",
    "base_subtotal_incl_tax": "",
    "base_subtotal_invoiced": "",
    "base_subtotal_refunded": "",
    "base_tax_amount": "",
    "base_tax_canceled": "",
    "base_tax_invoiced": "",
    "base_tax_refunded": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_canceled": "",
    "base_total_due": "",
    "base_total_invoiced": "",
    "base_total_invoiced_cost": "",
    "base_total_offline_refunded": "",
    "base_total_online_refunded": "",
    "base_total_paid": "",
    "base_total_qty_ordered": "",
    "base_total_refunded": "",
    "billing_address": {
      "address_type": "",
      "city": "",
      "company": "",
      "country_id": "",
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "entity_id": 0,
      "extension_attributes": {
        "checkout_fields": [
          {
            "attribute_code": "",
            "value": ""
          }
        ]
      },
      "fax": "",
      "firstname": "",
      "lastname": "",
      "middlename": "",
      "parent_id": 0,
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": "",
      "vat_is_valid": 0,
      "vat_request_date": "",
      "vat_request_id": "",
      "vat_request_success": 0
    },
    "billing_address_id": 0,
    "can_ship_partially": 0,
    "can_ship_partially_item": 0,
    "coupon_code": "",
    "created_at": "",
    "customer_dob": "",
    "customer_email": "",
    "customer_firstname": "",
    "customer_gender": 0,
    "customer_group_id": 0,
    "customer_id": 0,
    "customer_is_guest": 0,
    "customer_lastname": "",
    "customer_middlename": "",
    "customer_note": "",
    "customer_note_notify": 0,
    "customer_prefix": "",
    "customer_suffix": "",
    "customer_taxvat": "",
    "discount_amount": "",
    "discount_canceled": "",
    "discount_description": "",
    "discount_invoiced": "",
    "discount_refunded": "",
    "discount_tax_compensation_amount": "",
    "discount_tax_compensation_invoiced": "",
    "discount_tax_compensation_refunded": "",
    "edit_increment": 0,
    "email_sent": 0,
    "entity_id": 0,
    "ext_customer_id": "",
    "ext_order_id": "",
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "applied_taxes": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "extension_attributes": {
            "rates": [
              {
                "code": "",
                "extension_attributes": {},
                "percent": "",
                "title": ""
              }
            ]
          },
          "percent": "",
          "title": ""
        }
      ],
      "base_customer_balance_amount": "",
      "base_customer_balance_invoiced": "",
      "base_customer_balance_refunded": "",
      "base_customer_balance_total_refunded": "",
      "base_gift_cards_amount": "",
      "base_gift_cards_invoiced": "",
      "base_gift_cards_refunded": "",
      "base_reward_currency_amount": "",
      "company_order_attributes": {
        "company_id": 0,
        "company_name": "",
        "extension_attributes": {},
        "order_id": 0
      },
      "converting_from_quote": false,
      "customer_balance_amount": "",
      "customer_balance_invoiced": "",
      "customer_balance_refunded": "",
      "customer_balance_total_refunded": "",
      "gift_cards": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "id": 0
        }
      ],
      "gift_cards_amount": "",
      "gift_cards_invoiced": "",
      "gift_cards_refunded": "",
      "gift_message": {
        "customer_id": 0,
        "extension_attributes": {
          "entity_id": "",
          "entity_type": "",
          "wrapping_add_printed_card": false,
          "wrapping_allow_gift_receipt": false,
          "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
      },
      "gw_add_card": "",
      "gw_allow_gift_receipt": "",
      "gw_base_price": "",
      "gw_base_price_incl_tax": "",
      "gw_base_price_invoiced": "",
      "gw_base_price_refunded": "",
      "gw_base_tax_amount": "",
      "gw_base_tax_amount_invoiced": "",
      "gw_base_tax_amount_refunded": "",
      "gw_card_base_price": "",
      "gw_card_base_price_incl_tax": "",
      "gw_card_base_price_invoiced": "",
      "gw_card_base_price_refunded": "",
      "gw_card_base_tax_amount": "",
      "gw_card_base_tax_invoiced": "",
      "gw_card_base_tax_refunded": "",
      "gw_card_price": "",
      "gw_card_price_incl_tax": "",
      "gw_card_price_invoiced": "",
      "gw_card_price_refunded": "",
      "gw_card_tax_amount": "",
      "gw_card_tax_invoiced": "",
      "gw_card_tax_refunded": "",
      "gw_id": "",
      "gw_items_base_price": "",
      "gw_items_base_price_incl_tax": "",
      "gw_items_base_price_invoiced": "",
      "gw_items_base_price_refunded": "",
      "gw_items_base_tax_amount": "",
      "gw_items_base_tax_invoiced": "",
      "gw_items_base_tax_refunded": "",
      "gw_items_price": "",
      "gw_items_price_incl_tax": "",
      "gw_items_price_invoiced": "",
      "gw_items_price_refunded": "",
      "gw_items_tax_amount": "",
      "gw_items_tax_invoiced": "",
      "gw_items_tax_refunded": "",
      "gw_price": "",
      "gw_price_incl_tax": "",
      "gw_price_invoiced": "",
      "gw_price_refunded": "",
      "gw_tax_amount": "",
      "gw_tax_amount_invoiced": "",
      "gw_tax_amount_refunded": "",
      "item_applied_taxes": [
        {
          "applied_taxes": [
            {}
          ],
          "associated_item_id": 0,
          "extension_attributes": {},
          "item_id": 0,
          "type": ""
        }
      ],
      "payment_additional_info": [
        {
          "key": "",
          "value": ""
        }
      ],
      "reward_currency_amount": "",
      "reward_points_balance": 0,
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "additional_data": "",
              "amount_refunded": "",
              "applied_rule_ids": "",
              "base_amount_refunded": "",
              "base_cost": "",
              "base_discount_amount": "",
              "base_discount_invoiced": "",
              "base_discount_refunded": "",
              "base_discount_tax_compensation_amount": "",
              "base_discount_tax_compensation_invoiced": "",
              "base_discount_tax_compensation_refunded": "",
              "base_original_price": "",
              "base_price": "",
              "base_price_incl_tax": "",
              "base_row_invoiced": "",
              "base_row_total": "",
              "base_row_total_incl_tax": "",
              "base_tax_amount": "",
              "base_tax_before_discount": "",
              "base_tax_invoiced": "",
              "base_tax_refunded": "",
              "base_weee_tax_applied_amount": "",
              "base_weee_tax_applied_row_amnt": "",
              "base_weee_tax_disposition": "",
              "base_weee_tax_row_disposition": "",
              "created_at": "",
              "description": "",
              "discount_amount": "",
              "discount_invoiced": "",
              "discount_percent": "",
              "discount_refunded": "",
              "discount_tax_compensation_amount": "",
              "discount_tax_compensation_canceled": "",
              "discount_tax_compensation_invoiced": "",
              "discount_tax_compensation_refunded": "",
              "event_id": 0,
              "ext_order_item_id": "",
              "extension_attributes": {
                "gift_message": {},
                "gw_base_price": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_id": "",
                "gw_price": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "invoice_text_codes": [],
                "tax_codes": [],
                "vertex_tax_codes": []
              },
              "free_shipping": 0,
              "gw_base_price": "",
              "gw_base_price_invoiced": "",
              "gw_base_price_refunded": "",
              "gw_base_tax_amount": "",
              "gw_base_tax_amount_invoiced": "",
              "gw_base_tax_amount_refunded": "",
              "gw_id": 0,
              "gw_price": "",
              "gw_price_invoiced": "",
              "gw_price_refunded": "",
              "gw_tax_amount": "",
              "gw_tax_amount_invoiced": "",
              "gw_tax_amount_refunded": "",
              "is_qty_decimal": 0,
              "is_virtual": 0,
              "item_id": 0,
              "locked_do_invoice": 0,
              "locked_do_ship": 0,
              "name": "",
              "no_discount": 0,
              "order_id": 0,
              "original_price": "",
              "parent_item": "",
              "parent_item_id": 0,
              "price": "",
              "price_incl_tax": "",
              "product_id": 0,
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty_backordered": "",
              "qty_canceled": "",
              "qty_invoiced": "",
              "qty_ordered": "",
              "qty_refunded": "",
              "qty_returned": "",
              "qty_shipped": "",
              "quote_item_id": 0,
              "row_invoiced": "",
              "row_total": "",
              "row_total_incl_tax": "",
              "row_weight": "",
              "sku": "",
              "store_id": 0,
              "tax_amount": "",
              "tax_before_discount": "",
              "tax_canceled": "",
              "tax_invoiced": "",
              "tax_percent": "",
              "tax_refunded": "",
              "updated_at": "",
              "weee_tax_applied": "",
              "weee_tax_applied_amount": "",
              "weee_tax_applied_row_amount": "",
              "weee_tax_disposition": "",
              "weee_tax_row_disposition": "",
              "weight": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {
              "collection_point": {
                "city": "",
                "collection_point_id": "",
                "country": "",
                "name": "",
                "postcode": "",
                "recipient_address_id": 0,
                "region": "",
                "street": []
              },
              "ext_order_id": "",
              "shipping_experience": {
                "code": "",
                "cost": "",
                "label": ""
              }
            },
            "method": "",
            "total": {
              "base_shipping_amount": "",
              "base_shipping_canceled": "",
              "base_shipping_discount_amount": "",
              "base_shipping_discount_tax_compensation_amnt": "",
              "base_shipping_incl_tax": "",
              "base_shipping_invoiced": "",
              "base_shipping_refunded": "",
              "base_shipping_tax_amount": "",
              "base_shipping_tax_refunded": "",
              "extension_attributes": {},
              "shipping_amount": "",
              "shipping_canceled": "",
              "shipping_discount_amount": "",
              "shipping_discount_tax_compensation_amount": "",
              "shipping_incl_tax": "",
              "shipping_invoiced": "",
              "shipping_refunded": "",
              "shipping_tax_amount": "",
              "shipping_tax_refunded": ""
            }
          },
          "stock_id": 0
        }
      ]
    },
    "forced_shipment_with_invoice": 0,
    "global_currency_code": "",
    "grand_total": "",
    "hold_before_state": "",
    "hold_before_status": "",
    "increment_id": "",
    "is_virtual": 0,
    "items": [
      {}
    ],
    "order_currency_code": "",
    "original_increment_id": "",
    "payment": {
      "account_status": "",
      "additional_data": "",
      "additional_information": [],
      "address_status": "",
      "amount_authorized": "",
      "amount_canceled": "",
      "amount_ordered": "",
      "amount_paid": "",
      "amount_refunded": "",
      "anet_trans_method": "",
      "base_amount_authorized": "",
      "base_amount_canceled": "",
      "base_amount_ordered": "",
      "base_amount_paid": "",
      "base_amount_paid_online": "",
      "base_amount_refunded": "",
      "base_amount_refunded_online": "",
      "base_shipping_amount": "",
      "base_shipping_captured": "",
      "base_shipping_refunded": "",
      "cc_approval": "",
      "cc_avs_status": "",
      "cc_cid_status": "",
      "cc_debug_request_body": "",
      "cc_debug_response_body": "",
      "cc_debug_response_serialized": "",
      "cc_exp_month": "",
      "cc_exp_year": "",
      "cc_last4": "",
      "cc_number_enc": "",
      "cc_owner": "",
      "cc_secure_verify": "",
      "cc_ss_issue": "",
      "cc_ss_start_month": "",
      "cc_ss_start_year": "",
      "cc_status": "",
      "cc_status_description": "",
      "cc_trans_id": "",
      "cc_type": "",
      "echeck_account_name": "",
      "echeck_account_type": "",
      "echeck_bank_name": "",
      "echeck_routing_number": "",
      "echeck_type": "",
      "entity_id": 0,
      "extension_attributes": {
        "vault_payment_token": {
          "created_at": "",
          "customer_id": 0,
          "entity_id": 0,
          "expires_at": "",
          "gateway_token": "",
          "is_active": false,
          "is_visible": false,
          "payment_method_code": "",
          "public_hash": "",
          "token_details": "",
          "type": ""
        }
      },
      "last_trans_id": "",
      "method": "",
      "parent_id": 0,
      "po_number": "",
      "protection_eligibility": "",
      "quote_payment_id": 0,
      "shipping_amount": "",
      "shipping_captured": "",
      "shipping_refunded": ""
    },
    "payment_auth_expiration": 0,
    "payment_authorization_amount": "",
    "protect_code": "",
    "quote_address_id": 0,
    "quote_id": 0,
    "relation_child_id": "",
    "relation_child_real_id": "",
    "relation_parent_id": "",
    "relation_parent_real_id": "",
    "remote_ip": "",
    "shipping_amount": "",
    "shipping_canceled": "",
    "shipping_description": "",
    "shipping_discount_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_invoiced": "",
    "shipping_refunded": "",
    "shipping_tax_amount": "",
    "shipping_tax_refunded": "",
    "state": "",
    "status": "",
    "status_histories": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "entity_name": "",
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0,
        "status": ""
      }
    ],
    "store_currency_code": "",
    "store_id": 0,
    "store_name": "",
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_canceled": "",
    "subtotal_incl_tax": "",
    "subtotal_invoiced": "",
    "subtotal_refunded": "",
    "tax_amount": "",
    "tax_canceled": "",
    "tax_invoiced": "",
    "tax_refunded": "",
    "total_canceled": "",
    "total_due": "",
    "total_invoiced": "",
    "total_item_count": 0,
    "total_offline_refunded": "",
    "total_online_refunded": "",
    "total_paid": "",
    "total_qty_ordered": "",
    "total_refunded": "",
    "updated_at": "",
    "weight": "",
    "x_forwarded_for": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/orders/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/orders/" {:content-type :json
                                                       :form-params {:entity {:adjustment_negative ""
                                                                              :adjustment_positive ""
                                                                              :applied_rule_ids ""
                                                                              :base_adjustment_negative ""
                                                                              :base_adjustment_positive ""
                                                                              :base_currency_code ""
                                                                              :base_discount_amount ""
                                                                              :base_discount_canceled ""
                                                                              :base_discount_invoiced ""
                                                                              :base_discount_refunded ""
                                                                              :base_discount_tax_compensation_amount ""
                                                                              :base_discount_tax_compensation_invoiced ""
                                                                              :base_discount_tax_compensation_refunded ""
                                                                              :base_grand_total ""
                                                                              :base_shipping_amount ""
                                                                              :base_shipping_canceled ""
                                                                              :base_shipping_discount_amount ""
                                                                              :base_shipping_discount_tax_compensation_amnt ""
                                                                              :base_shipping_incl_tax ""
                                                                              :base_shipping_invoiced ""
                                                                              :base_shipping_refunded ""
                                                                              :base_shipping_tax_amount ""
                                                                              :base_shipping_tax_refunded ""
                                                                              :base_subtotal ""
                                                                              :base_subtotal_canceled ""
                                                                              :base_subtotal_incl_tax ""
                                                                              :base_subtotal_invoiced ""
                                                                              :base_subtotal_refunded ""
                                                                              :base_tax_amount ""
                                                                              :base_tax_canceled ""
                                                                              :base_tax_invoiced ""
                                                                              :base_tax_refunded ""
                                                                              :base_to_global_rate ""
                                                                              :base_to_order_rate ""
                                                                              :base_total_canceled ""
                                                                              :base_total_due ""
                                                                              :base_total_invoiced ""
                                                                              :base_total_invoiced_cost ""
                                                                              :base_total_offline_refunded ""
                                                                              :base_total_online_refunded ""
                                                                              :base_total_paid ""
                                                                              :base_total_qty_ordered ""
                                                                              :base_total_refunded ""
                                                                              :billing_address {:address_type ""
                                                                                                :city ""
                                                                                                :company ""
                                                                                                :country_id ""
                                                                                                :customer_address_id 0
                                                                                                :customer_id 0
                                                                                                :email ""
                                                                                                :entity_id 0
                                                                                                :extension_attributes {:checkout_fields [{:attribute_code ""
                                                                                                                                          :value ""}]}
                                                                                                :fax ""
                                                                                                :firstname ""
                                                                                                :lastname ""
                                                                                                :middlename ""
                                                                                                :parent_id 0
                                                                                                :postcode ""
                                                                                                :prefix ""
                                                                                                :region ""
                                                                                                :region_code ""
                                                                                                :region_id 0
                                                                                                :street []
                                                                                                :suffix ""
                                                                                                :telephone ""
                                                                                                :vat_id ""
                                                                                                :vat_is_valid 0
                                                                                                :vat_request_date ""
                                                                                                :vat_request_id ""
                                                                                                :vat_request_success 0}
                                                                              :billing_address_id 0
                                                                              :can_ship_partially 0
                                                                              :can_ship_partially_item 0
                                                                              :coupon_code ""
                                                                              :created_at ""
                                                                              :customer_dob ""
                                                                              :customer_email ""
                                                                              :customer_firstname ""
                                                                              :customer_gender 0
                                                                              :customer_group_id 0
                                                                              :customer_id 0
                                                                              :customer_is_guest 0
                                                                              :customer_lastname ""
                                                                              :customer_middlename ""
                                                                              :customer_note ""
                                                                              :customer_note_notify 0
                                                                              :customer_prefix ""
                                                                              :customer_suffix ""
                                                                              :customer_taxvat ""
                                                                              :discount_amount ""
                                                                              :discount_canceled ""
                                                                              :discount_description ""
                                                                              :discount_invoiced ""
                                                                              :discount_refunded ""
                                                                              :discount_tax_compensation_amount ""
                                                                              :discount_tax_compensation_invoiced ""
                                                                              :discount_tax_compensation_refunded ""
                                                                              :edit_increment 0
                                                                              :email_sent 0
                                                                              :entity_id 0
                                                                              :ext_customer_id ""
                                                                              :ext_order_id ""
                                                                              :extension_attributes {:amazon_order_reference_id ""
                                                                                                     :applied_taxes [{:amount ""
                                                                                                                      :base_amount ""
                                                                                                                      :code ""
                                                                                                                      :extension_attributes {:rates [{:code ""
                                                                                                                                                      :extension_attributes {}
                                                                                                                                                      :percent ""
                                                                                                                                                      :title ""}]}
                                                                                                                      :percent ""
                                                                                                                      :title ""}]
                                                                                                     :base_customer_balance_amount ""
                                                                                                     :base_customer_balance_invoiced ""
                                                                                                     :base_customer_balance_refunded ""
                                                                                                     :base_customer_balance_total_refunded ""
                                                                                                     :base_gift_cards_amount ""
                                                                                                     :base_gift_cards_invoiced ""
                                                                                                     :base_gift_cards_refunded ""
                                                                                                     :base_reward_currency_amount ""
                                                                                                     :company_order_attributes {:company_id 0
                                                                                                                                :company_name ""
                                                                                                                                :extension_attributes {}
                                                                                                                                :order_id 0}
                                                                                                     :converting_from_quote false
                                                                                                     :customer_balance_amount ""
                                                                                                     :customer_balance_invoiced ""
                                                                                                     :customer_balance_refunded ""
                                                                                                     :customer_balance_total_refunded ""
                                                                                                     :gift_cards [{:amount ""
                                                                                                                   :base_amount ""
                                                                                                                   :code ""
                                                                                                                   :id 0}]
                                                                                                     :gift_cards_amount ""
                                                                                                     :gift_cards_invoiced ""
                                                                                                     :gift_cards_refunded ""
                                                                                                     :gift_message {:customer_id 0
                                                                                                                    :extension_attributes {:entity_id ""
                                                                                                                                           :entity_type ""
                                                                                                                                           :wrapping_add_printed_card false
                                                                                                                                           :wrapping_allow_gift_receipt false
                                                                                                                                           :wrapping_id 0}
                                                                                                                    :gift_message_id 0
                                                                                                                    :message ""
                                                                                                                    :recipient ""
                                                                                                                    :sender ""}
                                                                                                     :gw_add_card ""
                                                                                                     :gw_allow_gift_receipt ""
                                                                                                     :gw_base_price ""
                                                                                                     :gw_base_price_incl_tax ""
                                                                                                     :gw_base_price_invoiced ""
                                                                                                     :gw_base_price_refunded ""
                                                                                                     :gw_base_tax_amount ""
                                                                                                     :gw_base_tax_amount_invoiced ""
                                                                                                     :gw_base_tax_amount_refunded ""
                                                                                                     :gw_card_base_price ""
                                                                                                     :gw_card_base_price_incl_tax ""
                                                                                                     :gw_card_base_price_invoiced ""
                                                                                                     :gw_card_base_price_refunded ""
                                                                                                     :gw_card_base_tax_amount ""
                                                                                                     :gw_card_base_tax_invoiced ""
                                                                                                     :gw_card_base_tax_refunded ""
                                                                                                     :gw_card_price ""
                                                                                                     :gw_card_price_incl_tax ""
                                                                                                     :gw_card_price_invoiced ""
                                                                                                     :gw_card_price_refunded ""
                                                                                                     :gw_card_tax_amount ""
                                                                                                     :gw_card_tax_invoiced ""
                                                                                                     :gw_card_tax_refunded ""
                                                                                                     :gw_id ""
                                                                                                     :gw_items_base_price ""
                                                                                                     :gw_items_base_price_incl_tax ""
                                                                                                     :gw_items_base_price_invoiced ""
                                                                                                     :gw_items_base_price_refunded ""
                                                                                                     :gw_items_base_tax_amount ""
                                                                                                     :gw_items_base_tax_invoiced ""
                                                                                                     :gw_items_base_tax_refunded ""
                                                                                                     :gw_items_price ""
                                                                                                     :gw_items_price_incl_tax ""
                                                                                                     :gw_items_price_invoiced ""
                                                                                                     :gw_items_price_refunded ""
                                                                                                     :gw_items_tax_amount ""
                                                                                                     :gw_items_tax_invoiced ""
                                                                                                     :gw_items_tax_refunded ""
                                                                                                     :gw_price ""
                                                                                                     :gw_price_incl_tax ""
                                                                                                     :gw_price_invoiced ""
                                                                                                     :gw_price_refunded ""
                                                                                                     :gw_tax_amount ""
                                                                                                     :gw_tax_amount_invoiced ""
                                                                                                     :gw_tax_amount_refunded ""
                                                                                                     :item_applied_taxes [{:applied_taxes [{}]
                                                                                                                           :associated_item_id 0
                                                                                                                           :extension_attributes {}
                                                                                                                           :item_id 0
                                                                                                                           :type ""}]
                                                                                                     :payment_additional_info [{:key ""
                                                                                                                                :value ""}]
                                                                                                     :reward_currency_amount ""
                                                                                                     :reward_points_balance 0
                                                                                                     :shipping_assignments [{:extension_attributes {}
                                                                                                                             :items [{:additional_data ""
                                                                                                                                      :amount_refunded ""
                                                                                                                                      :applied_rule_ids ""
                                                                                                                                      :base_amount_refunded ""
                                                                                                                                      :base_cost ""
                                                                                                                                      :base_discount_amount ""
                                                                                                                                      :base_discount_invoiced ""
                                                                                                                                      :base_discount_refunded ""
                                                                                                                                      :base_discount_tax_compensation_amount ""
                                                                                                                                      :base_discount_tax_compensation_invoiced ""
                                                                                                                                      :base_discount_tax_compensation_refunded ""
                                                                                                                                      :base_original_price ""
                                                                                                                                      :base_price ""
                                                                                                                                      :base_price_incl_tax ""
                                                                                                                                      :base_row_invoiced ""
                                                                                                                                      :base_row_total ""
                                                                                                                                      :base_row_total_incl_tax ""
                                                                                                                                      :base_tax_amount ""
                                                                                                                                      :base_tax_before_discount ""
                                                                                                                                      :base_tax_invoiced ""
                                                                                                                                      :base_tax_refunded ""
                                                                                                                                      :base_weee_tax_applied_amount ""
                                                                                                                                      :base_weee_tax_applied_row_amnt ""
                                                                                                                                      :base_weee_tax_disposition ""
                                                                                                                                      :base_weee_tax_row_disposition ""
                                                                                                                                      :created_at ""
                                                                                                                                      :description ""
                                                                                                                                      :discount_amount ""
                                                                                                                                      :discount_invoiced ""
                                                                                                                                      :discount_percent ""
                                                                                                                                      :discount_refunded ""
                                                                                                                                      :discount_tax_compensation_amount ""
                                                                                                                                      :discount_tax_compensation_canceled ""
                                                                                                                                      :discount_tax_compensation_invoiced ""
                                                                                                                                      :discount_tax_compensation_refunded ""
                                                                                                                                      :event_id 0
                                                                                                                                      :ext_order_item_id ""
                                                                                                                                      :extension_attributes {:gift_message {}
                                                                                                                                                             :gw_base_price ""
                                                                                                                                                             :gw_base_price_invoiced ""
                                                                                                                                                             :gw_base_price_refunded ""
                                                                                                                                                             :gw_base_tax_amount ""
                                                                                                                                                             :gw_base_tax_amount_invoiced ""
                                                                                                                                                             :gw_base_tax_amount_refunded ""
                                                                                                                                                             :gw_id ""
                                                                                                                                                             :gw_price ""
                                                                                                                                                             :gw_price_invoiced ""
                                                                                                                                                             :gw_price_refunded ""
                                                                                                                                                             :gw_tax_amount ""
                                                                                                                                                             :gw_tax_amount_invoiced ""
                                                                                                                                                             :gw_tax_amount_refunded ""
                                                                                                                                                             :invoice_text_codes []
                                                                                                                                                             :tax_codes []
                                                                                                                                                             :vertex_tax_codes []}
                                                                                                                                      :free_shipping 0
                                                                                                                                      :gw_base_price ""
                                                                                                                                      :gw_base_price_invoiced ""
                                                                                                                                      :gw_base_price_refunded ""
                                                                                                                                      :gw_base_tax_amount ""
                                                                                                                                      :gw_base_tax_amount_invoiced ""
                                                                                                                                      :gw_base_tax_amount_refunded ""
                                                                                                                                      :gw_id 0
                                                                                                                                      :gw_price ""
                                                                                                                                      :gw_price_invoiced ""
                                                                                                                                      :gw_price_refunded ""
                                                                                                                                      :gw_tax_amount ""
                                                                                                                                      :gw_tax_amount_invoiced ""
                                                                                                                                      :gw_tax_amount_refunded ""
                                                                                                                                      :is_qty_decimal 0
                                                                                                                                      :is_virtual 0
                                                                                                                                      :item_id 0
                                                                                                                                      :locked_do_invoice 0
                                                                                                                                      :locked_do_ship 0
                                                                                                                                      :name ""
                                                                                                                                      :no_discount 0
                                                                                                                                      :order_id 0
                                                                                                                                      :original_price ""
                                                                                                                                      :parent_item ""
                                                                                                                                      :parent_item_id 0
                                                                                                                                      :price ""
                                                                                                                                      :price_incl_tax ""
                                                                                                                                      :product_id 0
                                                                                                                                      :product_option {:extension_attributes {:bundle_options [{:extension_attributes {}
                                                                                                                                                                                                :option_id 0
                                                                                                                                                                                                :option_qty 0
                                                                                                                                                                                                :option_selections []}]
                                                                                                                                                                              :configurable_item_options [{:extension_attributes {}
                                                                                                                                                                                                           :option_id ""
                                                                                                                                                                                                           :option_value 0}]
                                                                                                                                                                              :custom_options [{:extension_attributes {:file_info {:base64_encoded_data ""
                                                                                                                                                                                                                                   :name ""
                                                                                                                                                                                                                                   :type ""}}
                                                                                                                                                                                                :option_id ""
                                                                                                                                                                                                :option_value ""}]
                                                                                                                                                                              :downloadable_option {:downloadable_links []}
                                                                                                                                                                              :giftcard_item_option {:custom_giftcard_amount ""
                                                                                                                                                                                                     :extension_attributes {}
                                                                                                                                                                                                     :giftcard_amount ""
                                                                                                                                                                                                     :giftcard_message ""
                                                                                                                                                                                                     :giftcard_recipient_email ""
                                                                                                                                                                                                     :giftcard_recipient_name ""
                                                                                                                                                                                                     :giftcard_sender_email ""
                                                                                                                                                                                                     :giftcard_sender_name ""}}}
                                                                                                                                      :product_type ""
                                                                                                                                      :qty_backordered ""
                                                                                                                                      :qty_canceled ""
                                                                                                                                      :qty_invoiced ""
                                                                                                                                      :qty_ordered ""
                                                                                                                                      :qty_refunded ""
                                                                                                                                      :qty_returned ""
                                                                                                                                      :qty_shipped ""
                                                                                                                                      :quote_item_id 0
                                                                                                                                      :row_invoiced ""
                                                                                                                                      :row_total ""
                                                                                                                                      :row_total_incl_tax ""
                                                                                                                                      :row_weight ""
                                                                                                                                      :sku ""
                                                                                                                                      :store_id 0
                                                                                                                                      :tax_amount ""
                                                                                                                                      :tax_before_discount ""
                                                                                                                                      :tax_canceled ""
                                                                                                                                      :tax_invoiced ""
                                                                                                                                      :tax_percent ""
                                                                                                                                      :tax_refunded ""
                                                                                                                                      :updated_at ""
                                                                                                                                      :weee_tax_applied ""
                                                                                                                                      :weee_tax_applied_amount ""
                                                                                                                                      :weee_tax_applied_row_amount ""
                                                                                                                                      :weee_tax_disposition ""
                                                                                                                                      :weee_tax_row_disposition ""
                                                                                                                                      :weight ""}]
                                                                                                                             :shipping {:address {}
                                                                                                                                        :extension_attributes {:collection_point {:city ""
                                                                                                                                                                                  :collection_point_id ""
                                                                                                                                                                                  :country ""
                                                                                                                                                                                  :name ""
                                                                                                                                                                                  :postcode ""
                                                                                                                                                                                  :recipient_address_id 0
                                                                                                                                                                                  :region ""
                                                                                                                                                                                  :street []}
                                                                                                                                                               :ext_order_id ""
                                                                                                                                                               :shipping_experience {:code ""
                                                                                                                                                                                     :cost ""
                                                                                                                                                                                     :label ""}}
                                                                                                                                        :method ""
                                                                                                                                        :total {:base_shipping_amount ""
                                                                                                                                                :base_shipping_canceled ""
                                                                                                                                                :base_shipping_discount_amount ""
                                                                                                                                                :base_shipping_discount_tax_compensation_amnt ""
                                                                                                                                                :base_shipping_incl_tax ""
                                                                                                                                                :base_shipping_invoiced ""
                                                                                                                                                :base_shipping_refunded ""
                                                                                                                                                :base_shipping_tax_amount ""
                                                                                                                                                :base_shipping_tax_refunded ""
                                                                                                                                                :extension_attributes {}
                                                                                                                                                :shipping_amount ""
                                                                                                                                                :shipping_canceled ""
                                                                                                                                                :shipping_discount_amount ""
                                                                                                                                                :shipping_discount_tax_compensation_amount ""
                                                                                                                                                :shipping_incl_tax ""
                                                                                                                                                :shipping_invoiced ""
                                                                                                                                                :shipping_refunded ""
                                                                                                                                                :shipping_tax_amount ""
                                                                                                                                                :shipping_tax_refunded ""}}
                                                                                                                             :stock_id 0}]}
                                                                              :forced_shipment_with_invoice 0
                                                                              :global_currency_code ""
                                                                              :grand_total ""
                                                                              :hold_before_state ""
                                                                              :hold_before_status ""
                                                                              :increment_id ""
                                                                              :is_virtual 0
                                                                              :items [{}]
                                                                              :order_currency_code ""
                                                                              :original_increment_id ""
                                                                              :payment {:account_status ""
                                                                                        :additional_data ""
                                                                                        :additional_information []
                                                                                        :address_status ""
                                                                                        :amount_authorized ""
                                                                                        :amount_canceled ""
                                                                                        :amount_ordered ""
                                                                                        :amount_paid ""
                                                                                        :amount_refunded ""
                                                                                        :anet_trans_method ""
                                                                                        :base_amount_authorized ""
                                                                                        :base_amount_canceled ""
                                                                                        :base_amount_ordered ""
                                                                                        :base_amount_paid ""
                                                                                        :base_amount_paid_online ""
                                                                                        :base_amount_refunded ""
                                                                                        :base_amount_refunded_online ""
                                                                                        :base_shipping_amount ""
                                                                                        :base_shipping_captured ""
                                                                                        :base_shipping_refunded ""
                                                                                        :cc_approval ""
                                                                                        :cc_avs_status ""
                                                                                        :cc_cid_status ""
                                                                                        :cc_debug_request_body ""
                                                                                        :cc_debug_response_body ""
                                                                                        :cc_debug_response_serialized ""
                                                                                        :cc_exp_month ""
                                                                                        :cc_exp_year ""
                                                                                        :cc_last4 ""
                                                                                        :cc_number_enc ""
                                                                                        :cc_owner ""
                                                                                        :cc_secure_verify ""
                                                                                        :cc_ss_issue ""
                                                                                        :cc_ss_start_month ""
                                                                                        :cc_ss_start_year ""
                                                                                        :cc_status ""
                                                                                        :cc_status_description ""
                                                                                        :cc_trans_id ""
                                                                                        :cc_type ""
                                                                                        :echeck_account_name ""
                                                                                        :echeck_account_type ""
                                                                                        :echeck_bank_name ""
                                                                                        :echeck_routing_number ""
                                                                                        :echeck_type ""
                                                                                        :entity_id 0
                                                                                        :extension_attributes {:vault_payment_token {:created_at ""
                                                                                                                                     :customer_id 0
                                                                                                                                     :entity_id 0
                                                                                                                                     :expires_at ""
                                                                                                                                     :gateway_token ""
                                                                                                                                     :is_active false
                                                                                                                                     :is_visible false
                                                                                                                                     :payment_method_code ""
                                                                                                                                     :public_hash ""
                                                                                                                                     :token_details ""
                                                                                                                                     :type ""}}
                                                                                        :last_trans_id ""
                                                                                        :method ""
                                                                                        :parent_id 0
                                                                                        :po_number ""
                                                                                        :protection_eligibility ""
                                                                                        :quote_payment_id 0
                                                                                        :shipping_amount ""
                                                                                        :shipping_captured ""
                                                                                        :shipping_refunded ""}
                                                                              :payment_auth_expiration 0
                                                                              :payment_authorization_amount ""
                                                                              :protect_code ""
                                                                              :quote_address_id 0
                                                                              :quote_id 0
                                                                              :relation_child_id ""
                                                                              :relation_child_real_id ""
                                                                              :relation_parent_id ""
                                                                              :relation_parent_real_id ""
                                                                              :remote_ip ""
                                                                              :shipping_amount ""
                                                                              :shipping_canceled ""
                                                                              :shipping_description ""
                                                                              :shipping_discount_amount ""
                                                                              :shipping_discount_tax_compensation_amount ""
                                                                              :shipping_incl_tax ""
                                                                              :shipping_invoiced ""
                                                                              :shipping_refunded ""
                                                                              :shipping_tax_amount ""
                                                                              :shipping_tax_refunded ""
                                                                              :state ""
                                                                              :status ""
                                                                              :status_histories [{:comment ""
                                                                                                  :created_at ""
                                                                                                  :entity_id 0
                                                                                                  :entity_name ""
                                                                                                  :extension_attributes {}
                                                                                                  :is_customer_notified 0
                                                                                                  :is_visible_on_front 0
                                                                                                  :parent_id 0
                                                                                                  :status ""}]
                                                                              :store_currency_code ""
                                                                              :store_id 0
                                                                              :store_name ""
                                                                              :store_to_base_rate ""
                                                                              :store_to_order_rate ""
                                                                              :subtotal ""
                                                                              :subtotal_canceled ""
                                                                              :subtotal_incl_tax ""
                                                                              :subtotal_invoiced ""
                                                                              :subtotal_refunded ""
                                                                              :tax_amount ""
                                                                              :tax_canceled ""
                                                                              :tax_invoiced ""
                                                                              :tax_refunded ""
                                                                              :total_canceled ""
                                                                              :total_due ""
                                                                              :total_invoiced ""
                                                                              :total_item_count 0
                                                                              :total_offline_refunded ""
                                                                              :total_online_refunded ""
                                                                              :total_paid ""
                                                                              :total_qty_ordered ""
                                                                              :total_refunded ""
                                                                              :updated_at ""
                                                                              :weight ""
                                                                              :x_forwarded_for ""}}})
require "http/client"

url = "{{baseUrl}}/V1/orders/"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\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}}/V1/orders/"),
    Content = new StringContent("{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\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}}/V1/orders/");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/orders/"

	payload := strings.NewReader("{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/orders/ HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 18630

{
  "entity": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "applied_rule_ids": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_canceled": "",
    "base_discount_invoiced": "",
    "base_discount_refunded": "",
    "base_discount_tax_compensation_amount": "",
    "base_discount_tax_compensation_invoiced": "",
    "base_discount_tax_compensation_refunded": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_canceled": "",
    "base_shipping_discount_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_invoiced": "",
    "base_shipping_refunded": "",
    "base_shipping_tax_amount": "",
    "base_shipping_tax_refunded": "",
    "base_subtotal": "",
    "base_subtotal_canceled": "",
    "base_subtotal_incl_tax": "",
    "base_subtotal_invoiced": "",
    "base_subtotal_refunded": "",
    "base_tax_amount": "",
    "base_tax_canceled": "",
    "base_tax_invoiced": "",
    "base_tax_refunded": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_canceled": "",
    "base_total_due": "",
    "base_total_invoiced": "",
    "base_total_invoiced_cost": "",
    "base_total_offline_refunded": "",
    "base_total_online_refunded": "",
    "base_total_paid": "",
    "base_total_qty_ordered": "",
    "base_total_refunded": "",
    "billing_address": {
      "address_type": "",
      "city": "",
      "company": "",
      "country_id": "",
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "entity_id": 0,
      "extension_attributes": {
        "checkout_fields": [
          {
            "attribute_code": "",
            "value": ""
          }
        ]
      },
      "fax": "",
      "firstname": "",
      "lastname": "",
      "middlename": "",
      "parent_id": 0,
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": "",
      "vat_is_valid": 0,
      "vat_request_date": "",
      "vat_request_id": "",
      "vat_request_success": 0
    },
    "billing_address_id": 0,
    "can_ship_partially": 0,
    "can_ship_partially_item": 0,
    "coupon_code": "",
    "created_at": "",
    "customer_dob": "",
    "customer_email": "",
    "customer_firstname": "",
    "customer_gender": 0,
    "customer_group_id": 0,
    "customer_id": 0,
    "customer_is_guest": 0,
    "customer_lastname": "",
    "customer_middlename": "",
    "customer_note": "",
    "customer_note_notify": 0,
    "customer_prefix": "",
    "customer_suffix": "",
    "customer_taxvat": "",
    "discount_amount": "",
    "discount_canceled": "",
    "discount_description": "",
    "discount_invoiced": "",
    "discount_refunded": "",
    "discount_tax_compensation_amount": "",
    "discount_tax_compensation_invoiced": "",
    "discount_tax_compensation_refunded": "",
    "edit_increment": 0,
    "email_sent": 0,
    "entity_id": 0,
    "ext_customer_id": "",
    "ext_order_id": "",
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "applied_taxes": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "extension_attributes": {
            "rates": [
              {
                "code": "",
                "extension_attributes": {},
                "percent": "",
                "title": ""
              }
            ]
          },
          "percent": "",
          "title": ""
        }
      ],
      "base_customer_balance_amount": "",
      "base_customer_balance_invoiced": "",
      "base_customer_balance_refunded": "",
      "base_customer_balance_total_refunded": "",
      "base_gift_cards_amount": "",
      "base_gift_cards_invoiced": "",
      "base_gift_cards_refunded": "",
      "base_reward_currency_amount": "",
      "company_order_attributes": {
        "company_id": 0,
        "company_name": "",
        "extension_attributes": {},
        "order_id": 0
      },
      "converting_from_quote": false,
      "customer_balance_amount": "",
      "customer_balance_invoiced": "",
      "customer_balance_refunded": "",
      "customer_balance_total_refunded": "",
      "gift_cards": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "id": 0
        }
      ],
      "gift_cards_amount": "",
      "gift_cards_invoiced": "",
      "gift_cards_refunded": "",
      "gift_message": {
        "customer_id": 0,
        "extension_attributes": {
          "entity_id": "",
          "entity_type": "",
          "wrapping_add_printed_card": false,
          "wrapping_allow_gift_receipt": false,
          "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
      },
      "gw_add_card": "",
      "gw_allow_gift_receipt": "",
      "gw_base_price": "",
      "gw_base_price_incl_tax": "",
      "gw_base_price_invoiced": "",
      "gw_base_price_refunded": "",
      "gw_base_tax_amount": "",
      "gw_base_tax_amount_invoiced": "",
      "gw_base_tax_amount_refunded": "",
      "gw_card_base_price": "",
      "gw_card_base_price_incl_tax": "",
      "gw_card_base_price_invoiced": "",
      "gw_card_base_price_refunded": "",
      "gw_card_base_tax_amount": "",
      "gw_card_base_tax_invoiced": "",
      "gw_card_base_tax_refunded": "",
      "gw_card_price": "",
      "gw_card_price_incl_tax": "",
      "gw_card_price_invoiced": "",
      "gw_card_price_refunded": "",
      "gw_card_tax_amount": "",
      "gw_card_tax_invoiced": "",
      "gw_card_tax_refunded": "",
      "gw_id": "",
      "gw_items_base_price": "",
      "gw_items_base_price_incl_tax": "",
      "gw_items_base_price_invoiced": "",
      "gw_items_base_price_refunded": "",
      "gw_items_base_tax_amount": "",
      "gw_items_base_tax_invoiced": "",
      "gw_items_base_tax_refunded": "",
      "gw_items_price": "",
      "gw_items_price_incl_tax": "",
      "gw_items_price_invoiced": "",
      "gw_items_price_refunded": "",
      "gw_items_tax_amount": "",
      "gw_items_tax_invoiced": "",
      "gw_items_tax_refunded": "",
      "gw_price": "",
      "gw_price_incl_tax": "",
      "gw_price_invoiced": "",
      "gw_price_refunded": "",
      "gw_tax_amount": "",
      "gw_tax_amount_invoiced": "",
      "gw_tax_amount_refunded": "",
      "item_applied_taxes": [
        {
          "applied_taxes": [
            {}
          ],
          "associated_item_id": 0,
          "extension_attributes": {},
          "item_id": 0,
          "type": ""
        }
      ],
      "payment_additional_info": [
        {
          "key": "",
          "value": ""
        }
      ],
      "reward_currency_amount": "",
      "reward_points_balance": 0,
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "additional_data": "",
              "amount_refunded": "",
              "applied_rule_ids": "",
              "base_amount_refunded": "",
              "base_cost": "",
              "base_discount_amount": "",
              "base_discount_invoiced": "",
              "base_discount_refunded": "",
              "base_discount_tax_compensation_amount": "",
              "base_discount_tax_compensation_invoiced": "",
              "base_discount_tax_compensation_refunded": "",
              "base_original_price": "",
              "base_price": "",
              "base_price_incl_tax": "",
              "base_row_invoiced": "",
              "base_row_total": "",
              "base_row_total_incl_tax": "",
              "base_tax_amount": "",
              "base_tax_before_discount": "",
              "base_tax_invoiced": "",
              "base_tax_refunded": "",
              "base_weee_tax_applied_amount": "",
              "base_weee_tax_applied_row_amnt": "",
              "base_weee_tax_disposition": "",
              "base_weee_tax_row_disposition": "",
              "created_at": "",
              "description": "",
              "discount_amount": "",
              "discount_invoiced": "",
              "discount_percent": "",
              "discount_refunded": "",
              "discount_tax_compensation_amount": "",
              "discount_tax_compensation_canceled": "",
              "discount_tax_compensation_invoiced": "",
              "discount_tax_compensation_refunded": "",
              "event_id": 0,
              "ext_order_item_id": "",
              "extension_attributes": {
                "gift_message": {},
                "gw_base_price": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_id": "",
                "gw_price": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "invoice_text_codes": [],
                "tax_codes": [],
                "vertex_tax_codes": []
              },
              "free_shipping": 0,
              "gw_base_price": "",
              "gw_base_price_invoiced": "",
              "gw_base_price_refunded": "",
              "gw_base_tax_amount": "",
              "gw_base_tax_amount_invoiced": "",
              "gw_base_tax_amount_refunded": "",
              "gw_id": 0,
              "gw_price": "",
              "gw_price_invoiced": "",
              "gw_price_refunded": "",
              "gw_tax_amount": "",
              "gw_tax_amount_invoiced": "",
              "gw_tax_amount_refunded": "",
              "is_qty_decimal": 0,
              "is_virtual": 0,
              "item_id": 0,
              "locked_do_invoice": 0,
              "locked_do_ship": 0,
              "name": "",
              "no_discount": 0,
              "order_id": 0,
              "original_price": "",
              "parent_item": "",
              "parent_item_id": 0,
              "price": "",
              "price_incl_tax": "",
              "product_id": 0,
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty_backordered": "",
              "qty_canceled": "",
              "qty_invoiced": "",
              "qty_ordered": "",
              "qty_refunded": "",
              "qty_returned": "",
              "qty_shipped": "",
              "quote_item_id": 0,
              "row_invoiced": "",
              "row_total": "",
              "row_total_incl_tax": "",
              "row_weight": "",
              "sku": "",
              "store_id": 0,
              "tax_amount": "",
              "tax_before_discount": "",
              "tax_canceled": "",
              "tax_invoiced": "",
              "tax_percent": "",
              "tax_refunded": "",
              "updated_at": "",
              "weee_tax_applied": "",
              "weee_tax_applied_amount": "",
              "weee_tax_applied_row_amount": "",
              "weee_tax_disposition": "",
              "weee_tax_row_disposition": "",
              "weight": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {
              "collection_point": {
                "city": "",
                "collection_point_id": "",
                "country": "",
                "name": "",
                "postcode": "",
                "recipient_address_id": 0,
                "region": "",
                "street": []
              },
              "ext_order_id": "",
              "shipping_experience": {
                "code": "",
                "cost": "",
                "label": ""
              }
            },
            "method": "",
            "total": {
              "base_shipping_amount": "",
              "base_shipping_canceled": "",
              "base_shipping_discount_amount": "",
              "base_shipping_discount_tax_compensation_amnt": "",
              "base_shipping_incl_tax": "",
              "base_shipping_invoiced": "",
              "base_shipping_refunded": "",
              "base_shipping_tax_amount": "",
              "base_shipping_tax_refunded": "",
              "extension_attributes": {},
              "shipping_amount": "",
              "shipping_canceled": "",
              "shipping_discount_amount": "",
              "shipping_discount_tax_compensation_amount": "",
              "shipping_incl_tax": "",
              "shipping_invoiced": "",
              "shipping_refunded": "",
              "shipping_tax_amount": "",
              "shipping_tax_refunded": ""
            }
          },
          "stock_id": 0
        }
      ]
    },
    "forced_shipment_with_invoice": 0,
    "global_currency_code": "",
    "grand_total": "",
    "hold_before_state": "",
    "hold_before_status": "",
    "increment_id": "",
    "is_virtual": 0,
    "items": [
      {}
    ],
    "order_currency_code": "",
    "original_increment_id": "",
    "payment": {
      "account_status": "",
      "additional_data": "",
      "additional_information": [],
      "address_status": "",
      "amount_authorized": "",
      "amount_canceled": "",
      "amount_ordered": "",
      "amount_paid": "",
      "amount_refunded": "",
      "anet_trans_method": "",
      "base_amount_authorized": "",
      "base_amount_canceled": "",
      "base_amount_ordered": "",
      "base_amount_paid": "",
      "base_amount_paid_online": "",
      "base_amount_refunded": "",
      "base_amount_refunded_online": "",
      "base_shipping_amount": "",
      "base_shipping_captured": "",
      "base_shipping_refunded": "",
      "cc_approval": "",
      "cc_avs_status": "",
      "cc_cid_status": "",
      "cc_debug_request_body": "",
      "cc_debug_response_body": "",
      "cc_debug_response_serialized": "",
      "cc_exp_month": "",
      "cc_exp_year": "",
      "cc_last4": "",
      "cc_number_enc": "",
      "cc_owner": "",
      "cc_secure_verify": "",
      "cc_ss_issue": "",
      "cc_ss_start_month": "",
      "cc_ss_start_year": "",
      "cc_status": "",
      "cc_status_description": "",
      "cc_trans_id": "",
      "cc_type": "",
      "echeck_account_name": "",
      "echeck_account_type": "",
      "echeck_bank_name": "",
      "echeck_routing_number": "",
      "echeck_type": "",
      "entity_id": 0,
      "extension_attributes": {
        "vault_payment_token": {
          "created_at": "",
          "customer_id": 0,
          "entity_id": 0,
          "expires_at": "",
          "gateway_token": "",
          "is_active": false,
          "is_visible": false,
          "payment_method_code": "",
          "public_hash": "",
          "token_details": "",
          "type": ""
        }
      },
      "last_trans_id": "",
      "method": "",
      "parent_id": 0,
      "po_number": "",
      "protection_eligibility": "",
      "quote_payment_id": 0,
      "shipping_amount": "",
      "shipping_captured": "",
      "shipping_refunded": ""
    },
    "payment_auth_expiration": 0,
    "payment_authorization_amount": "",
    "protect_code": "",
    "quote_address_id": 0,
    "quote_id": 0,
    "relation_child_id": "",
    "relation_child_real_id": "",
    "relation_parent_id": "",
    "relation_parent_real_id": "",
    "remote_ip": "",
    "shipping_amount": "",
    "shipping_canceled": "",
    "shipping_description": "",
    "shipping_discount_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_invoiced": "",
    "shipping_refunded": "",
    "shipping_tax_amount": "",
    "shipping_tax_refunded": "",
    "state": "",
    "status": "",
    "status_histories": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "entity_name": "",
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0,
        "status": ""
      }
    ],
    "store_currency_code": "",
    "store_id": 0,
    "store_name": "",
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_canceled": "",
    "subtotal_incl_tax": "",
    "subtotal_invoiced": "",
    "subtotal_refunded": "",
    "tax_amount": "",
    "tax_canceled": "",
    "tax_invoiced": "",
    "tax_refunded": "",
    "total_canceled": "",
    "total_due": "",
    "total_invoiced": "",
    "total_item_count": 0,
    "total_offline_refunded": "",
    "total_online_refunded": "",
    "total_paid": "",
    "total_qty_ordered": "",
    "total_refunded": "",
    "updated_at": "",
    "weight": "",
    "x_forwarded_for": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/orders/")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/orders/"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\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  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/orders/")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/orders/")
  .header("content-type", "application/json")
  .body("{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  entity: {
    adjustment_negative: '',
    adjustment_positive: '',
    applied_rule_ids: '',
    base_adjustment_negative: '',
    base_adjustment_positive: '',
    base_currency_code: '',
    base_discount_amount: '',
    base_discount_canceled: '',
    base_discount_invoiced: '',
    base_discount_refunded: '',
    base_discount_tax_compensation_amount: '',
    base_discount_tax_compensation_invoiced: '',
    base_discount_tax_compensation_refunded: '',
    base_grand_total: '',
    base_shipping_amount: '',
    base_shipping_canceled: '',
    base_shipping_discount_amount: '',
    base_shipping_discount_tax_compensation_amnt: '',
    base_shipping_incl_tax: '',
    base_shipping_invoiced: '',
    base_shipping_refunded: '',
    base_shipping_tax_amount: '',
    base_shipping_tax_refunded: '',
    base_subtotal: '',
    base_subtotal_canceled: '',
    base_subtotal_incl_tax: '',
    base_subtotal_invoiced: '',
    base_subtotal_refunded: '',
    base_tax_amount: '',
    base_tax_canceled: '',
    base_tax_invoiced: '',
    base_tax_refunded: '',
    base_to_global_rate: '',
    base_to_order_rate: '',
    base_total_canceled: '',
    base_total_due: '',
    base_total_invoiced: '',
    base_total_invoiced_cost: '',
    base_total_offline_refunded: '',
    base_total_online_refunded: '',
    base_total_paid: '',
    base_total_qty_ordered: '',
    base_total_refunded: '',
    billing_address: {
      address_type: '',
      city: '',
      company: '',
      country_id: '',
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      entity_id: 0,
      extension_attributes: {
        checkout_fields: [
          {
            attribute_code: '',
            value: ''
          }
        ]
      },
      fax: '',
      firstname: '',
      lastname: '',
      middlename: '',
      parent_id: 0,
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: '',
      vat_is_valid: 0,
      vat_request_date: '',
      vat_request_id: '',
      vat_request_success: 0
    },
    billing_address_id: 0,
    can_ship_partially: 0,
    can_ship_partially_item: 0,
    coupon_code: '',
    created_at: '',
    customer_dob: '',
    customer_email: '',
    customer_firstname: '',
    customer_gender: 0,
    customer_group_id: 0,
    customer_id: 0,
    customer_is_guest: 0,
    customer_lastname: '',
    customer_middlename: '',
    customer_note: '',
    customer_note_notify: 0,
    customer_prefix: '',
    customer_suffix: '',
    customer_taxvat: '',
    discount_amount: '',
    discount_canceled: '',
    discount_description: '',
    discount_invoiced: '',
    discount_refunded: '',
    discount_tax_compensation_amount: '',
    discount_tax_compensation_invoiced: '',
    discount_tax_compensation_refunded: '',
    edit_increment: 0,
    email_sent: 0,
    entity_id: 0,
    ext_customer_id: '',
    ext_order_id: '',
    extension_attributes: {
      amazon_order_reference_id: '',
      applied_taxes: [
        {
          amount: '',
          base_amount: '',
          code: '',
          extension_attributes: {
            rates: [
              {
                code: '',
                extension_attributes: {},
                percent: '',
                title: ''
              }
            ]
          },
          percent: '',
          title: ''
        }
      ],
      base_customer_balance_amount: '',
      base_customer_balance_invoiced: '',
      base_customer_balance_refunded: '',
      base_customer_balance_total_refunded: '',
      base_gift_cards_amount: '',
      base_gift_cards_invoiced: '',
      base_gift_cards_refunded: '',
      base_reward_currency_amount: '',
      company_order_attributes: {
        company_id: 0,
        company_name: '',
        extension_attributes: {},
        order_id: 0
      },
      converting_from_quote: false,
      customer_balance_amount: '',
      customer_balance_invoiced: '',
      customer_balance_refunded: '',
      customer_balance_total_refunded: '',
      gift_cards: [
        {
          amount: '',
          base_amount: '',
          code: '',
          id: 0
        }
      ],
      gift_cards_amount: '',
      gift_cards_invoiced: '',
      gift_cards_refunded: '',
      gift_message: {
        customer_id: 0,
        extension_attributes: {
          entity_id: '',
          entity_type: '',
          wrapping_add_printed_card: false,
          wrapping_allow_gift_receipt: false,
          wrapping_id: 0
        },
        gift_message_id: 0,
        message: '',
        recipient: '',
        sender: ''
      },
      gw_add_card: '',
      gw_allow_gift_receipt: '',
      gw_base_price: '',
      gw_base_price_incl_tax: '',
      gw_base_price_invoiced: '',
      gw_base_price_refunded: '',
      gw_base_tax_amount: '',
      gw_base_tax_amount_invoiced: '',
      gw_base_tax_amount_refunded: '',
      gw_card_base_price: '',
      gw_card_base_price_incl_tax: '',
      gw_card_base_price_invoiced: '',
      gw_card_base_price_refunded: '',
      gw_card_base_tax_amount: '',
      gw_card_base_tax_invoiced: '',
      gw_card_base_tax_refunded: '',
      gw_card_price: '',
      gw_card_price_incl_tax: '',
      gw_card_price_invoiced: '',
      gw_card_price_refunded: '',
      gw_card_tax_amount: '',
      gw_card_tax_invoiced: '',
      gw_card_tax_refunded: '',
      gw_id: '',
      gw_items_base_price: '',
      gw_items_base_price_incl_tax: '',
      gw_items_base_price_invoiced: '',
      gw_items_base_price_refunded: '',
      gw_items_base_tax_amount: '',
      gw_items_base_tax_invoiced: '',
      gw_items_base_tax_refunded: '',
      gw_items_price: '',
      gw_items_price_incl_tax: '',
      gw_items_price_invoiced: '',
      gw_items_price_refunded: '',
      gw_items_tax_amount: '',
      gw_items_tax_invoiced: '',
      gw_items_tax_refunded: '',
      gw_price: '',
      gw_price_incl_tax: '',
      gw_price_invoiced: '',
      gw_price_refunded: '',
      gw_tax_amount: '',
      gw_tax_amount_invoiced: '',
      gw_tax_amount_refunded: '',
      item_applied_taxes: [
        {
          applied_taxes: [
            {}
          ],
          associated_item_id: 0,
          extension_attributes: {},
          item_id: 0,
          type: ''
        }
      ],
      payment_additional_info: [
        {
          key: '',
          value: ''
        }
      ],
      reward_currency_amount: '',
      reward_points_balance: 0,
      shipping_assignments: [
        {
          extension_attributes: {},
          items: [
            {
              additional_data: '',
              amount_refunded: '',
              applied_rule_ids: '',
              base_amount_refunded: '',
              base_cost: '',
              base_discount_amount: '',
              base_discount_invoiced: '',
              base_discount_refunded: '',
              base_discount_tax_compensation_amount: '',
              base_discount_tax_compensation_invoiced: '',
              base_discount_tax_compensation_refunded: '',
              base_original_price: '',
              base_price: '',
              base_price_incl_tax: '',
              base_row_invoiced: '',
              base_row_total: '',
              base_row_total_incl_tax: '',
              base_tax_amount: '',
              base_tax_before_discount: '',
              base_tax_invoiced: '',
              base_tax_refunded: '',
              base_weee_tax_applied_amount: '',
              base_weee_tax_applied_row_amnt: '',
              base_weee_tax_disposition: '',
              base_weee_tax_row_disposition: '',
              created_at: '',
              description: '',
              discount_amount: '',
              discount_invoiced: '',
              discount_percent: '',
              discount_refunded: '',
              discount_tax_compensation_amount: '',
              discount_tax_compensation_canceled: '',
              discount_tax_compensation_invoiced: '',
              discount_tax_compensation_refunded: '',
              event_id: 0,
              ext_order_item_id: '',
              extension_attributes: {
                gift_message: {},
                gw_base_price: '',
                gw_base_price_invoiced: '',
                gw_base_price_refunded: '',
                gw_base_tax_amount: '',
                gw_base_tax_amount_invoiced: '',
                gw_base_tax_amount_refunded: '',
                gw_id: '',
                gw_price: '',
                gw_price_invoiced: '',
                gw_price_refunded: '',
                gw_tax_amount: '',
                gw_tax_amount_invoiced: '',
                gw_tax_amount_refunded: '',
                invoice_text_codes: [],
                tax_codes: [],
                vertex_tax_codes: []
              },
              free_shipping: 0,
              gw_base_price: '',
              gw_base_price_invoiced: '',
              gw_base_price_refunded: '',
              gw_base_tax_amount: '',
              gw_base_tax_amount_invoiced: '',
              gw_base_tax_amount_refunded: '',
              gw_id: 0,
              gw_price: '',
              gw_price_invoiced: '',
              gw_price_refunded: '',
              gw_tax_amount: '',
              gw_tax_amount_invoiced: '',
              gw_tax_amount_refunded: '',
              is_qty_decimal: 0,
              is_virtual: 0,
              item_id: 0,
              locked_do_invoice: 0,
              locked_do_ship: 0,
              name: '',
              no_discount: 0,
              order_id: 0,
              original_price: '',
              parent_item: '',
              parent_item_id: 0,
              price: '',
              price_incl_tax: '',
              product_id: 0,
              product_option: {
                extension_attributes: {
                  bundle_options: [
                    {
                      extension_attributes: {},
                      option_id: 0,
                      option_qty: 0,
                      option_selections: []
                    }
                  ],
                  configurable_item_options: [
                    {
                      extension_attributes: {},
                      option_id: '',
                      option_value: 0
                    }
                  ],
                  custom_options: [
                    {
                      extension_attributes: {
                        file_info: {
                          base64_encoded_data: '',
                          name: '',
                          type: ''
                        }
                      },
                      option_id: '',
                      option_value: ''
                    }
                  ],
                  downloadable_option: {
                    downloadable_links: []
                  },
                  giftcard_item_option: {
                    custom_giftcard_amount: '',
                    extension_attributes: {},
                    giftcard_amount: '',
                    giftcard_message: '',
                    giftcard_recipient_email: '',
                    giftcard_recipient_name: '',
                    giftcard_sender_email: '',
                    giftcard_sender_name: ''
                  }
                }
              },
              product_type: '',
              qty_backordered: '',
              qty_canceled: '',
              qty_invoiced: '',
              qty_ordered: '',
              qty_refunded: '',
              qty_returned: '',
              qty_shipped: '',
              quote_item_id: 0,
              row_invoiced: '',
              row_total: '',
              row_total_incl_tax: '',
              row_weight: '',
              sku: '',
              store_id: 0,
              tax_amount: '',
              tax_before_discount: '',
              tax_canceled: '',
              tax_invoiced: '',
              tax_percent: '',
              tax_refunded: '',
              updated_at: '',
              weee_tax_applied: '',
              weee_tax_applied_amount: '',
              weee_tax_applied_row_amount: '',
              weee_tax_disposition: '',
              weee_tax_row_disposition: '',
              weight: ''
            }
          ],
          shipping: {
            address: {},
            extension_attributes: {
              collection_point: {
                city: '',
                collection_point_id: '',
                country: '',
                name: '',
                postcode: '',
                recipient_address_id: 0,
                region: '',
                street: []
              },
              ext_order_id: '',
              shipping_experience: {
                code: '',
                cost: '',
                label: ''
              }
            },
            method: '',
            total: {
              base_shipping_amount: '',
              base_shipping_canceled: '',
              base_shipping_discount_amount: '',
              base_shipping_discount_tax_compensation_amnt: '',
              base_shipping_incl_tax: '',
              base_shipping_invoiced: '',
              base_shipping_refunded: '',
              base_shipping_tax_amount: '',
              base_shipping_tax_refunded: '',
              extension_attributes: {},
              shipping_amount: '',
              shipping_canceled: '',
              shipping_discount_amount: '',
              shipping_discount_tax_compensation_amount: '',
              shipping_incl_tax: '',
              shipping_invoiced: '',
              shipping_refunded: '',
              shipping_tax_amount: '',
              shipping_tax_refunded: ''
            }
          },
          stock_id: 0
        }
      ]
    },
    forced_shipment_with_invoice: 0,
    global_currency_code: '',
    grand_total: '',
    hold_before_state: '',
    hold_before_status: '',
    increment_id: '',
    is_virtual: 0,
    items: [
      {}
    ],
    order_currency_code: '',
    original_increment_id: '',
    payment: {
      account_status: '',
      additional_data: '',
      additional_information: [],
      address_status: '',
      amount_authorized: '',
      amount_canceled: '',
      amount_ordered: '',
      amount_paid: '',
      amount_refunded: '',
      anet_trans_method: '',
      base_amount_authorized: '',
      base_amount_canceled: '',
      base_amount_ordered: '',
      base_amount_paid: '',
      base_amount_paid_online: '',
      base_amount_refunded: '',
      base_amount_refunded_online: '',
      base_shipping_amount: '',
      base_shipping_captured: '',
      base_shipping_refunded: '',
      cc_approval: '',
      cc_avs_status: '',
      cc_cid_status: '',
      cc_debug_request_body: '',
      cc_debug_response_body: '',
      cc_debug_response_serialized: '',
      cc_exp_month: '',
      cc_exp_year: '',
      cc_last4: '',
      cc_number_enc: '',
      cc_owner: '',
      cc_secure_verify: '',
      cc_ss_issue: '',
      cc_ss_start_month: '',
      cc_ss_start_year: '',
      cc_status: '',
      cc_status_description: '',
      cc_trans_id: '',
      cc_type: '',
      echeck_account_name: '',
      echeck_account_type: '',
      echeck_bank_name: '',
      echeck_routing_number: '',
      echeck_type: '',
      entity_id: 0,
      extension_attributes: {
        vault_payment_token: {
          created_at: '',
          customer_id: 0,
          entity_id: 0,
          expires_at: '',
          gateway_token: '',
          is_active: false,
          is_visible: false,
          payment_method_code: '',
          public_hash: '',
          token_details: '',
          type: ''
        }
      },
      last_trans_id: '',
      method: '',
      parent_id: 0,
      po_number: '',
      protection_eligibility: '',
      quote_payment_id: 0,
      shipping_amount: '',
      shipping_captured: '',
      shipping_refunded: ''
    },
    payment_auth_expiration: 0,
    payment_authorization_amount: '',
    protect_code: '',
    quote_address_id: 0,
    quote_id: 0,
    relation_child_id: '',
    relation_child_real_id: '',
    relation_parent_id: '',
    relation_parent_real_id: '',
    remote_ip: '',
    shipping_amount: '',
    shipping_canceled: '',
    shipping_description: '',
    shipping_discount_amount: '',
    shipping_discount_tax_compensation_amount: '',
    shipping_incl_tax: '',
    shipping_invoiced: '',
    shipping_refunded: '',
    shipping_tax_amount: '',
    shipping_tax_refunded: '',
    state: '',
    status: '',
    status_histories: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        entity_name: '',
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0,
        status: ''
      }
    ],
    store_currency_code: '',
    store_id: 0,
    store_name: '',
    store_to_base_rate: '',
    store_to_order_rate: '',
    subtotal: '',
    subtotal_canceled: '',
    subtotal_incl_tax: '',
    subtotal_invoiced: '',
    subtotal_refunded: '',
    tax_amount: '',
    tax_canceled: '',
    tax_invoiced: '',
    tax_refunded: '',
    total_canceled: '',
    total_due: '',
    total_invoiced: '',
    total_item_count: 0,
    total_offline_refunded: '',
    total_online_refunded: '',
    total_paid: '',
    total_qty_ordered: '',
    total_refunded: '',
    updated_at: '',
    weight: '',
    x_forwarded_for: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/orders/');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/orders/',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      adjustment_negative: '',
      adjustment_positive: '',
      applied_rule_ids: '',
      base_adjustment_negative: '',
      base_adjustment_positive: '',
      base_currency_code: '',
      base_discount_amount: '',
      base_discount_canceled: '',
      base_discount_invoiced: '',
      base_discount_refunded: '',
      base_discount_tax_compensation_amount: '',
      base_discount_tax_compensation_invoiced: '',
      base_discount_tax_compensation_refunded: '',
      base_grand_total: '',
      base_shipping_amount: '',
      base_shipping_canceled: '',
      base_shipping_discount_amount: '',
      base_shipping_discount_tax_compensation_amnt: '',
      base_shipping_incl_tax: '',
      base_shipping_invoiced: '',
      base_shipping_refunded: '',
      base_shipping_tax_amount: '',
      base_shipping_tax_refunded: '',
      base_subtotal: '',
      base_subtotal_canceled: '',
      base_subtotal_incl_tax: '',
      base_subtotal_invoiced: '',
      base_subtotal_refunded: '',
      base_tax_amount: '',
      base_tax_canceled: '',
      base_tax_invoiced: '',
      base_tax_refunded: '',
      base_to_global_rate: '',
      base_to_order_rate: '',
      base_total_canceled: '',
      base_total_due: '',
      base_total_invoiced: '',
      base_total_invoiced_cost: '',
      base_total_offline_refunded: '',
      base_total_online_refunded: '',
      base_total_paid: '',
      base_total_qty_ordered: '',
      base_total_refunded: '',
      billing_address: {
        address_type: '',
        city: '',
        company: '',
        country_id: '',
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        entity_id: 0,
        extension_attributes: {checkout_fields: [{attribute_code: '', value: ''}]},
        fax: '',
        firstname: '',
        lastname: '',
        middlename: '',
        parent_id: 0,
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: '',
        vat_is_valid: 0,
        vat_request_date: '',
        vat_request_id: '',
        vat_request_success: 0
      },
      billing_address_id: 0,
      can_ship_partially: 0,
      can_ship_partially_item: 0,
      coupon_code: '',
      created_at: '',
      customer_dob: '',
      customer_email: '',
      customer_firstname: '',
      customer_gender: 0,
      customer_group_id: 0,
      customer_id: 0,
      customer_is_guest: 0,
      customer_lastname: '',
      customer_middlename: '',
      customer_note: '',
      customer_note_notify: 0,
      customer_prefix: '',
      customer_suffix: '',
      customer_taxvat: '',
      discount_amount: '',
      discount_canceled: '',
      discount_description: '',
      discount_invoiced: '',
      discount_refunded: '',
      discount_tax_compensation_amount: '',
      discount_tax_compensation_invoiced: '',
      discount_tax_compensation_refunded: '',
      edit_increment: 0,
      email_sent: 0,
      entity_id: 0,
      ext_customer_id: '',
      ext_order_id: '',
      extension_attributes: {
        amazon_order_reference_id: '',
        applied_taxes: [
          {
            amount: '',
            base_amount: '',
            code: '',
            extension_attributes: {rates: [{code: '', extension_attributes: {}, percent: '', title: ''}]},
            percent: '',
            title: ''
          }
        ],
        base_customer_balance_amount: '',
        base_customer_balance_invoiced: '',
        base_customer_balance_refunded: '',
        base_customer_balance_total_refunded: '',
        base_gift_cards_amount: '',
        base_gift_cards_invoiced: '',
        base_gift_cards_refunded: '',
        base_reward_currency_amount: '',
        company_order_attributes: {company_id: 0, company_name: '', extension_attributes: {}, order_id: 0},
        converting_from_quote: false,
        customer_balance_amount: '',
        customer_balance_invoiced: '',
        customer_balance_refunded: '',
        customer_balance_total_refunded: '',
        gift_cards: [{amount: '', base_amount: '', code: '', id: 0}],
        gift_cards_amount: '',
        gift_cards_invoiced: '',
        gift_cards_refunded: '',
        gift_message: {
          customer_id: 0,
          extension_attributes: {
            entity_id: '',
            entity_type: '',
            wrapping_add_printed_card: false,
            wrapping_allow_gift_receipt: false,
            wrapping_id: 0
          },
          gift_message_id: 0,
          message: '',
          recipient: '',
          sender: ''
        },
        gw_add_card: '',
        gw_allow_gift_receipt: '',
        gw_base_price: '',
        gw_base_price_incl_tax: '',
        gw_base_price_invoiced: '',
        gw_base_price_refunded: '',
        gw_base_tax_amount: '',
        gw_base_tax_amount_invoiced: '',
        gw_base_tax_amount_refunded: '',
        gw_card_base_price: '',
        gw_card_base_price_incl_tax: '',
        gw_card_base_price_invoiced: '',
        gw_card_base_price_refunded: '',
        gw_card_base_tax_amount: '',
        gw_card_base_tax_invoiced: '',
        gw_card_base_tax_refunded: '',
        gw_card_price: '',
        gw_card_price_incl_tax: '',
        gw_card_price_invoiced: '',
        gw_card_price_refunded: '',
        gw_card_tax_amount: '',
        gw_card_tax_invoiced: '',
        gw_card_tax_refunded: '',
        gw_id: '',
        gw_items_base_price: '',
        gw_items_base_price_incl_tax: '',
        gw_items_base_price_invoiced: '',
        gw_items_base_price_refunded: '',
        gw_items_base_tax_amount: '',
        gw_items_base_tax_invoiced: '',
        gw_items_base_tax_refunded: '',
        gw_items_price: '',
        gw_items_price_incl_tax: '',
        gw_items_price_invoiced: '',
        gw_items_price_refunded: '',
        gw_items_tax_amount: '',
        gw_items_tax_invoiced: '',
        gw_items_tax_refunded: '',
        gw_price: '',
        gw_price_incl_tax: '',
        gw_price_invoiced: '',
        gw_price_refunded: '',
        gw_tax_amount: '',
        gw_tax_amount_invoiced: '',
        gw_tax_amount_refunded: '',
        item_applied_taxes: [
          {
            applied_taxes: [{}],
            associated_item_id: 0,
            extension_attributes: {},
            item_id: 0,
            type: ''
          }
        ],
        payment_additional_info: [{key: '', value: ''}],
        reward_currency_amount: '',
        reward_points_balance: 0,
        shipping_assignments: [
          {
            extension_attributes: {},
            items: [
              {
                additional_data: '',
                amount_refunded: '',
                applied_rule_ids: '',
                base_amount_refunded: '',
                base_cost: '',
                base_discount_amount: '',
                base_discount_invoiced: '',
                base_discount_refunded: '',
                base_discount_tax_compensation_amount: '',
                base_discount_tax_compensation_invoiced: '',
                base_discount_tax_compensation_refunded: '',
                base_original_price: '',
                base_price: '',
                base_price_incl_tax: '',
                base_row_invoiced: '',
                base_row_total: '',
                base_row_total_incl_tax: '',
                base_tax_amount: '',
                base_tax_before_discount: '',
                base_tax_invoiced: '',
                base_tax_refunded: '',
                base_weee_tax_applied_amount: '',
                base_weee_tax_applied_row_amnt: '',
                base_weee_tax_disposition: '',
                base_weee_tax_row_disposition: '',
                created_at: '',
                description: '',
                discount_amount: '',
                discount_invoiced: '',
                discount_percent: '',
                discount_refunded: '',
                discount_tax_compensation_amount: '',
                discount_tax_compensation_canceled: '',
                discount_tax_compensation_invoiced: '',
                discount_tax_compensation_refunded: '',
                event_id: 0,
                ext_order_item_id: '',
                extension_attributes: {
                  gift_message: {},
                  gw_base_price: '',
                  gw_base_price_invoiced: '',
                  gw_base_price_refunded: '',
                  gw_base_tax_amount: '',
                  gw_base_tax_amount_invoiced: '',
                  gw_base_tax_amount_refunded: '',
                  gw_id: '',
                  gw_price: '',
                  gw_price_invoiced: '',
                  gw_price_refunded: '',
                  gw_tax_amount: '',
                  gw_tax_amount_invoiced: '',
                  gw_tax_amount_refunded: '',
                  invoice_text_codes: [],
                  tax_codes: [],
                  vertex_tax_codes: []
                },
                free_shipping: 0,
                gw_base_price: '',
                gw_base_price_invoiced: '',
                gw_base_price_refunded: '',
                gw_base_tax_amount: '',
                gw_base_tax_amount_invoiced: '',
                gw_base_tax_amount_refunded: '',
                gw_id: 0,
                gw_price: '',
                gw_price_invoiced: '',
                gw_price_refunded: '',
                gw_tax_amount: '',
                gw_tax_amount_invoiced: '',
                gw_tax_amount_refunded: '',
                is_qty_decimal: 0,
                is_virtual: 0,
                item_id: 0,
                locked_do_invoice: 0,
                locked_do_ship: 0,
                name: '',
                no_discount: 0,
                order_id: 0,
                original_price: '',
                parent_item: '',
                parent_item_id: 0,
                price: '',
                price_incl_tax: '',
                product_id: 0,
                product_option: {
                  extension_attributes: {
                    bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                    configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                    custom_options: [
                      {
                        extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                        option_id: '',
                        option_value: ''
                      }
                    ],
                    downloadable_option: {downloadable_links: []},
                    giftcard_item_option: {
                      custom_giftcard_amount: '',
                      extension_attributes: {},
                      giftcard_amount: '',
                      giftcard_message: '',
                      giftcard_recipient_email: '',
                      giftcard_recipient_name: '',
                      giftcard_sender_email: '',
                      giftcard_sender_name: ''
                    }
                  }
                },
                product_type: '',
                qty_backordered: '',
                qty_canceled: '',
                qty_invoiced: '',
                qty_ordered: '',
                qty_refunded: '',
                qty_returned: '',
                qty_shipped: '',
                quote_item_id: 0,
                row_invoiced: '',
                row_total: '',
                row_total_incl_tax: '',
                row_weight: '',
                sku: '',
                store_id: 0,
                tax_amount: '',
                tax_before_discount: '',
                tax_canceled: '',
                tax_invoiced: '',
                tax_percent: '',
                tax_refunded: '',
                updated_at: '',
                weee_tax_applied: '',
                weee_tax_applied_amount: '',
                weee_tax_applied_row_amount: '',
                weee_tax_disposition: '',
                weee_tax_row_disposition: '',
                weight: ''
              }
            ],
            shipping: {
              address: {},
              extension_attributes: {
                collection_point: {
                  city: '',
                  collection_point_id: '',
                  country: '',
                  name: '',
                  postcode: '',
                  recipient_address_id: 0,
                  region: '',
                  street: []
                },
                ext_order_id: '',
                shipping_experience: {code: '', cost: '', label: ''}
              },
              method: '',
              total: {
                base_shipping_amount: '',
                base_shipping_canceled: '',
                base_shipping_discount_amount: '',
                base_shipping_discount_tax_compensation_amnt: '',
                base_shipping_incl_tax: '',
                base_shipping_invoiced: '',
                base_shipping_refunded: '',
                base_shipping_tax_amount: '',
                base_shipping_tax_refunded: '',
                extension_attributes: {},
                shipping_amount: '',
                shipping_canceled: '',
                shipping_discount_amount: '',
                shipping_discount_tax_compensation_amount: '',
                shipping_incl_tax: '',
                shipping_invoiced: '',
                shipping_refunded: '',
                shipping_tax_amount: '',
                shipping_tax_refunded: ''
              }
            },
            stock_id: 0
          }
        ]
      },
      forced_shipment_with_invoice: 0,
      global_currency_code: '',
      grand_total: '',
      hold_before_state: '',
      hold_before_status: '',
      increment_id: '',
      is_virtual: 0,
      items: [{}],
      order_currency_code: '',
      original_increment_id: '',
      payment: {
        account_status: '',
        additional_data: '',
        additional_information: [],
        address_status: '',
        amount_authorized: '',
        amount_canceled: '',
        amount_ordered: '',
        amount_paid: '',
        amount_refunded: '',
        anet_trans_method: '',
        base_amount_authorized: '',
        base_amount_canceled: '',
        base_amount_ordered: '',
        base_amount_paid: '',
        base_amount_paid_online: '',
        base_amount_refunded: '',
        base_amount_refunded_online: '',
        base_shipping_amount: '',
        base_shipping_captured: '',
        base_shipping_refunded: '',
        cc_approval: '',
        cc_avs_status: '',
        cc_cid_status: '',
        cc_debug_request_body: '',
        cc_debug_response_body: '',
        cc_debug_response_serialized: '',
        cc_exp_month: '',
        cc_exp_year: '',
        cc_last4: '',
        cc_number_enc: '',
        cc_owner: '',
        cc_secure_verify: '',
        cc_ss_issue: '',
        cc_ss_start_month: '',
        cc_ss_start_year: '',
        cc_status: '',
        cc_status_description: '',
        cc_trans_id: '',
        cc_type: '',
        echeck_account_name: '',
        echeck_account_type: '',
        echeck_bank_name: '',
        echeck_routing_number: '',
        echeck_type: '',
        entity_id: 0,
        extension_attributes: {
          vault_payment_token: {
            created_at: '',
            customer_id: 0,
            entity_id: 0,
            expires_at: '',
            gateway_token: '',
            is_active: false,
            is_visible: false,
            payment_method_code: '',
            public_hash: '',
            token_details: '',
            type: ''
          }
        },
        last_trans_id: '',
        method: '',
        parent_id: 0,
        po_number: '',
        protection_eligibility: '',
        quote_payment_id: 0,
        shipping_amount: '',
        shipping_captured: '',
        shipping_refunded: ''
      },
      payment_auth_expiration: 0,
      payment_authorization_amount: '',
      protect_code: '',
      quote_address_id: 0,
      quote_id: 0,
      relation_child_id: '',
      relation_child_real_id: '',
      relation_parent_id: '',
      relation_parent_real_id: '',
      remote_ip: '',
      shipping_amount: '',
      shipping_canceled: '',
      shipping_description: '',
      shipping_discount_amount: '',
      shipping_discount_tax_compensation_amount: '',
      shipping_incl_tax: '',
      shipping_invoiced: '',
      shipping_refunded: '',
      shipping_tax_amount: '',
      shipping_tax_refunded: '',
      state: '',
      status: '',
      status_histories: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          entity_name: '',
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0,
          status: ''
        }
      ],
      store_currency_code: '',
      store_id: 0,
      store_name: '',
      store_to_base_rate: '',
      store_to_order_rate: '',
      subtotal: '',
      subtotal_canceled: '',
      subtotal_incl_tax: '',
      subtotal_invoiced: '',
      subtotal_refunded: '',
      tax_amount: '',
      tax_canceled: '',
      tax_invoiced: '',
      tax_refunded: '',
      total_canceled: '',
      total_due: '',
      total_invoiced: '',
      total_item_count: 0,
      total_offline_refunded: '',
      total_online_refunded: '',
      total_paid: '',
      total_qty_ordered: '',
      total_refunded: '',
      updated_at: '',
      weight: '',
      x_forwarded_for: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/orders/';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"adjustment_negative":"","adjustment_positive":"","applied_rule_ids":"","base_adjustment_negative":"","base_adjustment_positive":"","base_currency_code":"","base_discount_amount":"","base_discount_canceled":"","base_discount_invoiced":"","base_discount_refunded":"","base_discount_tax_compensation_amount":"","base_discount_tax_compensation_invoiced":"","base_discount_tax_compensation_refunded":"","base_grand_total":"","base_shipping_amount":"","base_shipping_canceled":"","base_shipping_discount_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_invoiced":"","base_shipping_refunded":"","base_shipping_tax_amount":"","base_shipping_tax_refunded":"","base_subtotal":"","base_subtotal_canceled":"","base_subtotal_incl_tax":"","base_subtotal_invoiced":"","base_subtotal_refunded":"","base_tax_amount":"","base_tax_canceled":"","base_tax_invoiced":"","base_tax_refunded":"","base_to_global_rate":"","base_to_order_rate":"","base_total_canceled":"","base_total_due":"","base_total_invoiced":"","base_total_invoiced_cost":"","base_total_offline_refunded":"","base_total_online_refunded":"","base_total_paid":"","base_total_qty_ordered":"","base_total_refunded":"","billing_address":{"address_type":"","city":"","company":"","country_id":"","customer_address_id":0,"customer_id":0,"email":"","entity_id":0,"extension_attributes":{"checkout_fields":[{"attribute_code":"","value":""}]},"fax":"","firstname":"","lastname":"","middlename":"","parent_id":0,"postcode":"","prefix":"","region":"","region_code":"","region_id":0,"street":[],"suffix":"","telephone":"","vat_id":"","vat_is_valid":0,"vat_request_date":"","vat_request_id":"","vat_request_success":0},"billing_address_id":0,"can_ship_partially":0,"can_ship_partially_item":0,"coupon_code":"","created_at":"","customer_dob":"","customer_email":"","customer_firstname":"","customer_gender":0,"customer_group_id":0,"customer_id":0,"customer_is_guest":0,"customer_lastname":"","customer_middlename":"","customer_note":"","customer_note_notify":0,"customer_prefix":"","customer_suffix":"","customer_taxvat":"","discount_amount":"","discount_canceled":"","discount_description":"","discount_invoiced":"","discount_refunded":"","discount_tax_compensation_amount":"","discount_tax_compensation_invoiced":"","discount_tax_compensation_refunded":"","edit_increment":0,"email_sent":0,"entity_id":0,"ext_customer_id":"","ext_order_id":"","extension_attributes":{"amazon_order_reference_id":"","applied_taxes":[{"amount":"","base_amount":"","code":"","extension_attributes":{"rates":[{"code":"","extension_attributes":{},"percent":"","title":""}]},"percent":"","title":""}],"base_customer_balance_amount":"","base_customer_balance_invoiced":"","base_customer_balance_refunded":"","base_customer_balance_total_refunded":"","base_gift_cards_amount":"","base_gift_cards_invoiced":"","base_gift_cards_refunded":"","base_reward_currency_amount":"","company_order_attributes":{"company_id":0,"company_name":"","extension_attributes":{},"order_id":0},"converting_from_quote":false,"customer_balance_amount":"","customer_balance_invoiced":"","customer_balance_refunded":"","customer_balance_total_refunded":"","gift_cards":[{"amount":"","base_amount":"","code":"","id":0}],"gift_cards_amount":"","gift_cards_invoiced":"","gift_cards_refunded":"","gift_message":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""},"gw_add_card":"","gw_allow_gift_receipt":"","gw_base_price":"","gw_base_price_incl_tax":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_card_base_price":"","gw_card_base_price_incl_tax":"","gw_card_base_price_invoiced":"","gw_card_base_price_refunded":"","gw_card_base_tax_amount":"","gw_card_base_tax_invoiced":"","gw_card_base_tax_refunded":"","gw_card_price":"","gw_card_price_incl_tax":"","gw_card_price_invoiced":"","gw_card_price_refunded":"","gw_card_tax_amount":"","gw_card_tax_invoiced":"","gw_card_tax_refunded":"","gw_id":"","gw_items_base_price":"","gw_items_base_price_incl_tax":"","gw_items_base_price_invoiced":"","gw_items_base_price_refunded":"","gw_items_base_tax_amount":"","gw_items_base_tax_invoiced":"","gw_items_base_tax_refunded":"","gw_items_price":"","gw_items_price_incl_tax":"","gw_items_price_invoiced":"","gw_items_price_refunded":"","gw_items_tax_amount":"","gw_items_tax_invoiced":"","gw_items_tax_refunded":"","gw_price":"","gw_price_incl_tax":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","item_applied_taxes":[{"applied_taxes":[{}],"associated_item_id":0,"extension_attributes":{},"item_id":0,"type":""}],"payment_additional_info":[{"key":"","value":""}],"reward_currency_amount":"","reward_points_balance":0,"shipping_assignments":[{"extension_attributes":{},"items":[{"additional_data":"","amount_refunded":"","applied_rule_ids":"","base_amount_refunded":"","base_cost":"","base_discount_amount":"","base_discount_invoiced":"","base_discount_refunded":"","base_discount_tax_compensation_amount":"","base_discount_tax_compensation_invoiced":"","base_discount_tax_compensation_refunded":"","base_original_price":"","base_price":"","base_price_incl_tax":"","base_row_invoiced":"","base_row_total":"","base_row_total_incl_tax":"","base_tax_amount":"","base_tax_before_discount":"","base_tax_invoiced":"","base_tax_refunded":"","base_weee_tax_applied_amount":"","base_weee_tax_applied_row_amnt":"","base_weee_tax_disposition":"","base_weee_tax_row_disposition":"","created_at":"","description":"","discount_amount":"","discount_invoiced":"","discount_percent":"","discount_refunded":"","discount_tax_compensation_amount":"","discount_tax_compensation_canceled":"","discount_tax_compensation_invoiced":"","discount_tax_compensation_refunded":"","event_id":0,"ext_order_item_id":"","extension_attributes":{"gift_message":{},"gw_base_price":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_id":"","gw_price":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","invoice_text_codes":[],"tax_codes":[],"vertex_tax_codes":[]},"free_shipping":0,"gw_base_price":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_id":0,"gw_price":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","is_qty_decimal":0,"is_virtual":0,"item_id":0,"locked_do_invoice":0,"locked_do_ship":0,"name":"","no_discount":0,"order_id":0,"original_price":"","parent_item":"","parent_item_id":0,"price":"","price_incl_tax":"","product_id":0,"product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty_backordered":"","qty_canceled":"","qty_invoiced":"","qty_ordered":"","qty_refunded":"","qty_returned":"","qty_shipped":"","quote_item_id":0,"row_invoiced":"","row_total":"","row_total_incl_tax":"","row_weight":"","sku":"","store_id":0,"tax_amount":"","tax_before_discount":"","tax_canceled":"","tax_invoiced":"","tax_percent":"","tax_refunded":"","updated_at":"","weee_tax_applied":"","weee_tax_applied_amount":"","weee_tax_applied_row_amount":"","weee_tax_disposition":"","weee_tax_row_disposition":"","weight":""}],"shipping":{"address":{},"extension_attributes":{"collection_point":{"city":"","collection_point_id":"","country":"","name":"","postcode":"","recipient_address_id":0,"region":"","street":[]},"ext_order_id":"","shipping_experience":{"code":"","cost":"","label":""}},"method":"","total":{"base_shipping_amount":"","base_shipping_canceled":"","base_shipping_discount_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_invoiced":"","base_shipping_refunded":"","base_shipping_tax_amount":"","base_shipping_tax_refunded":"","extension_attributes":{},"shipping_amount":"","shipping_canceled":"","shipping_discount_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_invoiced":"","shipping_refunded":"","shipping_tax_amount":"","shipping_tax_refunded":""}},"stock_id":0}]},"forced_shipment_with_invoice":0,"global_currency_code":"","grand_total":"","hold_before_state":"","hold_before_status":"","increment_id":"","is_virtual":0,"items":[{}],"order_currency_code":"","original_increment_id":"","payment":{"account_status":"","additional_data":"","additional_information":[],"address_status":"","amount_authorized":"","amount_canceled":"","amount_ordered":"","amount_paid":"","amount_refunded":"","anet_trans_method":"","base_amount_authorized":"","base_amount_canceled":"","base_amount_ordered":"","base_amount_paid":"","base_amount_paid_online":"","base_amount_refunded":"","base_amount_refunded_online":"","base_shipping_amount":"","base_shipping_captured":"","base_shipping_refunded":"","cc_approval":"","cc_avs_status":"","cc_cid_status":"","cc_debug_request_body":"","cc_debug_response_body":"","cc_debug_response_serialized":"","cc_exp_month":"","cc_exp_year":"","cc_last4":"","cc_number_enc":"","cc_owner":"","cc_secure_verify":"","cc_ss_issue":"","cc_ss_start_month":"","cc_ss_start_year":"","cc_status":"","cc_status_description":"","cc_trans_id":"","cc_type":"","echeck_account_name":"","echeck_account_type":"","echeck_bank_name":"","echeck_routing_number":"","echeck_type":"","entity_id":0,"extension_attributes":{"vault_payment_token":{"created_at":"","customer_id":0,"entity_id":0,"expires_at":"","gateway_token":"","is_active":false,"is_visible":false,"payment_method_code":"","public_hash":"","token_details":"","type":""}},"last_trans_id":"","method":"","parent_id":0,"po_number":"","protection_eligibility":"","quote_payment_id":0,"shipping_amount":"","shipping_captured":"","shipping_refunded":""},"payment_auth_expiration":0,"payment_authorization_amount":"","protect_code":"","quote_address_id":0,"quote_id":0,"relation_child_id":"","relation_child_real_id":"","relation_parent_id":"","relation_parent_real_id":"","remote_ip":"","shipping_amount":"","shipping_canceled":"","shipping_description":"","shipping_discount_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_invoiced":"","shipping_refunded":"","shipping_tax_amount":"","shipping_tax_refunded":"","state":"","status":"","status_histories":[{"comment":"","created_at":"","entity_id":0,"entity_name":"","extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_id":0,"status":""}],"store_currency_code":"","store_id":0,"store_name":"","store_to_base_rate":"","store_to_order_rate":"","subtotal":"","subtotal_canceled":"","subtotal_incl_tax":"","subtotal_invoiced":"","subtotal_refunded":"","tax_amount":"","tax_canceled":"","tax_invoiced":"","tax_refunded":"","total_canceled":"","total_due":"","total_invoiced":"","total_item_count":0,"total_offline_refunded":"","total_online_refunded":"","total_paid":"","total_qty_ordered":"","total_refunded":"","updated_at":"","weight":"","x_forwarded_for":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/orders/',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "entity": {\n    "adjustment_negative": "",\n    "adjustment_positive": "",\n    "applied_rule_ids": "",\n    "base_adjustment_negative": "",\n    "base_adjustment_positive": "",\n    "base_currency_code": "",\n    "base_discount_amount": "",\n    "base_discount_canceled": "",\n    "base_discount_invoiced": "",\n    "base_discount_refunded": "",\n    "base_discount_tax_compensation_amount": "",\n    "base_discount_tax_compensation_invoiced": "",\n    "base_discount_tax_compensation_refunded": "",\n    "base_grand_total": "",\n    "base_shipping_amount": "",\n    "base_shipping_canceled": "",\n    "base_shipping_discount_amount": "",\n    "base_shipping_discount_tax_compensation_amnt": "",\n    "base_shipping_incl_tax": "",\n    "base_shipping_invoiced": "",\n    "base_shipping_refunded": "",\n    "base_shipping_tax_amount": "",\n    "base_shipping_tax_refunded": "",\n    "base_subtotal": "",\n    "base_subtotal_canceled": "",\n    "base_subtotal_incl_tax": "",\n    "base_subtotal_invoiced": "",\n    "base_subtotal_refunded": "",\n    "base_tax_amount": "",\n    "base_tax_canceled": "",\n    "base_tax_invoiced": "",\n    "base_tax_refunded": "",\n    "base_to_global_rate": "",\n    "base_to_order_rate": "",\n    "base_total_canceled": "",\n    "base_total_due": "",\n    "base_total_invoiced": "",\n    "base_total_invoiced_cost": "",\n    "base_total_offline_refunded": "",\n    "base_total_online_refunded": "",\n    "base_total_paid": "",\n    "base_total_qty_ordered": "",\n    "base_total_refunded": "",\n    "billing_address": {\n      "address_type": "",\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "entity_id": 0,\n      "extension_attributes": {\n        "checkout_fields": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ]\n      },\n      "fax": "",\n      "firstname": "",\n      "lastname": "",\n      "middlename": "",\n      "parent_id": 0,\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": "",\n      "vat_is_valid": 0,\n      "vat_request_date": "",\n      "vat_request_id": "",\n      "vat_request_success": 0\n    },\n    "billing_address_id": 0,\n    "can_ship_partially": 0,\n    "can_ship_partially_item": 0,\n    "coupon_code": "",\n    "created_at": "",\n    "customer_dob": "",\n    "customer_email": "",\n    "customer_firstname": "",\n    "customer_gender": 0,\n    "customer_group_id": 0,\n    "customer_id": 0,\n    "customer_is_guest": 0,\n    "customer_lastname": "",\n    "customer_middlename": "",\n    "customer_note": "",\n    "customer_note_notify": 0,\n    "customer_prefix": "",\n    "customer_suffix": "",\n    "customer_taxvat": "",\n    "discount_amount": "",\n    "discount_canceled": "",\n    "discount_description": "",\n    "discount_invoiced": "",\n    "discount_refunded": "",\n    "discount_tax_compensation_amount": "",\n    "discount_tax_compensation_invoiced": "",\n    "discount_tax_compensation_refunded": "",\n    "edit_increment": 0,\n    "email_sent": 0,\n    "entity_id": 0,\n    "ext_customer_id": "",\n    "ext_order_id": "",\n    "extension_attributes": {\n      "amazon_order_reference_id": "",\n      "applied_taxes": [\n        {\n          "amount": "",\n          "base_amount": "",\n          "code": "",\n          "extension_attributes": {\n            "rates": [\n              {\n                "code": "",\n                "extension_attributes": {},\n                "percent": "",\n                "title": ""\n              }\n            ]\n          },\n          "percent": "",\n          "title": ""\n        }\n      ],\n      "base_customer_balance_amount": "",\n      "base_customer_balance_invoiced": "",\n      "base_customer_balance_refunded": "",\n      "base_customer_balance_total_refunded": "",\n      "base_gift_cards_amount": "",\n      "base_gift_cards_invoiced": "",\n      "base_gift_cards_refunded": "",\n      "base_reward_currency_amount": "",\n      "company_order_attributes": {\n        "company_id": 0,\n        "company_name": "",\n        "extension_attributes": {},\n        "order_id": 0\n      },\n      "converting_from_quote": false,\n      "customer_balance_amount": "",\n      "customer_balance_invoiced": "",\n      "customer_balance_refunded": "",\n      "customer_balance_total_refunded": "",\n      "gift_cards": [\n        {\n          "amount": "",\n          "base_amount": "",\n          "code": "",\n          "id": 0\n        }\n      ],\n      "gift_cards_amount": "",\n      "gift_cards_invoiced": "",\n      "gift_cards_refunded": "",\n      "gift_message": {\n        "customer_id": 0,\n        "extension_attributes": {\n          "entity_id": "",\n          "entity_type": "",\n          "wrapping_add_printed_card": false,\n          "wrapping_allow_gift_receipt": false,\n          "wrapping_id": 0\n        },\n        "gift_message_id": 0,\n        "message": "",\n        "recipient": "",\n        "sender": ""\n      },\n      "gw_add_card": "",\n      "gw_allow_gift_receipt": "",\n      "gw_base_price": "",\n      "gw_base_price_incl_tax": "",\n      "gw_base_price_invoiced": "",\n      "gw_base_price_refunded": "",\n      "gw_base_tax_amount": "",\n      "gw_base_tax_amount_invoiced": "",\n      "gw_base_tax_amount_refunded": "",\n      "gw_card_base_price": "",\n      "gw_card_base_price_incl_tax": "",\n      "gw_card_base_price_invoiced": "",\n      "gw_card_base_price_refunded": "",\n      "gw_card_base_tax_amount": "",\n      "gw_card_base_tax_invoiced": "",\n      "gw_card_base_tax_refunded": "",\n      "gw_card_price": "",\n      "gw_card_price_incl_tax": "",\n      "gw_card_price_invoiced": "",\n      "gw_card_price_refunded": "",\n      "gw_card_tax_amount": "",\n      "gw_card_tax_invoiced": "",\n      "gw_card_tax_refunded": "",\n      "gw_id": "",\n      "gw_items_base_price": "",\n      "gw_items_base_price_incl_tax": "",\n      "gw_items_base_price_invoiced": "",\n      "gw_items_base_price_refunded": "",\n      "gw_items_base_tax_amount": "",\n      "gw_items_base_tax_invoiced": "",\n      "gw_items_base_tax_refunded": "",\n      "gw_items_price": "",\n      "gw_items_price_incl_tax": "",\n      "gw_items_price_invoiced": "",\n      "gw_items_price_refunded": "",\n      "gw_items_tax_amount": "",\n      "gw_items_tax_invoiced": "",\n      "gw_items_tax_refunded": "",\n      "gw_price": "",\n      "gw_price_incl_tax": "",\n      "gw_price_invoiced": "",\n      "gw_price_refunded": "",\n      "gw_tax_amount": "",\n      "gw_tax_amount_invoiced": "",\n      "gw_tax_amount_refunded": "",\n      "item_applied_taxes": [\n        {\n          "applied_taxes": [\n            {}\n          ],\n          "associated_item_id": 0,\n          "extension_attributes": {},\n          "item_id": 0,\n          "type": ""\n        }\n      ],\n      "payment_additional_info": [\n        {\n          "key": "",\n          "value": ""\n        }\n      ],\n      "reward_currency_amount": "",\n      "reward_points_balance": 0,\n      "shipping_assignments": [\n        {\n          "extension_attributes": {},\n          "items": [\n            {\n              "additional_data": "",\n              "amount_refunded": "",\n              "applied_rule_ids": "",\n              "base_amount_refunded": "",\n              "base_cost": "",\n              "base_discount_amount": "",\n              "base_discount_invoiced": "",\n              "base_discount_refunded": "",\n              "base_discount_tax_compensation_amount": "",\n              "base_discount_tax_compensation_invoiced": "",\n              "base_discount_tax_compensation_refunded": "",\n              "base_original_price": "",\n              "base_price": "",\n              "base_price_incl_tax": "",\n              "base_row_invoiced": "",\n              "base_row_total": "",\n              "base_row_total_incl_tax": "",\n              "base_tax_amount": "",\n              "base_tax_before_discount": "",\n              "base_tax_invoiced": "",\n              "base_tax_refunded": "",\n              "base_weee_tax_applied_amount": "",\n              "base_weee_tax_applied_row_amnt": "",\n              "base_weee_tax_disposition": "",\n              "base_weee_tax_row_disposition": "",\n              "created_at": "",\n              "description": "",\n              "discount_amount": "",\n              "discount_invoiced": "",\n              "discount_percent": "",\n              "discount_refunded": "",\n              "discount_tax_compensation_amount": "",\n              "discount_tax_compensation_canceled": "",\n              "discount_tax_compensation_invoiced": "",\n              "discount_tax_compensation_refunded": "",\n              "event_id": 0,\n              "ext_order_item_id": "",\n              "extension_attributes": {\n                "gift_message": {},\n                "gw_base_price": "",\n                "gw_base_price_invoiced": "",\n                "gw_base_price_refunded": "",\n                "gw_base_tax_amount": "",\n                "gw_base_tax_amount_invoiced": "",\n                "gw_base_tax_amount_refunded": "",\n                "gw_id": "",\n                "gw_price": "",\n                "gw_price_invoiced": "",\n                "gw_price_refunded": "",\n                "gw_tax_amount": "",\n                "gw_tax_amount_invoiced": "",\n                "gw_tax_amount_refunded": "",\n                "invoice_text_codes": [],\n                "tax_codes": [],\n                "vertex_tax_codes": []\n              },\n              "free_shipping": 0,\n              "gw_base_price": "",\n              "gw_base_price_invoiced": "",\n              "gw_base_price_refunded": "",\n              "gw_base_tax_amount": "",\n              "gw_base_tax_amount_invoiced": "",\n              "gw_base_tax_amount_refunded": "",\n              "gw_id": 0,\n              "gw_price": "",\n              "gw_price_invoiced": "",\n              "gw_price_refunded": "",\n              "gw_tax_amount": "",\n              "gw_tax_amount_invoiced": "",\n              "gw_tax_amount_refunded": "",\n              "is_qty_decimal": 0,\n              "is_virtual": 0,\n              "item_id": 0,\n              "locked_do_invoice": 0,\n              "locked_do_ship": 0,\n              "name": "",\n              "no_discount": 0,\n              "order_id": 0,\n              "original_price": "",\n              "parent_item": "",\n              "parent_item_id": 0,\n              "price": "",\n              "price_incl_tax": "",\n              "product_id": 0,\n              "product_option": {\n                "extension_attributes": {\n                  "bundle_options": [\n                    {\n                      "extension_attributes": {},\n                      "option_id": 0,\n                      "option_qty": 0,\n                      "option_selections": []\n                    }\n                  ],\n                  "configurable_item_options": [\n                    {\n                      "extension_attributes": {},\n                      "option_id": "",\n                      "option_value": 0\n                    }\n                  ],\n                  "custom_options": [\n                    {\n                      "extension_attributes": {\n                        "file_info": {\n                          "base64_encoded_data": "",\n                          "name": "",\n                          "type": ""\n                        }\n                      },\n                      "option_id": "",\n                      "option_value": ""\n                    }\n                  ],\n                  "downloadable_option": {\n                    "downloadable_links": []\n                  },\n                  "giftcard_item_option": {\n                    "custom_giftcard_amount": "",\n                    "extension_attributes": {},\n                    "giftcard_amount": "",\n                    "giftcard_message": "",\n                    "giftcard_recipient_email": "",\n                    "giftcard_recipient_name": "",\n                    "giftcard_sender_email": "",\n                    "giftcard_sender_name": ""\n                  }\n                }\n              },\n              "product_type": "",\n              "qty_backordered": "",\n              "qty_canceled": "",\n              "qty_invoiced": "",\n              "qty_ordered": "",\n              "qty_refunded": "",\n              "qty_returned": "",\n              "qty_shipped": "",\n              "quote_item_id": 0,\n              "row_invoiced": "",\n              "row_total": "",\n              "row_total_incl_tax": "",\n              "row_weight": "",\n              "sku": "",\n              "store_id": 0,\n              "tax_amount": "",\n              "tax_before_discount": "",\n              "tax_canceled": "",\n              "tax_invoiced": "",\n              "tax_percent": "",\n              "tax_refunded": "",\n              "updated_at": "",\n              "weee_tax_applied": "",\n              "weee_tax_applied_amount": "",\n              "weee_tax_applied_row_amount": "",\n              "weee_tax_disposition": "",\n              "weee_tax_row_disposition": "",\n              "weight": ""\n            }\n          ],\n          "shipping": {\n            "address": {},\n            "extension_attributes": {\n              "collection_point": {\n                "city": "",\n                "collection_point_id": "",\n                "country": "",\n                "name": "",\n                "postcode": "",\n                "recipient_address_id": 0,\n                "region": "",\n                "street": []\n              },\n              "ext_order_id": "",\n              "shipping_experience": {\n                "code": "",\n                "cost": "",\n                "label": ""\n              }\n            },\n            "method": "",\n            "total": {\n              "base_shipping_amount": "",\n              "base_shipping_canceled": "",\n              "base_shipping_discount_amount": "",\n              "base_shipping_discount_tax_compensation_amnt": "",\n              "base_shipping_incl_tax": "",\n              "base_shipping_invoiced": "",\n              "base_shipping_refunded": "",\n              "base_shipping_tax_amount": "",\n              "base_shipping_tax_refunded": "",\n              "extension_attributes": {},\n              "shipping_amount": "",\n              "shipping_canceled": "",\n              "shipping_discount_amount": "",\n              "shipping_discount_tax_compensation_amount": "",\n              "shipping_incl_tax": "",\n              "shipping_invoiced": "",\n              "shipping_refunded": "",\n              "shipping_tax_amount": "",\n              "shipping_tax_refunded": ""\n            }\n          },\n          "stock_id": 0\n        }\n      ]\n    },\n    "forced_shipment_with_invoice": 0,\n    "global_currency_code": "",\n    "grand_total": "",\n    "hold_before_state": "",\n    "hold_before_status": "",\n    "increment_id": "",\n    "is_virtual": 0,\n    "items": [\n      {}\n    ],\n    "order_currency_code": "",\n    "original_increment_id": "",\n    "payment": {\n      "account_status": "",\n      "additional_data": "",\n      "additional_information": [],\n      "address_status": "",\n      "amount_authorized": "",\n      "amount_canceled": "",\n      "amount_ordered": "",\n      "amount_paid": "",\n      "amount_refunded": "",\n      "anet_trans_method": "",\n      "base_amount_authorized": "",\n      "base_amount_canceled": "",\n      "base_amount_ordered": "",\n      "base_amount_paid": "",\n      "base_amount_paid_online": "",\n      "base_amount_refunded": "",\n      "base_amount_refunded_online": "",\n      "base_shipping_amount": "",\n      "base_shipping_captured": "",\n      "base_shipping_refunded": "",\n      "cc_approval": "",\n      "cc_avs_status": "",\n      "cc_cid_status": "",\n      "cc_debug_request_body": "",\n      "cc_debug_response_body": "",\n      "cc_debug_response_serialized": "",\n      "cc_exp_month": "",\n      "cc_exp_year": "",\n      "cc_last4": "",\n      "cc_number_enc": "",\n      "cc_owner": "",\n      "cc_secure_verify": "",\n      "cc_ss_issue": "",\n      "cc_ss_start_month": "",\n      "cc_ss_start_year": "",\n      "cc_status": "",\n      "cc_status_description": "",\n      "cc_trans_id": "",\n      "cc_type": "",\n      "echeck_account_name": "",\n      "echeck_account_type": "",\n      "echeck_bank_name": "",\n      "echeck_routing_number": "",\n      "echeck_type": "",\n      "entity_id": 0,\n      "extension_attributes": {\n        "vault_payment_token": {\n          "created_at": "",\n          "customer_id": 0,\n          "entity_id": 0,\n          "expires_at": "",\n          "gateway_token": "",\n          "is_active": false,\n          "is_visible": false,\n          "payment_method_code": "",\n          "public_hash": "",\n          "token_details": "",\n          "type": ""\n        }\n      },\n      "last_trans_id": "",\n      "method": "",\n      "parent_id": 0,\n      "po_number": "",\n      "protection_eligibility": "",\n      "quote_payment_id": 0,\n      "shipping_amount": "",\n      "shipping_captured": "",\n      "shipping_refunded": ""\n    },\n    "payment_auth_expiration": 0,\n    "payment_authorization_amount": "",\n    "protect_code": "",\n    "quote_address_id": 0,\n    "quote_id": 0,\n    "relation_child_id": "",\n    "relation_child_real_id": "",\n    "relation_parent_id": "",\n    "relation_parent_real_id": "",\n    "remote_ip": "",\n    "shipping_amount": "",\n    "shipping_canceled": "",\n    "shipping_description": "",\n    "shipping_discount_amount": "",\n    "shipping_discount_tax_compensation_amount": "",\n    "shipping_incl_tax": "",\n    "shipping_invoiced": "",\n    "shipping_refunded": "",\n    "shipping_tax_amount": "",\n    "shipping_tax_refunded": "",\n    "state": "",\n    "status": "",\n    "status_histories": [\n      {\n        "comment": "",\n        "created_at": "",\n        "entity_id": 0,\n        "entity_name": "",\n        "extension_attributes": {},\n        "is_customer_notified": 0,\n        "is_visible_on_front": 0,\n        "parent_id": 0,\n        "status": ""\n      }\n    ],\n    "store_currency_code": "",\n    "store_id": 0,\n    "store_name": "",\n    "store_to_base_rate": "",\n    "store_to_order_rate": "",\n    "subtotal": "",\n    "subtotal_canceled": "",\n    "subtotal_incl_tax": "",\n    "subtotal_invoiced": "",\n    "subtotal_refunded": "",\n    "tax_amount": "",\n    "tax_canceled": "",\n    "tax_invoiced": "",\n    "tax_refunded": "",\n    "total_canceled": "",\n    "total_due": "",\n    "total_invoiced": "",\n    "total_item_count": 0,\n    "total_offline_refunded": "",\n    "total_online_refunded": "",\n    "total_paid": "",\n    "total_qty_ordered": "",\n    "total_refunded": "",\n    "updated_at": "",\n    "weight": "",\n    "x_forwarded_for": ""\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  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/orders/")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/orders/',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  entity: {
    adjustment_negative: '',
    adjustment_positive: '',
    applied_rule_ids: '',
    base_adjustment_negative: '',
    base_adjustment_positive: '',
    base_currency_code: '',
    base_discount_amount: '',
    base_discount_canceled: '',
    base_discount_invoiced: '',
    base_discount_refunded: '',
    base_discount_tax_compensation_amount: '',
    base_discount_tax_compensation_invoiced: '',
    base_discount_tax_compensation_refunded: '',
    base_grand_total: '',
    base_shipping_amount: '',
    base_shipping_canceled: '',
    base_shipping_discount_amount: '',
    base_shipping_discount_tax_compensation_amnt: '',
    base_shipping_incl_tax: '',
    base_shipping_invoiced: '',
    base_shipping_refunded: '',
    base_shipping_tax_amount: '',
    base_shipping_tax_refunded: '',
    base_subtotal: '',
    base_subtotal_canceled: '',
    base_subtotal_incl_tax: '',
    base_subtotal_invoiced: '',
    base_subtotal_refunded: '',
    base_tax_amount: '',
    base_tax_canceled: '',
    base_tax_invoiced: '',
    base_tax_refunded: '',
    base_to_global_rate: '',
    base_to_order_rate: '',
    base_total_canceled: '',
    base_total_due: '',
    base_total_invoiced: '',
    base_total_invoiced_cost: '',
    base_total_offline_refunded: '',
    base_total_online_refunded: '',
    base_total_paid: '',
    base_total_qty_ordered: '',
    base_total_refunded: '',
    billing_address: {
      address_type: '',
      city: '',
      company: '',
      country_id: '',
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      entity_id: 0,
      extension_attributes: {checkout_fields: [{attribute_code: '', value: ''}]},
      fax: '',
      firstname: '',
      lastname: '',
      middlename: '',
      parent_id: 0,
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: '',
      vat_is_valid: 0,
      vat_request_date: '',
      vat_request_id: '',
      vat_request_success: 0
    },
    billing_address_id: 0,
    can_ship_partially: 0,
    can_ship_partially_item: 0,
    coupon_code: '',
    created_at: '',
    customer_dob: '',
    customer_email: '',
    customer_firstname: '',
    customer_gender: 0,
    customer_group_id: 0,
    customer_id: 0,
    customer_is_guest: 0,
    customer_lastname: '',
    customer_middlename: '',
    customer_note: '',
    customer_note_notify: 0,
    customer_prefix: '',
    customer_suffix: '',
    customer_taxvat: '',
    discount_amount: '',
    discount_canceled: '',
    discount_description: '',
    discount_invoiced: '',
    discount_refunded: '',
    discount_tax_compensation_amount: '',
    discount_tax_compensation_invoiced: '',
    discount_tax_compensation_refunded: '',
    edit_increment: 0,
    email_sent: 0,
    entity_id: 0,
    ext_customer_id: '',
    ext_order_id: '',
    extension_attributes: {
      amazon_order_reference_id: '',
      applied_taxes: [
        {
          amount: '',
          base_amount: '',
          code: '',
          extension_attributes: {rates: [{code: '', extension_attributes: {}, percent: '', title: ''}]},
          percent: '',
          title: ''
        }
      ],
      base_customer_balance_amount: '',
      base_customer_balance_invoiced: '',
      base_customer_balance_refunded: '',
      base_customer_balance_total_refunded: '',
      base_gift_cards_amount: '',
      base_gift_cards_invoiced: '',
      base_gift_cards_refunded: '',
      base_reward_currency_amount: '',
      company_order_attributes: {company_id: 0, company_name: '', extension_attributes: {}, order_id: 0},
      converting_from_quote: false,
      customer_balance_amount: '',
      customer_balance_invoiced: '',
      customer_balance_refunded: '',
      customer_balance_total_refunded: '',
      gift_cards: [{amount: '', base_amount: '', code: '', id: 0}],
      gift_cards_amount: '',
      gift_cards_invoiced: '',
      gift_cards_refunded: '',
      gift_message: {
        customer_id: 0,
        extension_attributes: {
          entity_id: '',
          entity_type: '',
          wrapping_add_printed_card: false,
          wrapping_allow_gift_receipt: false,
          wrapping_id: 0
        },
        gift_message_id: 0,
        message: '',
        recipient: '',
        sender: ''
      },
      gw_add_card: '',
      gw_allow_gift_receipt: '',
      gw_base_price: '',
      gw_base_price_incl_tax: '',
      gw_base_price_invoiced: '',
      gw_base_price_refunded: '',
      gw_base_tax_amount: '',
      gw_base_tax_amount_invoiced: '',
      gw_base_tax_amount_refunded: '',
      gw_card_base_price: '',
      gw_card_base_price_incl_tax: '',
      gw_card_base_price_invoiced: '',
      gw_card_base_price_refunded: '',
      gw_card_base_tax_amount: '',
      gw_card_base_tax_invoiced: '',
      gw_card_base_tax_refunded: '',
      gw_card_price: '',
      gw_card_price_incl_tax: '',
      gw_card_price_invoiced: '',
      gw_card_price_refunded: '',
      gw_card_tax_amount: '',
      gw_card_tax_invoiced: '',
      gw_card_tax_refunded: '',
      gw_id: '',
      gw_items_base_price: '',
      gw_items_base_price_incl_tax: '',
      gw_items_base_price_invoiced: '',
      gw_items_base_price_refunded: '',
      gw_items_base_tax_amount: '',
      gw_items_base_tax_invoiced: '',
      gw_items_base_tax_refunded: '',
      gw_items_price: '',
      gw_items_price_incl_tax: '',
      gw_items_price_invoiced: '',
      gw_items_price_refunded: '',
      gw_items_tax_amount: '',
      gw_items_tax_invoiced: '',
      gw_items_tax_refunded: '',
      gw_price: '',
      gw_price_incl_tax: '',
      gw_price_invoiced: '',
      gw_price_refunded: '',
      gw_tax_amount: '',
      gw_tax_amount_invoiced: '',
      gw_tax_amount_refunded: '',
      item_applied_taxes: [
        {
          applied_taxes: [{}],
          associated_item_id: 0,
          extension_attributes: {},
          item_id: 0,
          type: ''
        }
      ],
      payment_additional_info: [{key: '', value: ''}],
      reward_currency_amount: '',
      reward_points_balance: 0,
      shipping_assignments: [
        {
          extension_attributes: {},
          items: [
            {
              additional_data: '',
              amount_refunded: '',
              applied_rule_ids: '',
              base_amount_refunded: '',
              base_cost: '',
              base_discount_amount: '',
              base_discount_invoiced: '',
              base_discount_refunded: '',
              base_discount_tax_compensation_amount: '',
              base_discount_tax_compensation_invoiced: '',
              base_discount_tax_compensation_refunded: '',
              base_original_price: '',
              base_price: '',
              base_price_incl_tax: '',
              base_row_invoiced: '',
              base_row_total: '',
              base_row_total_incl_tax: '',
              base_tax_amount: '',
              base_tax_before_discount: '',
              base_tax_invoiced: '',
              base_tax_refunded: '',
              base_weee_tax_applied_amount: '',
              base_weee_tax_applied_row_amnt: '',
              base_weee_tax_disposition: '',
              base_weee_tax_row_disposition: '',
              created_at: '',
              description: '',
              discount_amount: '',
              discount_invoiced: '',
              discount_percent: '',
              discount_refunded: '',
              discount_tax_compensation_amount: '',
              discount_tax_compensation_canceled: '',
              discount_tax_compensation_invoiced: '',
              discount_tax_compensation_refunded: '',
              event_id: 0,
              ext_order_item_id: '',
              extension_attributes: {
                gift_message: {},
                gw_base_price: '',
                gw_base_price_invoiced: '',
                gw_base_price_refunded: '',
                gw_base_tax_amount: '',
                gw_base_tax_amount_invoiced: '',
                gw_base_tax_amount_refunded: '',
                gw_id: '',
                gw_price: '',
                gw_price_invoiced: '',
                gw_price_refunded: '',
                gw_tax_amount: '',
                gw_tax_amount_invoiced: '',
                gw_tax_amount_refunded: '',
                invoice_text_codes: [],
                tax_codes: [],
                vertex_tax_codes: []
              },
              free_shipping: 0,
              gw_base_price: '',
              gw_base_price_invoiced: '',
              gw_base_price_refunded: '',
              gw_base_tax_amount: '',
              gw_base_tax_amount_invoiced: '',
              gw_base_tax_amount_refunded: '',
              gw_id: 0,
              gw_price: '',
              gw_price_invoiced: '',
              gw_price_refunded: '',
              gw_tax_amount: '',
              gw_tax_amount_invoiced: '',
              gw_tax_amount_refunded: '',
              is_qty_decimal: 0,
              is_virtual: 0,
              item_id: 0,
              locked_do_invoice: 0,
              locked_do_ship: 0,
              name: '',
              no_discount: 0,
              order_id: 0,
              original_price: '',
              parent_item: '',
              parent_item_id: 0,
              price: '',
              price_incl_tax: '',
              product_id: 0,
              product_option: {
                extension_attributes: {
                  bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                  configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                  custom_options: [
                    {
                      extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                      option_id: '',
                      option_value: ''
                    }
                  ],
                  downloadable_option: {downloadable_links: []},
                  giftcard_item_option: {
                    custom_giftcard_amount: '',
                    extension_attributes: {},
                    giftcard_amount: '',
                    giftcard_message: '',
                    giftcard_recipient_email: '',
                    giftcard_recipient_name: '',
                    giftcard_sender_email: '',
                    giftcard_sender_name: ''
                  }
                }
              },
              product_type: '',
              qty_backordered: '',
              qty_canceled: '',
              qty_invoiced: '',
              qty_ordered: '',
              qty_refunded: '',
              qty_returned: '',
              qty_shipped: '',
              quote_item_id: 0,
              row_invoiced: '',
              row_total: '',
              row_total_incl_tax: '',
              row_weight: '',
              sku: '',
              store_id: 0,
              tax_amount: '',
              tax_before_discount: '',
              tax_canceled: '',
              tax_invoiced: '',
              tax_percent: '',
              tax_refunded: '',
              updated_at: '',
              weee_tax_applied: '',
              weee_tax_applied_amount: '',
              weee_tax_applied_row_amount: '',
              weee_tax_disposition: '',
              weee_tax_row_disposition: '',
              weight: ''
            }
          ],
          shipping: {
            address: {},
            extension_attributes: {
              collection_point: {
                city: '',
                collection_point_id: '',
                country: '',
                name: '',
                postcode: '',
                recipient_address_id: 0,
                region: '',
                street: []
              },
              ext_order_id: '',
              shipping_experience: {code: '', cost: '', label: ''}
            },
            method: '',
            total: {
              base_shipping_amount: '',
              base_shipping_canceled: '',
              base_shipping_discount_amount: '',
              base_shipping_discount_tax_compensation_amnt: '',
              base_shipping_incl_tax: '',
              base_shipping_invoiced: '',
              base_shipping_refunded: '',
              base_shipping_tax_amount: '',
              base_shipping_tax_refunded: '',
              extension_attributes: {},
              shipping_amount: '',
              shipping_canceled: '',
              shipping_discount_amount: '',
              shipping_discount_tax_compensation_amount: '',
              shipping_incl_tax: '',
              shipping_invoiced: '',
              shipping_refunded: '',
              shipping_tax_amount: '',
              shipping_tax_refunded: ''
            }
          },
          stock_id: 0
        }
      ]
    },
    forced_shipment_with_invoice: 0,
    global_currency_code: '',
    grand_total: '',
    hold_before_state: '',
    hold_before_status: '',
    increment_id: '',
    is_virtual: 0,
    items: [{}],
    order_currency_code: '',
    original_increment_id: '',
    payment: {
      account_status: '',
      additional_data: '',
      additional_information: [],
      address_status: '',
      amount_authorized: '',
      amount_canceled: '',
      amount_ordered: '',
      amount_paid: '',
      amount_refunded: '',
      anet_trans_method: '',
      base_amount_authorized: '',
      base_amount_canceled: '',
      base_amount_ordered: '',
      base_amount_paid: '',
      base_amount_paid_online: '',
      base_amount_refunded: '',
      base_amount_refunded_online: '',
      base_shipping_amount: '',
      base_shipping_captured: '',
      base_shipping_refunded: '',
      cc_approval: '',
      cc_avs_status: '',
      cc_cid_status: '',
      cc_debug_request_body: '',
      cc_debug_response_body: '',
      cc_debug_response_serialized: '',
      cc_exp_month: '',
      cc_exp_year: '',
      cc_last4: '',
      cc_number_enc: '',
      cc_owner: '',
      cc_secure_verify: '',
      cc_ss_issue: '',
      cc_ss_start_month: '',
      cc_ss_start_year: '',
      cc_status: '',
      cc_status_description: '',
      cc_trans_id: '',
      cc_type: '',
      echeck_account_name: '',
      echeck_account_type: '',
      echeck_bank_name: '',
      echeck_routing_number: '',
      echeck_type: '',
      entity_id: 0,
      extension_attributes: {
        vault_payment_token: {
          created_at: '',
          customer_id: 0,
          entity_id: 0,
          expires_at: '',
          gateway_token: '',
          is_active: false,
          is_visible: false,
          payment_method_code: '',
          public_hash: '',
          token_details: '',
          type: ''
        }
      },
      last_trans_id: '',
      method: '',
      parent_id: 0,
      po_number: '',
      protection_eligibility: '',
      quote_payment_id: 0,
      shipping_amount: '',
      shipping_captured: '',
      shipping_refunded: ''
    },
    payment_auth_expiration: 0,
    payment_authorization_amount: '',
    protect_code: '',
    quote_address_id: 0,
    quote_id: 0,
    relation_child_id: '',
    relation_child_real_id: '',
    relation_parent_id: '',
    relation_parent_real_id: '',
    remote_ip: '',
    shipping_amount: '',
    shipping_canceled: '',
    shipping_description: '',
    shipping_discount_amount: '',
    shipping_discount_tax_compensation_amount: '',
    shipping_incl_tax: '',
    shipping_invoiced: '',
    shipping_refunded: '',
    shipping_tax_amount: '',
    shipping_tax_refunded: '',
    state: '',
    status: '',
    status_histories: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        entity_name: '',
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0,
        status: ''
      }
    ],
    store_currency_code: '',
    store_id: 0,
    store_name: '',
    store_to_base_rate: '',
    store_to_order_rate: '',
    subtotal: '',
    subtotal_canceled: '',
    subtotal_incl_tax: '',
    subtotal_invoiced: '',
    subtotal_refunded: '',
    tax_amount: '',
    tax_canceled: '',
    tax_invoiced: '',
    tax_refunded: '',
    total_canceled: '',
    total_due: '',
    total_invoiced: '',
    total_item_count: 0,
    total_offline_refunded: '',
    total_online_refunded: '',
    total_paid: '',
    total_qty_ordered: '',
    total_refunded: '',
    updated_at: '',
    weight: '',
    x_forwarded_for: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/orders/',
  headers: {'content-type': 'application/json'},
  body: {
    entity: {
      adjustment_negative: '',
      adjustment_positive: '',
      applied_rule_ids: '',
      base_adjustment_negative: '',
      base_adjustment_positive: '',
      base_currency_code: '',
      base_discount_amount: '',
      base_discount_canceled: '',
      base_discount_invoiced: '',
      base_discount_refunded: '',
      base_discount_tax_compensation_amount: '',
      base_discount_tax_compensation_invoiced: '',
      base_discount_tax_compensation_refunded: '',
      base_grand_total: '',
      base_shipping_amount: '',
      base_shipping_canceled: '',
      base_shipping_discount_amount: '',
      base_shipping_discount_tax_compensation_amnt: '',
      base_shipping_incl_tax: '',
      base_shipping_invoiced: '',
      base_shipping_refunded: '',
      base_shipping_tax_amount: '',
      base_shipping_tax_refunded: '',
      base_subtotal: '',
      base_subtotal_canceled: '',
      base_subtotal_incl_tax: '',
      base_subtotal_invoiced: '',
      base_subtotal_refunded: '',
      base_tax_amount: '',
      base_tax_canceled: '',
      base_tax_invoiced: '',
      base_tax_refunded: '',
      base_to_global_rate: '',
      base_to_order_rate: '',
      base_total_canceled: '',
      base_total_due: '',
      base_total_invoiced: '',
      base_total_invoiced_cost: '',
      base_total_offline_refunded: '',
      base_total_online_refunded: '',
      base_total_paid: '',
      base_total_qty_ordered: '',
      base_total_refunded: '',
      billing_address: {
        address_type: '',
        city: '',
        company: '',
        country_id: '',
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        entity_id: 0,
        extension_attributes: {checkout_fields: [{attribute_code: '', value: ''}]},
        fax: '',
        firstname: '',
        lastname: '',
        middlename: '',
        parent_id: 0,
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: '',
        vat_is_valid: 0,
        vat_request_date: '',
        vat_request_id: '',
        vat_request_success: 0
      },
      billing_address_id: 0,
      can_ship_partially: 0,
      can_ship_partially_item: 0,
      coupon_code: '',
      created_at: '',
      customer_dob: '',
      customer_email: '',
      customer_firstname: '',
      customer_gender: 0,
      customer_group_id: 0,
      customer_id: 0,
      customer_is_guest: 0,
      customer_lastname: '',
      customer_middlename: '',
      customer_note: '',
      customer_note_notify: 0,
      customer_prefix: '',
      customer_suffix: '',
      customer_taxvat: '',
      discount_amount: '',
      discount_canceled: '',
      discount_description: '',
      discount_invoiced: '',
      discount_refunded: '',
      discount_tax_compensation_amount: '',
      discount_tax_compensation_invoiced: '',
      discount_tax_compensation_refunded: '',
      edit_increment: 0,
      email_sent: 0,
      entity_id: 0,
      ext_customer_id: '',
      ext_order_id: '',
      extension_attributes: {
        amazon_order_reference_id: '',
        applied_taxes: [
          {
            amount: '',
            base_amount: '',
            code: '',
            extension_attributes: {rates: [{code: '', extension_attributes: {}, percent: '', title: ''}]},
            percent: '',
            title: ''
          }
        ],
        base_customer_balance_amount: '',
        base_customer_balance_invoiced: '',
        base_customer_balance_refunded: '',
        base_customer_balance_total_refunded: '',
        base_gift_cards_amount: '',
        base_gift_cards_invoiced: '',
        base_gift_cards_refunded: '',
        base_reward_currency_amount: '',
        company_order_attributes: {company_id: 0, company_name: '', extension_attributes: {}, order_id: 0},
        converting_from_quote: false,
        customer_balance_amount: '',
        customer_balance_invoiced: '',
        customer_balance_refunded: '',
        customer_balance_total_refunded: '',
        gift_cards: [{amount: '', base_amount: '', code: '', id: 0}],
        gift_cards_amount: '',
        gift_cards_invoiced: '',
        gift_cards_refunded: '',
        gift_message: {
          customer_id: 0,
          extension_attributes: {
            entity_id: '',
            entity_type: '',
            wrapping_add_printed_card: false,
            wrapping_allow_gift_receipt: false,
            wrapping_id: 0
          },
          gift_message_id: 0,
          message: '',
          recipient: '',
          sender: ''
        },
        gw_add_card: '',
        gw_allow_gift_receipt: '',
        gw_base_price: '',
        gw_base_price_incl_tax: '',
        gw_base_price_invoiced: '',
        gw_base_price_refunded: '',
        gw_base_tax_amount: '',
        gw_base_tax_amount_invoiced: '',
        gw_base_tax_amount_refunded: '',
        gw_card_base_price: '',
        gw_card_base_price_incl_tax: '',
        gw_card_base_price_invoiced: '',
        gw_card_base_price_refunded: '',
        gw_card_base_tax_amount: '',
        gw_card_base_tax_invoiced: '',
        gw_card_base_tax_refunded: '',
        gw_card_price: '',
        gw_card_price_incl_tax: '',
        gw_card_price_invoiced: '',
        gw_card_price_refunded: '',
        gw_card_tax_amount: '',
        gw_card_tax_invoiced: '',
        gw_card_tax_refunded: '',
        gw_id: '',
        gw_items_base_price: '',
        gw_items_base_price_incl_tax: '',
        gw_items_base_price_invoiced: '',
        gw_items_base_price_refunded: '',
        gw_items_base_tax_amount: '',
        gw_items_base_tax_invoiced: '',
        gw_items_base_tax_refunded: '',
        gw_items_price: '',
        gw_items_price_incl_tax: '',
        gw_items_price_invoiced: '',
        gw_items_price_refunded: '',
        gw_items_tax_amount: '',
        gw_items_tax_invoiced: '',
        gw_items_tax_refunded: '',
        gw_price: '',
        gw_price_incl_tax: '',
        gw_price_invoiced: '',
        gw_price_refunded: '',
        gw_tax_amount: '',
        gw_tax_amount_invoiced: '',
        gw_tax_amount_refunded: '',
        item_applied_taxes: [
          {
            applied_taxes: [{}],
            associated_item_id: 0,
            extension_attributes: {},
            item_id: 0,
            type: ''
          }
        ],
        payment_additional_info: [{key: '', value: ''}],
        reward_currency_amount: '',
        reward_points_balance: 0,
        shipping_assignments: [
          {
            extension_attributes: {},
            items: [
              {
                additional_data: '',
                amount_refunded: '',
                applied_rule_ids: '',
                base_amount_refunded: '',
                base_cost: '',
                base_discount_amount: '',
                base_discount_invoiced: '',
                base_discount_refunded: '',
                base_discount_tax_compensation_amount: '',
                base_discount_tax_compensation_invoiced: '',
                base_discount_tax_compensation_refunded: '',
                base_original_price: '',
                base_price: '',
                base_price_incl_tax: '',
                base_row_invoiced: '',
                base_row_total: '',
                base_row_total_incl_tax: '',
                base_tax_amount: '',
                base_tax_before_discount: '',
                base_tax_invoiced: '',
                base_tax_refunded: '',
                base_weee_tax_applied_amount: '',
                base_weee_tax_applied_row_amnt: '',
                base_weee_tax_disposition: '',
                base_weee_tax_row_disposition: '',
                created_at: '',
                description: '',
                discount_amount: '',
                discount_invoiced: '',
                discount_percent: '',
                discount_refunded: '',
                discount_tax_compensation_amount: '',
                discount_tax_compensation_canceled: '',
                discount_tax_compensation_invoiced: '',
                discount_tax_compensation_refunded: '',
                event_id: 0,
                ext_order_item_id: '',
                extension_attributes: {
                  gift_message: {},
                  gw_base_price: '',
                  gw_base_price_invoiced: '',
                  gw_base_price_refunded: '',
                  gw_base_tax_amount: '',
                  gw_base_tax_amount_invoiced: '',
                  gw_base_tax_amount_refunded: '',
                  gw_id: '',
                  gw_price: '',
                  gw_price_invoiced: '',
                  gw_price_refunded: '',
                  gw_tax_amount: '',
                  gw_tax_amount_invoiced: '',
                  gw_tax_amount_refunded: '',
                  invoice_text_codes: [],
                  tax_codes: [],
                  vertex_tax_codes: []
                },
                free_shipping: 0,
                gw_base_price: '',
                gw_base_price_invoiced: '',
                gw_base_price_refunded: '',
                gw_base_tax_amount: '',
                gw_base_tax_amount_invoiced: '',
                gw_base_tax_amount_refunded: '',
                gw_id: 0,
                gw_price: '',
                gw_price_invoiced: '',
                gw_price_refunded: '',
                gw_tax_amount: '',
                gw_tax_amount_invoiced: '',
                gw_tax_amount_refunded: '',
                is_qty_decimal: 0,
                is_virtual: 0,
                item_id: 0,
                locked_do_invoice: 0,
                locked_do_ship: 0,
                name: '',
                no_discount: 0,
                order_id: 0,
                original_price: '',
                parent_item: '',
                parent_item_id: 0,
                price: '',
                price_incl_tax: '',
                product_id: 0,
                product_option: {
                  extension_attributes: {
                    bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                    configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                    custom_options: [
                      {
                        extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                        option_id: '',
                        option_value: ''
                      }
                    ],
                    downloadable_option: {downloadable_links: []},
                    giftcard_item_option: {
                      custom_giftcard_amount: '',
                      extension_attributes: {},
                      giftcard_amount: '',
                      giftcard_message: '',
                      giftcard_recipient_email: '',
                      giftcard_recipient_name: '',
                      giftcard_sender_email: '',
                      giftcard_sender_name: ''
                    }
                  }
                },
                product_type: '',
                qty_backordered: '',
                qty_canceled: '',
                qty_invoiced: '',
                qty_ordered: '',
                qty_refunded: '',
                qty_returned: '',
                qty_shipped: '',
                quote_item_id: 0,
                row_invoiced: '',
                row_total: '',
                row_total_incl_tax: '',
                row_weight: '',
                sku: '',
                store_id: 0,
                tax_amount: '',
                tax_before_discount: '',
                tax_canceled: '',
                tax_invoiced: '',
                tax_percent: '',
                tax_refunded: '',
                updated_at: '',
                weee_tax_applied: '',
                weee_tax_applied_amount: '',
                weee_tax_applied_row_amount: '',
                weee_tax_disposition: '',
                weee_tax_row_disposition: '',
                weight: ''
              }
            ],
            shipping: {
              address: {},
              extension_attributes: {
                collection_point: {
                  city: '',
                  collection_point_id: '',
                  country: '',
                  name: '',
                  postcode: '',
                  recipient_address_id: 0,
                  region: '',
                  street: []
                },
                ext_order_id: '',
                shipping_experience: {code: '', cost: '', label: ''}
              },
              method: '',
              total: {
                base_shipping_amount: '',
                base_shipping_canceled: '',
                base_shipping_discount_amount: '',
                base_shipping_discount_tax_compensation_amnt: '',
                base_shipping_incl_tax: '',
                base_shipping_invoiced: '',
                base_shipping_refunded: '',
                base_shipping_tax_amount: '',
                base_shipping_tax_refunded: '',
                extension_attributes: {},
                shipping_amount: '',
                shipping_canceled: '',
                shipping_discount_amount: '',
                shipping_discount_tax_compensation_amount: '',
                shipping_incl_tax: '',
                shipping_invoiced: '',
                shipping_refunded: '',
                shipping_tax_amount: '',
                shipping_tax_refunded: ''
              }
            },
            stock_id: 0
          }
        ]
      },
      forced_shipment_with_invoice: 0,
      global_currency_code: '',
      grand_total: '',
      hold_before_state: '',
      hold_before_status: '',
      increment_id: '',
      is_virtual: 0,
      items: [{}],
      order_currency_code: '',
      original_increment_id: '',
      payment: {
        account_status: '',
        additional_data: '',
        additional_information: [],
        address_status: '',
        amount_authorized: '',
        amount_canceled: '',
        amount_ordered: '',
        amount_paid: '',
        amount_refunded: '',
        anet_trans_method: '',
        base_amount_authorized: '',
        base_amount_canceled: '',
        base_amount_ordered: '',
        base_amount_paid: '',
        base_amount_paid_online: '',
        base_amount_refunded: '',
        base_amount_refunded_online: '',
        base_shipping_amount: '',
        base_shipping_captured: '',
        base_shipping_refunded: '',
        cc_approval: '',
        cc_avs_status: '',
        cc_cid_status: '',
        cc_debug_request_body: '',
        cc_debug_response_body: '',
        cc_debug_response_serialized: '',
        cc_exp_month: '',
        cc_exp_year: '',
        cc_last4: '',
        cc_number_enc: '',
        cc_owner: '',
        cc_secure_verify: '',
        cc_ss_issue: '',
        cc_ss_start_month: '',
        cc_ss_start_year: '',
        cc_status: '',
        cc_status_description: '',
        cc_trans_id: '',
        cc_type: '',
        echeck_account_name: '',
        echeck_account_type: '',
        echeck_bank_name: '',
        echeck_routing_number: '',
        echeck_type: '',
        entity_id: 0,
        extension_attributes: {
          vault_payment_token: {
            created_at: '',
            customer_id: 0,
            entity_id: 0,
            expires_at: '',
            gateway_token: '',
            is_active: false,
            is_visible: false,
            payment_method_code: '',
            public_hash: '',
            token_details: '',
            type: ''
          }
        },
        last_trans_id: '',
        method: '',
        parent_id: 0,
        po_number: '',
        protection_eligibility: '',
        quote_payment_id: 0,
        shipping_amount: '',
        shipping_captured: '',
        shipping_refunded: ''
      },
      payment_auth_expiration: 0,
      payment_authorization_amount: '',
      protect_code: '',
      quote_address_id: 0,
      quote_id: 0,
      relation_child_id: '',
      relation_child_real_id: '',
      relation_parent_id: '',
      relation_parent_real_id: '',
      remote_ip: '',
      shipping_amount: '',
      shipping_canceled: '',
      shipping_description: '',
      shipping_discount_amount: '',
      shipping_discount_tax_compensation_amount: '',
      shipping_incl_tax: '',
      shipping_invoiced: '',
      shipping_refunded: '',
      shipping_tax_amount: '',
      shipping_tax_refunded: '',
      state: '',
      status: '',
      status_histories: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          entity_name: '',
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0,
          status: ''
        }
      ],
      store_currency_code: '',
      store_id: 0,
      store_name: '',
      store_to_base_rate: '',
      store_to_order_rate: '',
      subtotal: '',
      subtotal_canceled: '',
      subtotal_incl_tax: '',
      subtotal_invoiced: '',
      subtotal_refunded: '',
      tax_amount: '',
      tax_canceled: '',
      tax_invoiced: '',
      tax_refunded: '',
      total_canceled: '',
      total_due: '',
      total_invoiced: '',
      total_item_count: 0,
      total_offline_refunded: '',
      total_online_refunded: '',
      total_paid: '',
      total_qty_ordered: '',
      total_refunded: '',
      updated_at: '',
      weight: '',
      x_forwarded_for: ''
    }
  },
  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}}/V1/orders/');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  entity: {
    adjustment_negative: '',
    adjustment_positive: '',
    applied_rule_ids: '',
    base_adjustment_negative: '',
    base_adjustment_positive: '',
    base_currency_code: '',
    base_discount_amount: '',
    base_discount_canceled: '',
    base_discount_invoiced: '',
    base_discount_refunded: '',
    base_discount_tax_compensation_amount: '',
    base_discount_tax_compensation_invoiced: '',
    base_discount_tax_compensation_refunded: '',
    base_grand_total: '',
    base_shipping_amount: '',
    base_shipping_canceled: '',
    base_shipping_discount_amount: '',
    base_shipping_discount_tax_compensation_amnt: '',
    base_shipping_incl_tax: '',
    base_shipping_invoiced: '',
    base_shipping_refunded: '',
    base_shipping_tax_amount: '',
    base_shipping_tax_refunded: '',
    base_subtotal: '',
    base_subtotal_canceled: '',
    base_subtotal_incl_tax: '',
    base_subtotal_invoiced: '',
    base_subtotal_refunded: '',
    base_tax_amount: '',
    base_tax_canceled: '',
    base_tax_invoiced: '',
    base_tax_refunded: '',
    base_to_global_rate: '',
    base_to_order_rate: '',
    base_total_canceled: '',
    base_total_due: '',
    base_total_invoiced: '',
    base_total_invoiced_cost: '',
    base_total_offline_refunded: '',
    base_total_online_refunded: '',
    base_total_paid: '',
    base_total_qty_ordered: '',
    base_total_refunded: '',
    billing_address: {
      address_type: '',
      city: '',
      company: '',
      country_id: '',
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      entity_id: 0,
      extension_attributes: {
        checkout_fields: [
          {
            attribute_code: '',
            value: ''
          }
        ]
      },
      fax: '',
      firstname: '',
      lastname: '',
      middlename: '',
      parent_id: 0,
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: '',
      vat_is_valid: 0,
      vat_request_date: '',
      vat_request_id: '',
      vat_request_success: 0
    },
    billing_address_id: 0,
    can_ship_partially: 0,
    can_ship_partially_item: 0,
    coupon_code: '',
    created_at: '',
    customer_dob: '',
    customer_email: '',
    customer_firstname: '',
    customer_gender: 0,
    customer_group_id: 0,
    customer_id: 0,
    customer_is_guest: 0,
    customer_lastname: '',
    customer_middlename: '',
    customer_note: '',
    customer_note_notify: 0,
    customer_prefix: '',
    customer_suffix: '',
    customer_taxvat: '',
    discount_amount: '',
    discount_canceled: '',
    discount_description: '',
    discount_invoiced: '',
    discount_refunded: '',
    discount_tax_compensation_amount: '',
    discount_tax_compensation_invoiced: '',
    discount_tax_compensation_refunded: '',
    edit_increment: 0,
    email_sent: 0,
    entity_id: 0,
    ext_customer_id: '',
    ext_order_id: '',
    extension_attributes: {
      amazon_order_reference_id: '',
      applied_taxes: [
        {
          amount: '',
          base_amount: '',
          code: '',
          extension_attributes: {
            rates: [
              {
                code: '',
                extension_attributes: {},
                percent: '',
                title: ''
              }
            ]
          },
          percent: '',
          title: ''
        }
      ],
      base_customer_balance_amount: '',
      base_customer_balance_invoiced: '',
      base_customer_balance_refunded: '',
      base_customer_balance_total_refunded: '',
      base_gift_cards_amount: '',
      base_gift_cards_invoiced: '',
      base_gift_cards_refunded: '',
      base_reward_currency_amount: '',
      company_order_attributes: {
        company_id: 0,
        company_name: '',
        extension_attributes: {},
        order_id: 0
      },
      converting_from_quote: false,
      customer_balance_amount: '',
      customer_balance_invoiced: '',
      customer_balance_refunded: '',
      customer_balance_total_refunded: '',
      gift_cards: [
        {
          amount: '',
          base_amount: '',
          code: '',
          id: 0
        }
      ],
      gift_cards_amount: '',
      gift_cards_invoiced: '',
      gift_cards_refunded: '',
      gift_message: {
        customer_id: 0,
        extension_attributes: {
          entity_id: '',
          entity_type: '',
          wrapping_add_printed_card: false,
          wrapping_allow_gift_receipt: false,
          wrapping_id: 0
        },
        gift_message_id: 0,
        message: '',
        recipient: '',
        sender: ''
      },
      gw_add_card: '',
      gw_allow_gift_receipt: '',
      gw_base_price: '',
      gw_base_price_incl_tax: '',
      gw_base_price_invoiced: '',
      gw_base_price_refunded: '',
      gw_base_tax_amount: '',
      gw_base_tax_amount_invoiced: '',
      gw_base_tax_amount_refunded: '',
      gw_card_base_price: '',
      gw_card_base_price_incl_tax: '',
      gw_card_base_price_invoiced: '',
      gw_card_base_price_refunded: '',
      gw_card_base_tax_amount: '',
      gw_card_base_tax_invoiced: '',
      gw_card_base_tax_refunded: '',
      gw_card_price: '',
      gw_card_price_incl_tax: '',
      gw_card_price_invoiced: '',
      gw_card_price_refunded: '',
      gw_card_tax_amount: '',
      gw_card_tax_invoiced: '',
      gw_card_tax_refunded: '',
      gw_id: '',
      gw_items_base_price: '',
      gw_items_base_price_incl_tax: '',
      gw_items_base_price_invoiced: '',
      gw_items_base_price_refunded: '',
      gw_items_base_tax_amount: '',
      gw_items_base_tax_invoiced: '',
      gw_items_base_tax_refunded: '',
      gw_items_price: '',
      gw_items_price_incl_tax: '',
      gw_items_price_invoiced: '',
      gw_items_price_refunded: '',
      gw_items_tax_amount: '',
      gw_items_tax_invoiced: '',
      gw_items_tax_refunded: '',
      gw_price: '',
      gw_price_incl_tax: '',
      gw_price_invoiced: '',
      gw_price_refunded: '',
      gw_tax_amount: '',
      gw_tax_amount_invoiced: '',
      gw_tax_amount_refunded: '',
      item_applied_taxes: [
        {
          applied_taxes: [
            {}
          ],
          associated_item_id: 0,
          extension_attributes: {},
          item_id: 0,
          type: ''
        }
      ],
      payment_additional_info: [
        {
          key: '',
          value: ''
        }
      ],
      reward_currency_amount: '',
      reward_points_balance: 0,
      shipping_assignments: [
        {
          extension_attributes: {},
          items: [
            {
              additional_data: '',
              amount_refunded: '',
              applied_rule_ids: '',
              base_amount_refunded: '',
              base_cost: '',
              base_discount_amount: '',
              base_discount_invoiced: '',
              base_discount_refunded: '',
              base_discount_tax_compensation_amount: '',
              base_discount_tax_compensation_invoiced: '',
              base_discount_tax_compensation_refunded: '',
              base_original_price: '',
              base_price: '',
              base_price_incl_tax: '',
              base_row_invoiced: '',
              base_row_total: '',
              base_row_total_incl_tax: '',
              base_tax_amount: '',
              base_tax_before_discount: '',
              base_tax_invoiced: '',
              base_tax_refunded: '',
              base_weee_tax_applied_amount: '',
              base_weee_tax_applied_row_amnt: '',
              base_weee_tax_disposition: '',
              base_weee_tax_row_disposition: '',
              created_at: '',
              description: '',
              discount_amount: '',
              discount_invoiced: '',
              discount_percent: '',
              discount_refunded: '',
              discount_tax_compensation_amount: '',
              discount_tax_compensation_canceled: '',
              discount_tax_compensation_invoiced: '',
              discount_tax_compensation_refunded: '',
              event_id: 0,
              ext_order_item_id: '',
              extension_attributes: {
                gift_message: {},
                gw_base_price: '',
                gw_base_price_invoiced: '',
                gw_base_price_refunded: '',
                gw_base_tax_amount: '',
                gw_base_tax_amount_invoiced: '',
                gw_base_tax_amount_refunded: '',
                gw_id: '',
                gw_price: '',
                gw_price_invoiced: '',
                gw_price_refunded: '',
                gw_tax_amount: '',
                gw_tax_amount_invoiced: '',
                gw_tax_amount_refunded: '',
                invoice_text_codes: [],
                tax_codes: [],
                vertex_tax_codes: []
              },
              free_shipping: 0,
              gw_base_price: '',
              gw_base_price_invoiced: '',
              gw_base_price_refunded: '',
              gw_base_tax_amount: '',
              gw_base_tax_amount_invoiced: '',
              gw_base_tax_amount_refunded: '',
              gw_id: 0,
              gw_price: '',
              gw_price_invoiced: '',
              gw_price_refunded: '',
              gw_tax_amount: '',
              gw_tax_amount_invoiced: '',
              gw_tax_amount_refunded: '',
              is_qty_decimal: 0,
              is_virtual: 0,
              item_id: 0,
              locked_do_invoice: 0,
              locked_do_ship: 0,
              name: '',
              no_discount: 0,
              order_id: 0,
              original_price: '',
              parent_item: '',
              parent_item_id: 0,
              price: '',
              price_incl_tax: '',
              product_id: 0,
              product_option: {
                extension_attributes: {
                  bundle_options: [
                    {
                      extension_attributes: {},
                      option_id: 0,
                      option_qty: 0,
                      option_selections: []
                    }
                  ],
                  configurable_item_options: [
                    {
                      extension_attributes: {},
                      option_id: '',
                      option_value: 0
                    }
                  ],
                  custom_options: [
                    {
                      extension_attributes: {
                        file_info: {
                          base64_encoded_data: '',
                          name: '',
                          type: ''
                        }
                      },
                      option_id: '',
                      option_value: ''
                    }
                  ],
                  downloadable_option: {
                    downloadable_links: []
                  },
                  giftcard_item_option: {
                    custom_giftcard_amount: '',
                    extension_attributes: {},
                    giftcard_amount: '',
                    giftcard_message: '',
                    giftcard_recipient_email: '',
                    giftcard_recipient_name: '',
                    giftcard_sender_email: '',
                    giftcard_sender_name: ''
                  }
                }
              },
              product_type: '',
              qty_backordered: '',
              qty_canceled: '',
              qty_invoiced: '',
              qty_ordered: '',
              qty_refunded: '',
              qty_returned: '',
              qty_shipped: '',
              quote_item_id: 0,
              row_invoiced: '',
              row_total: '',
              row_total_incl_tax: '',
              row_weight: '',
              sku: '',
              store_id: 0,
              tax_amount: '',
              tax_before_discount: '',
              tax_canceled: '',
              tax_invoiced: '',
              tax_percent: '',
              tax_refunded: '',
              updated_at: '',
              weee_tax_applied: '',
              weee_tax_applied_amount: '',
              weee_tax_applied_row_amount: '',
              weee_tax_disposition: '',
              weee_tax_row_disposition: '',
              weight: ''
            }
          ],
          shipping: {
            address: {},
            extension_attributes: {
              collection_point: {
                city: '',
                collection_point_id: '',
                country: '',
                name: '',
                postcode: '',
                recipient_address_id: 0,
                region: '',
                street: []
              },
              ext_order_id: '',
              shipping_experience: {
                code: '',
                cost: '',
                label: ''
              }
            },
            method: '',
            total: {
              base_shipping_amount: '',
              base_shipping_canceled: '',
              base_shipping_discount_amount: '',
              base_shipping_discount_tax_compensation_amnt: '',
              base_shipping_incl_tax: '',
              base_shipping_invoiced: '',
              base_shipping_refunded: '',
              base_shipping_tax_amount: '',
              base_shipping_tax_refunded: '',
              extension_attributes: {},
              shipping_amount: '',
              shipping_canceled: '',
              shipping_discount_amount: '',
              shipping_discount_tax_compensation_amount: '',
              shipping_incl_tax: '',
              shipping_invoiced: '',
              shipping_refunded: '',
              shipping_tax_amount: '',
              shipping_tax_refunded: ''
            }
          },
          stock_id: 0
        }
      ]
    },
    forced_shipment_with_invoice: 0,
    global_currency_code: '',
    grand_total: '',
    hold_before_state: '',
    hold_before_status: '',
    increment_id: '',
    is_virtual: 0,
    items: [
      {}
    ],
    order_currency_code: '',
    original_increment_id: '',
    payment: {
      account_status: '',
      additional_data: '',
      additional_information: [],
      address_status: '',
      amount_authorized: '',
      amount_canceled: '',
      amount_ordered: '',
      amount_paid: '',
      amount_refunded: '',
      anet_trans_method: '',
      base_amount_authorized: '',
      base_amount_canceled: '',
      base_amount_ordered: '',
      base_amount_paid: '',
      base_amount_paid_online: '',
      base_amount_refunded: '',
      base_amount_refunded_online: '',
      base_shipping_amount: '',
      base_shipping_captured: '',
      base_shipping_refunded: '',
      cc_approval: '',
      cc_avs_status: '',
      cc_cid_status: '',
      cc_debug_request_body: '',
      cc_debug_response_body: '',
      cc_debug_response_serialized: '',
      cc_exp_month: '',
      cc_exp_year: '',
      cc_last4: '',
      cc_number_enc: '',
      cc_owner: '',
      cc_secure_verify: '',
      cc_ss_issue: '',
      cc_ss_start_month: '',
      cc_ss_start_year: '',
      cc_status: '',
      cc_status_description: '',
      cc_trans_id: '',
      cc_type: '',
      echeck_account_name: '',
      echeck_account_type: '',
      echeck_bank_name: '',
      echeck_routing_number: '',
      echeck_type: '',
      entity_id: 0,
      extension_attributes: {
        vault_payment_token: {
          created_at: '',
          customer_id: 0,
          entity_id: 0,
          expires_at: '',
          gateway_token: '',
          is_active: false,
          is_visible: false,
          payment_method_code: '',
          public_hash: '',
          token_details: '',
          type: ''
        }
      },
      last_trans_id: '',
      method: '',
      parent_id: 0,
      po_number: '',
      protection_eligibility: '',
      quote_payment_id: 0,
      shipping_amount: '',
      shipping_captured: '',
      shipping_refunded: ''
    },
    payment_auth_expiration: 0,
    payment_authorization_amount: '',
    protect_code: '',
    quote_address_id: 0,
    quote_id: 0,
    relation_child_id: '',
    relation_child_real_id: '',
    relation_parent_id: '',
    relation_parent_real_id: '',
    remote_ip: '',
    shipping_amount: '',
    shipping_canceled: '',
    shipping_description: '',
    shipping_discount_amount: '',
    shipping_discount_tax_compensation_amount: '',
    shipping_incl_tax: '',
    shipping_invoiced: '',
    shipping_refunded: '',
    shipping_tax_amount: '',
    shipping_tax_refunded: '',
    state: '',
    status: '',
    status_histories: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        entity_name: '',
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0,
        status: ''
      }
    ],
    store_currency_code: '',
    store_id: 0,
    store_name: '',
    store_to_base_rate: '',
    store_to_order_rate: '',
    subtotal: '',
    subtotal_canceled: '',
    subtotal_incl_tax: '',
    subtotal_invoiced: '',
    subtotal_refunded: '',
    tax_amount: '',
    tax_canceled: '',
    tax_invoiced: '',
    tax_refunded: '',
    total_canceled: '',
    total_due: '',
    total_invoiced: '',
    total_item_count: 0,
    total_offline_refunded: '',
    total_online_refunded: '',
    total_paid: '',
    total_qty_ordered: '',
    total_refunded: '',
    updated_at: '',
    weight: '',
    x_forwarded_for: ''
  }
});

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}}/V1/orders/',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      adjustment_negative: '',
      adjustment_positive: '',
      applied_rule_ids: '',
      base_adjustment_negative: '',
      base_adjustment_positive: '',
      base_currency_code: '',
      base_discount_amount: '',
      base_discount_canceled: '',
      base_discount_invoiced: '',
      base_discount_refunded: '',
      base_discount_tax_compensation_amount: '',
      base_discount_tax_compensation_invoiced: '',
      base_discount_tax_compensation_refunded: '',
      base_grand_total: '',
      base_shipping_amount: '',
      base_shipping_canceled: '',
      base_shipping_discount_amount: '',
      base_shipping_discount_tax_compensation_amnt: '',
      base_shipping_incl_tax: '',
      base_shipping_invoiced: '',
      base_shipping_refunded: '',
      base_shipping_tax_amount: '',
      base_shipping_tax_refunded: '',
      base_subtotal: '',
      base_subtotal_canceled: '',
      base_subtotal_incl_tax: '',
      base_subtotal_invoiced: '',
      base_subtotal_refunded: '',
      base_tax_amount: '',
      base_tax_canceled: '',
      base_tax_invoiced: '',
      base_tax_refunded: '',
      base_to_global_rate: '',
      base_to_order_rate: '',
      base_total_canceled: '',
      base_total_due: '',
      base_total_invoiced: '',
      base_total_invoiced_cost: '',
      base_total_offline_refunded: '',
      base_total_online_refunded: '',
      base_total_paid: '',
      base_total_qty_ordered: '',
      base_total_refunded: '',
      billing_address: {
        address_type: '',
        city: '',
        company: '',
        country_id: '',
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        entity_id: 0,
        extension_attributes: {checkout_fields: [{attribute_code: '', value: ''}]},
        fax: '',
        firstname: '',
        lastname: '',
        middlename: '',
        parent_id: 0,
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: '',
        vat_is_valid: 0,
        vat_request_date: '',
        vat_request_id: '',
        vat_request_success: 0
      },
      billing_address_id: 0,
      can_ship_partially: 0,
      can_ship_partially_item: 0,
      coupon_code: '',
      created_at: '',
      customer_dob: '',
      customer_email: '',
      customer_firstname: '',
      customer_gender: 0,
      customer_group_id: 0,
      customer_id: 0,
      customer_is_guest: 0,
      customer_lastname: '',
      customer_middlename: '',
      customer_note: '',
      customer_note_notify: 0,
      customer_prefix: '',
      customer_suffix: '',
      customer_taxvat: '',
      discount_amount: '',
      discount_canceled: '',
      discount_description: '',
      discount_invoiced: '',
      discount_refunded: '',
      discount_tax_compensation_amount: '',
      discount_tax_compensation_invoiced: '',
      discount_tax_compensation_refunded: '',
      edit_increment: 0,
      email_sent: 0,
      entity_id: 0,
      ext_customer_id: '',
      ext_order_id: '',
      extension_attributes: {
        amazon_order_reference_id: '',
        applied_taxes: [
          {
            amount: '',
            base_amount: '',
            code: '',
            extension_attributes: {rates: [{code: '', extension_attributes: {}, percent: '', title: ''}]},
            percent: '',
            title: ''
          }
        ],
        base_customer_balance_amount: '',
        base_customer_balance_invoiced: '',
        base_customer_balance_refunded: '',
        base_customer_balance_total_refunded: '',
        base_gift_cards_amount: '',
        base_gift_cards_invoiced: '',
        base_gift_cards_refunded: '',
        base_reward_currency_amount: '',
        company_order_attributes: {company_id: 0, company_name: '', extension_attributes: {}, order_id: 0},
        converting_from_quote: false,
        customer_balance_amount: '',
        customer_balance_invoiced: '',
        customer_balance_refunded: '',
        customer_balance_total_refunded: '',
        gift_cards: [{amount: '', base_amount: '', code: '', id: 0}],
        gift_cards_amount: '',
        gift_cards_invoiced: '',
        gift_cards_refunded: '',
        gift_message: {
          customer_id: 0,
          extension_attributes: {
            entity_id: '',
            entity_type: '',
            wrapping_add_printed_card: false,
            wrapping_allow_gift_receipt: false,
            wrapping_id: 0
          },
          gift_message_id: 0,
          message: '',
          recipient: '',
          sender: ''
        },
        gw_add_card: '',
        gw_allow_gift_receipt: '',
        gw_base_price: '',
        gw_base_price_incl_tax: '',
        gw_base_price_invoiced: '',
        gw_base_price_refunded: '',
        gw_base_tax_amount: '',
        gw_base_tax_amount_invoiced: '',
        gw_base_tax_amount_refunded: '',
        gw_card_base_price: '',
        gw_card_base_price_incl_tax: '',
        gw_card_base_price_invoiced: '',
        gw_card_base_price_refunded: '',
        gw_card_base_tax_amount: '',
        gw_card_base_tax_invoiced: '',
        gw_card_base_tax_refunded: '',
        gw_card_price: '',
        gw_card_price_incl_tax: '',
        gw_card_price_invoiced: '',
        gw_card_price_refunded: '',
        gw_card_tax_amount: '',
        gw_card_tax_invoiced: '',
        gw_card_tax_refunded: '',
        gw_id: '',
        gw_items_base_price: '',
        gw_items_base_price_incl_tax: '',
        gw_items_base_price_invoiced: '',
        gw_items_base_price_refunded: '',
        gw_items_base_tax_amount: '',
        gw_items_base_tax_invoiced: '',
        gw_items_base_tax_refunded: '',
        gw_items_price: '',
        gw_items_price_incl_tax: '',
        gw_items_price_invoiced: '',
        gw_items_price_refunded: '',
        gw_items_tax_amount: '',
        gw_items_tax_invoiced: '',
        gw_items_tax_refunded: '',
        gw_price: '',
        gw_price_incl_tax: '',
        gw_price_invoiced: '',
        gw_price_refunded: '',
        gw_tax_amount: '',
        gw_tax_amount_invoiced: '',
        gw_tax_amount_refunded: '',
        item_applied_taxes: [
          {
            applied_taxes: [{}],
            associated_item_id: 0,
            extension_attributes: {},
            item_id: 0,
            type: ''
          }
        ],
        payment_additional_info: [{key: '', value: ''}],
        reward_currency_amount: '',
        reward_points_balance: 0,
        shipping_assignments: [
          {
            extension_attributes: {},
            items: [
              {
                additional_data: '',
                amount_refunded: '',
                applied_rule_ids: '',
                base_amount_refunded: '',
                base_cost: '',
                base_discount_amount: '',
                base_discount_invoiced: '',
                base_discount_refunded: '',
                base_discount_tax_compensation_amount: '',
                base_discount_tax_compensation_invoiced: '',
                base_discount_tax_compensation_refunded: '',
                base_original_price: '',
                base_price: '',
                base_price_incl_tax: '',
                base_row_invoiced: '',
                base_row_total: '',
                base_row_total_incl_tax: '',
                base_tax_amount: '',
                base_tax_before_discount: '',
                base_tax_invoiced: '',
                base_tax_refunded: '',
                base_weee_tax_applied_amount: '',
                base_weee_tax_applied_row_amnt: '',
                base_weee_tax_disposition: '',
                base_weee_tax_row_disposition: '',
                created_at: '',
                description: '',
                discount_amount: '',
                discount_invoiced: '',
                discount_percent: '',
                discount_refunded: '',
                discount_tax_compensation_amount: '',
                discount_tax_compensation_canceled: '',
                discount_tax_compensation_invoiced: '',
                discount_tax_compensation_refunded: '',
                event_id: 0,
                ext_order_item_id: '',
                extension_attributes: {
                  gift_message: {},
                  gw_base_price: '',
                  gw_base_price_invoiced: '',
                  gw_base_price_refunded: '',
                  gw_base_tax_amount: '',
                  gw_base_tax_amount_invoiced: '',
                  gw_base_tax_amount_refunded: '',
                  gw_id: '',
                  gw_price: '',
                  gw_price_invoiced: '',
                  gw_price_refunded: '',
                  gw_tax_amount: '',
                  gw_tax_amount_invoiced: '',
                  gw_tax_amount_refunded: '',
                  invoice_text_codes: [],
                  tax_codes: [],
                  vertex_tax_codes: []
                },
                free_shipping: 0,
                gw_base_price: '',
                gw_base_price_invoiced: '',
                gw_base_price_refunded: '',
                gw_base_tax_amount: '',
                gw_base_tax_amount_invoiced: '',
                gw_base_tax_amount_refunded: '',
                gw_id: 0,
                gw_price: '',
                gw_price_invoiced: '',
                gw_price_refunded: '',
                gw_tax_amount: '',
                gw_tax_amount_invoiced: '',
                gw_tax_amount_refunded: '',
                is_qty_decimal: 0,
                is_virtual: 0,
                item_id: 0,
                locked_do_invoice: 0,
                locked_do_ship: 0,
                name: '',
                no_discount: 0,
                order_id: 0,
                original_price: '',
                parent_item: '',
                parent_item_id: 0,
                price: '',
                price_incl_tax: '',
                product_id: 0,
                product_option: {
                  extension_attributes: {
                    bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                    configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                    custom_options: [
                      {
                        extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                        option_id: '',
                        option_value: ''
                      }
                    ],
                    downloadable_option: {downloadable_links: []},
                    giftcard_item_option: {
                      custom_giftcard_amount: '',
                      extension_attributes: {},
                      giftcard_amount: '',
                      giftcard_message: '',
                      giftcard_recipient_email: '',
                      giftcard_recipient_name: '',
                      giftcard_sender_email: '',
                      giftcard_sender_name: ''
                    }
                  }
                },
                product_type: '',
                qty_backordered: '',
                qty_canceled: '',
                qty_invoiced: '',
                qty_ordered: '',
                qty_refunded: '',
                qty_returned: '',
                qty_shipped: '',
                quote_item_id: 0,
                row_invoiced: '',
                row_total: '',
                row_total_incl_tax: '',
                row_weight: '',
                sku: '',
                store_id: 0,
                tax_amount: '',
                tax_before_discount: '',
                tax_canceled: '',
                tax_invoiced: '',
                tax_percent: '',
                tax_refunded: '',
                updated_at: '',
                weee_tax_applied: '',
                weee_tax_applied_amount: '',
                weee_tax_applied_row_amount: '',
                weee_tax_disposition: '',
                weee_tax_row_disposition: '',
                weight: ''
              }
            ],
            shipping: {
              address: {},
              extension_attributes: {
                collection_point: {
                  city: '',
                  collection_point_id: '',
                  country: '',
                  name: '',
                  postcode: '',
                  recipient_address_id: 0,
                  region: '',
                  street: []
                },
                ext_order_id: '',
                shipping_experience: {code: '', cost: '', label: ''}
              },
              method: '',
              total: {
                base_shipping_amount: '',
                base_shipping_canceled: '',
                base_shipping_discount_amount: '',
                base_shipping_discount_tax_compensation_amnt: '',
                base_shipping_incl_tax: '',
                base_shipping_invoiced: '',
                base_shipping_refunded: '',
                base_shipping_tax_amount: '',
                base_shipping_tax_refunded: '',
                extension_attributes: {},
                shipping_amount: '',
                shipping_canceled: '',
                shipping_discount_amount: '',
                shipping_discount_tax_compensation_amount: '',
                shipping_incl_tax: '',
                shipping_invoiced: '',
                shipping_refunded: '',
                shipping_tax_amount: '',
                shipping_tax_refunded: ''
              }
            },
            stock_id: 0
          }
        ]
      },
      forced_shipment_with_invoice: 0,
      global_currency_code: '',
      grand_total: '',
      hold_before_state: '',
      hold_before_status: '',
      increment_id: '',
      is_virtual: 0,
      items: [{}],
      order_currency_code: '',
      original_increment_id: '',
      payment: {
        account_status: '',
        additional_data: '',
        additional_information: [],
        address_status: '',
        amount_authorized: '',
        amount_canceled: '',
        amount_ordered: '',
        amount_paid: '',
        amount_refunded: '',
        anet_trans_method: '',
        base_amount_authorized: '',
        base_amount_canceled: '',
        base_amount_ordered: '',
        base_amount_paid: '',
        base_amount_paid_online: '',
        base_amount_refunded: '',
        base_amount_refunded_online: '',
        base_shipping_amount: '',
        base_shipping_captured: '',
        base_shipping_refunded: '',
        cc_approval: '',
        cc_avs_status: '',
        cc_cid_status: '',
        cc_debug_request_body: '',
        cc_debug_response_body: '',
        cc_debug_response_serialized: '',
        cc_exp_month: '',
        cc_exp_year: '',
        cc_last4: '',
        cc_number_enc: '',
        cc_owner: '',
        cc_secure_verify: '',
        cc_ss_issue: '',
        cc_ss_start_month: '',
        cc_ss_start_year: '',
        cc_status: '',
        cc_status_description: '',
        cc_trans_id: '',
        cc_type: '',
        echeck_account_name: '',
        echeck_account_type: '',
        echeck_bank_name: '',
        echeck_routing_number: '',
        echeck_type: '',
        entity_id: 0,
        extension_attributes: {
          vault_payment_token: {
            created_at: '',
            customer_id: 0,
            entity_id: 0,
            expires_at: '',
            gateway_token: '',
            is_active: false,
            is_visible: false,
            payment_method_code: '',
            public_hash: '',
            token_details: '',
            type: ''
          }
        },
        last_trans_id: '',
        method: '',
        parent_id: 0,
        po_number: '',
        protection_eligibility: '',
        quote_payment_id: 0,
        shipping_amount: '',
        shipping_captured: '',
        shipping_refunded: ''
      },
      payment_auth_expiration: 0,
      payment_authorization_amount: '',
      protect_code: '',
      quote_address_id: 0,
      quote_id: 0,
      relation_child_id: '',
      relation_child_real_id: '',
      relation_parent_id: '',
      relation_parent_real_id: '',
      remote_ip: '',
      shipping_amount: '',
      shipping_canceled: '',
      shipping_description: '',
      shipping_discount_amount: '',
      shipping_discount_tax_compensation_amount: '',
      shipping_incl_tax: '',
      shipping_invoiced: '',
      shipping_refunded: '',
      shipping_tax_amount: '',
      shipping_tax_refunded: '',
      state: '',
      status: '',
      status_histories: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          entity_name: '',
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0,
          status: ''
        }
      ],
      store_currency_code: '',
      store_id: 0,
      store_name: '',
      store_to_base_rate: '',
      store_to_order_rate: '',
      subtotal: '',
      subtotal_canceled: '',
      subtotal_incl_tax: '',
      subtotal_invoiced: '',
      subtotal_refunded: '',
      tax_amount: '',
      tax_canceled: '',
      tax_invoiced: '',
      tax_refunded: '',
      total_canceled: '',
      total_due: '',
      total_invoiced: '',
      total_item_count: 0,
      total_offline_refunded: '',
      total_online_refunded: '',
      total_paid: '',
      total_qty_ordered: '',
      total_refunded: '',
      updated_at: '',
      weight: '',
      x_forwarded_for: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/orders/';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"adjustment_negative":"","adjustment_positive":"","applied_rule_ids":"","base_adjustment_negative":"","base_adjustment_positive":"","base_currency_code":"","base_discount_amount":"","base_discount_canceled":"","base_discount_invoiced":"","base_discount_refunded":"","base_discount_tax_compensation_amount":"","base_discount_tax_compensation_invoiced":"","base_discount_tax_compensation_refunded":"","base_grand_total":"","base_shipping_amount":"","base_shipping_canceled":"","base_shipping_discount_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_invoiced":"","base_shipping_refunded":"","base_shipping_tax_amount":"","base_shipping_tax_refunded":"","base_subtotal":"","base_subtotal_canceled":"","base_subtotal_incl_tax":"","base_subtotal_invoiced":"","base_subtotal_refunded":"","base_tax_amount":"","base_tax_canceled":"","base_tax_invoiced":"","base_tax_refunded":"","base_to_global_rate":"","base_to_order_rate":"","base_total_canceled":"","base_total_due":"","base_total_invoiced":"","base_total_invoiced_cost":"","base_total_offline_refunded":"","base_total_online_refunded":"","base_total_paid":"","base_total_qty_ordered":"","base_total_refunded":"","billing_address":{"address_type":"","city":"","company":"","country_id":"","customer_address_id":0,"customer_id":0,"email":"","entity_id":0,"extension_attributes":{"checkout_fields":[{"attribute_code":"","value":""}]},"fax":"","firstname":"","lastname":"","middlename":"","parent_id":0,"postcode":"","prefix":"","region":"","region_code":"","region_id":0,"street":[],"suffix":"","telephone":"","vat_id":"","vat_is_valid":0,"vat_request_date":"","vat_request_id":"","vat_request_success":0},"billing_address_id":0,"can_ship_partially":0,"can_ship_partially_item":0,"coupon_code":"","created_at":"","customer_dob":"","customer_email":"","customer_firstname":"","customer_gender":0,"customer_group_id":0,"customer_id":0,"customer_is_guest":0,"customer_lastname":"","customer_middlename":"","customer_note":"","customer_note_notify":0,"customer_prefix":"","customer_suffix":"","customer_taxvat":"","discount_amount":"","discount_canceled":"","discount_description":"","discount_invoiced":"","discount_refunded":"","discount_tax_compensation_amount":"","discount_tax_compensation_invoiced":"","discount_tax_compensation_refunded":"","edit_increment":0,"email_sent":0,"entity_id":0,"ext_customer_id":"","ext_order_id":"","extension_attributes":{"amazon_order_reference_id":"","applied_taxes":[{"amount":"","base_amount":"","code":"","extension_attributes":{"rates":[{"code":"","extension_attributes":{},"percent":"","title":""}]},"percent":"","title":""}],"base_customer_balance_amount":"","base_customer_balance_invoiced":"","base_customer_balance_refunded":"","base_customer_balance_total_refunded":"","base_gift_cards_amount":"","base_gift_cards_invoiced":"","base_gift_cards_refunded":"","base_reward_currency_amount":"","company_order_attributes":{"company_id":0,"company_name":"","extension_attributes":{},"order_id":0},"converting_from_quote":false,"customer_balance_amount":"","customer_balance_invoiced":"","customer_balance_refunded":"","customer_balance_total_refunded":"","gift_cards":[{"amount":"","base_amount":"","code":"","id":0}],"gift_cards_amount":"","gift_cards_invoiced":"","gift_cards_refunded":"","gift_message":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""},"gw_add_card":"","gw_allow_gift_receipt":"","gw_base_price":"","gw_base_price_incl_tax":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_card_base_price":"","gw_card_base_price_incl_tax":"","gw_card_base_price_invoiced":"","gw_card_base_price_refunded":"","gw_card_base_tax_amount":"","gw_card_base_tax_invoiced":"","gw_card_base_tax_refunded":"","gw_card_price":"","gw_card_price_incl_tax":"","gw_card_price_invoiced":"","gw_card_price_refunded":"","gw_card_tax_amount":"","gw_card_tax_invoiced":"","gw_card_tax_refunded":"","gw_id":"","gw_items_base_price":"","gw_items_base_price_incl_tax":"","gw_items_base_price_invoiced":"","gw_items_base_price_refunded":"","gw_items_base_tax_amount":"","gw_items_base_tax_invoiced":"","gw_items_base_tax_refunded":"","gw_items_price":"","gw_items_price_incl_tax":"","gw_items_price_invoiced":"","gw_items_price_refunded":"","gw_items_tax_amount":"","gw_items_tax_invoiced":"","gw_items_tax_refunded":"","gw_price":"","gw_price_incl_tax":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","item_applied_taxes":[{"applied_taxes":[{}],"associated_item_id":0,"extension_attributes":{},"item_id":0,"type":""}],"payment_additional_info":[{"key":"","value":""}],"reward_currency_amount":"","reward_points_balance":0,"shipping_assignments":[{"extension_attributes":{},"items":[{"additional_data":"","amount_refunded":"","applied_rule_ids":"","base_amount_refunded":"","base_cost":"","base_discount_amount":"","base_discount_invoiced":"","base_discount_refunded":"","base_discount_tax_compensation_amount":"","base_discount_tax_compensation_invoiced":"","base_discount_tax_compensation_refunded":"","base_original_price":"","base_price":"","base_price_incl_tax":"","base_row_invoiced":"","base_row_total":"","base_row_total_incl_tax":"","base_tax_amount":"","base_tax_before_discount":"","base_tax_invoiced":"","base_tax_refunded":"","base_weee_tax_applied_amount":"","base_weee_tax_applied_row_amnt":"","base_weee_tax_disposition":"","base_weee_tax_row_disposition":"","created_at":"","description":"","discount_amount":"","discount_invoiced":"","discount_percent":"","discount_refunded":"","discount_tax_compensation_amount":"","discount_tax_compensation_canceled":"","discount_tax_compensation_invoiced":"","discount_tax_compensation_refunded":"","event_id":0,"ext_order_item_id":"","extension_attributes":{"gift_message":{},"gw_base_price":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_id":"","gw_price":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","invoice_text_codes":[],"tax_codes":[],"vertex_tax_codes":[]},"free_shipping":0,"gw_base_price":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_id":0,"gw_price":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","is_qty_decimal":0,"is_virtual":0,"item_id":0,"locked_do_invoice":0,"locked_do_ship":0,"name":"","no_discount":0,"order_id":0,"original_price":"","parent_item":"","parent_item_id":0,"price":"","price_incl_tax":"","product_id":0,"product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty_backordered":"","qty_canceled":"","qty_invoiced":"","qty_ordered":"","qty_refunded":"","qty_returned":"","qty_shipped":"","quote_item_id":0,"row_invoiced":"","row_total":"","row_total_incl_tax":"","row_weight":"","sku":"","store_id":0,"tax_amount":"","tax_before_discount":"","tax_canceled":"","tax_invoiced":"","tax_percent":"","tax_refunded":"","updated_at":"","weee_tax_applied":"","weee_tax_applied_amount":"","weee_tax_applied_row_amount":"","weee_tax_disposition":"","weee_tax_row_disposition":"","weight":""}],"shipping":{"address":{},"extension_attributes":{"collection_point":{"city":"","collection_point_id":"","country":"","name":"","postcode":"","recipient_address_id":0,"region":"","street":[]},"ext_order_id":"","shipping_experience":{"code":"","cost":"","label":""}},"method":"","total":{"base_shipping_amount":"","base_shipping_canceled":"","base_shipping_discount_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_invoiced":"","base_shipping_refunded":"","base_shipping_tax_amount":"","base_shipping_tax_refunded":"","extension_attributes":{},"shipping_amount":"","shipping_canceled":"","shipping_discount_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_invoiced":"","shipping_refunded":"","shipping_tax_amount":"","shipping_tax_refunded":""}},"stock_id":0}]},"forced_shipment_with_invoice":0,"global_currency_code":"","grand_total":"","hold_before_state":"","hold_before_status":"","increment_id":"","is_virtual":0,"items":[{}],"order_currency_code":"","original_increment_id":"","payment":{"account_status":"","additional_data":"","additional_information":[],"address_status":"","amount_authorized":"","amount_canceled":"","amount_ordered":"","amount_paid":"","amount_refunded":"","anet_trans_method":"","base_amount_authorized":"","base_amount_canceled":"","base_amount_ordered":"","base_amount_paid":"","base_amount_paid_online":"","base_amount_refunded":"","base_amount_refunded_online":"","base_shipping_amount":"","base_shipping_captured":"","base_shipping_refunded":"","cc_approval":"","cc_avs_status":"","cc_cid_status":"","cc_debug_request_body":"","cc_debug_response_body":"","cc_debug_response_serialized":"","cc_exp_month":"","cc_exp_year":"","cc_last4":"","cc_number_enc":"","cc_owner":"","cc_secure_verify":"","cc_ss_issue":"","cc_ss_start_month":"","cc_ss_start_year":"","cc_status":"","cc_status_description":"","cc_trans_id":"","cc_type":"","echeck_account_name":"","echeck_account_type":"","echeck_bank_name":"","echeck_routing_number":"","echeck_type":"","entity_id":0,"extension_attributes":{"vault_payment_token":{"created_at":"","customer_id":0,"entity_id":0,"expires_at":"","gateway_token":"","is_active":false,"is_visible":false,"payment_method_code":"","public_hash":"","token_details":"","type":""}},"last_trans_id":"","method":"","parent_id":0,"po_number":"","protection_eligibility":"","quote_payment_id":0,"shipping_amount":"","shipping_captured":"","shipping_refunded":""},"payment_auth_expiration":0,"payment_authorization_amount":"","protect_code":"","quote_address_id":0,"quote_id":0,"relation_child_id":"","relation_child_real_id":"","relation_parent_id":"","relation_parent_real_id":"","remote_ip":"","shipping_amount":"","shipping_canceled":"","shipping_description":"","shipping_discount_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_invoiced":"","shipping_refunded":"","shipping_tax_amount":"","shipping_tax_refunded":"","state":"","status":"","status_histories":[{"comment":"","created_at":"","entity_id":0,"entity_name":"","extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_id":0,"status":""}],"store_currency_code":"","store_id":0,"store_name":"","store_to_base_rate":"","store_to_order_rate":"","subtotal":"","subtotal_canceled":"","subtotal_incl_tax":"","subtotal_invoiced":"","subtotal_refunded":"","tax_amount":"","tax_canceled":"","tax_invoiced":"","tax_refunded":"","total_canceled":"","total_due":"","total_invoiced":"","total_item_count":0,"total_offline_refunded":"","total_online_refunded":"","total_paid":"","total_qty_ordered":"","total_refunded":"","updated_at":"","weight":"","x_forwarded_for":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"entity": @{ @"adjustment_negative": @"", @"adjustment_positive": @"", @"applied_rule_ids": @"", @"base_adjustment_negative": @"", @"base_adjustment_positive": @"", @"base_currency_code": @"", @"base_discount_amount": @"", @"base_discount_canceled": @"", @"base_discount_invoiced": @"", @"base_discount_refunded": @"", @"base_discount_tax_compensation_amount": @"", @"base_discount_tax_compensation_invoiced": @"", @"base_discount_tax_compensation_refunded": @"", @"base_grand_total": @"", @"base_shipping_amount": @"", @"base_shipping_canceled": @"", @"base_shipping_discount_amount": @"", @"base_shipping_discount_tax_compensation_amnt": @"", @"base_shipping_incl_tax": @"", @"base_shipping_invoiced": @"", @"base_shipping_refunded": @"", @"base_shipping_tax_amount": @"", @"base_shipping_tax_refunded": @"", @"base_subtotal": @"", @"base_subtotal_canceled": @"", @"base_subtotal_incl_tax": @"", @"base_subtotal_invoiced": @"", @"base_subtotal_refunded": @"", @"base_tax_amount": @"", @"base_tax_canceled": @"", @"base_tax_invoiced": @"", @"base_tax_refunded": @"", @"base_to_global_rate": @"", @"base_to_order_rate": @"", @"base_total_canceled": @"", @"base_total_due": @"", @"base_total_invoiced": @"", @"base_total_invoiced_cost": @"", @"base_total_offline_refunded": @"", @"base_total_online_refunded": @"", @"base_total_paid": @"", @"base_total_qty_ordered": @"", @"base_total_refunded": @"", @"billing_address": @{ @"address_type": @"", @"city": @"", @"company": @"", @"country_id": @"", @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"entity_id": @0, @"extension_attributes": @{ @"checkout_fields": @[ @{ @"attribute_code": @"", @"value": @"" } ] }, @"fax": @"", @"firstname": @"", @"lastname": @"", @"middlename": @"", @"parent_id": @0, @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"", @"vat_is_valid": @0, @"vat_request_date": @"", @"vat_request_id": @"", @"vat_request_success": @0 }, @"billing_address_id": @0, @"can_ship_partially": @0, @"can_ship_partially_item": @0, @"coupon_code": @"", @"created_at": @"", @"customer_dob": @"", @"customer_email": @"", @"customer_firstname": @"", @"customer_gender": @0, @"customer_group_id": @0, @"customer_id": @0, @"customer_is_guest": @0, @"customer_lastname": @"", @"customer_middlename": @"", @"customer_note": @"", @"customer_note_notify": @0, @"customer_prefix": @"", @"customer_suffix": @"", @"customer_taxvat": @"", @"discount_amount": @"", @"discount_canceled": @"", @"discount_description": @"", @"discount_invoiced": @"", @"discount_refunded": @"", @"discount_tax_compensation_amount": @"", @"discount_tax_compensation_invoiced": @"", @"discount_tax_compensation_refunded": @"", @"edit_increment": @0, @"email_sent": @0, @"entity_id": @0, @"ext_customer_id": @"", @"ext_order_id": @"", @"extension_attributes": @{ @"amazon_order_reference_id": @"", @"applied_taxes": @[ @{ @"amount": @"", @"base_amount": @"", @"code": @"", @"extension_attributes": @{ @"rates": @[ @{ @"code": @"", @"extension_attributes": @{  }, @"percent": @"", @"title": @"" } ] }, @"percent": @"", @"title": @"" } ], @"base_customer_balance_amount": @"", @"base_customer_balance_invoiced": @"", @"base_customer_balance_refunded": @"", @"base_customer_balance_total_refunded": @"", @"base_gift_cards_amount": @"", @"base_gift_cards_invoiced": @"", @"base_gift_cards_refunded": @"", @"base_reward_currency_amount": @"", @"company_order_attributes": @{ @"company_id": @0, @"company_name": @"", @"extension_attributes": @{  }, @"order_id": @0 }, @"converting_from_quote": @NO, @"customer_balance_amount": @"", @"customer_balance_invoiced": @"", @"customer_balance_refunded": @"", @"customer_balance_total_refunded": @"", @"gift_cards": @[ @{ @"amount": @"", @"base_amount": @"", @"code": @"", @"id": @0 } ], @"gift_cards_amount": @"", @"gift_cards_invoiced": @"", @"gift_cards_refunded": @"", @"gift_message": @{ @"customer_id": @0, @"extension_attributes": @{ @"entity_id": @"", @"entity_type": @"", @"wrapping_add_printed_card": @NO, @"wrapping_allow_gift_receipt": @NO, @"wrapping_id": @0 }, @"gift_message_id": @0, @"message": @"", @"recipient": @"", @"sender": @"" }, @"gw_add_card": @"", @"gw_allow_gift_receipt": @"", @"gw_base_price": @"", @"gw_base_price_incl_tax": @"", @"gw_base_price_invoiced": @"", @"gw_base_price_refunded": @"", @"gw_base_tax_amount": @"", @"gw_base_tax_amount_invoiced": @"", @"gw_base_tax_amount_refunded": @"", @"gw_card_base_price": @"", @"gw_card_base_price_incl_tax": @"", @"gw_card_base_price_invoiced": @"", @"gw_card_base_price_refunded": @"", @"gw_card_base_tax_amount": @"", @"gw_card_base_tax_invoiced": @"", @"gw_card_base_tax_refunded": @"", @"gw_card_price": @"", @"gw_card_price_incl_tax": @"", @"gw_card_price_invoiced": @"", @"gw_card_price_refunded": @"", @"gw_card_tax_amount": @"", @"gw_card_tax_invoiced": @"", @"gw_card_tax_refunded": @"", @"gw_id": @"", @"gw_items_base_price": @"", @"gw_items_base_price_incl_tax": @"", @"gw_items_base_price_invoiced": @"", @"gw_items_base_price_refunded": @"", @"gw_items_base_tax_amount": @"", @"gw_items_base_tax_invoiced": @"", @"gw_items_base_tax_refunded": @"", @"gw_items_price": @"", @"gw_items_price_incl_tax": @"", @"gw_items_price_invoiced": @"", @"gw_items_price_refunded": @"", @"gw_items_tax_amount": @"", @"gw_items_tax_invoiced": @"", @"gw_items_tax_refunded": @"", @"gw_price": @"", @"gw_price_incl_tax": @"", @"gw_price_invoiced": @"", @"gw_price_refunded": @"", @"gw_tax_amount": @"", @"gw_tax_amount_invoiced": @"", @"gw_tax_amount_refunded": @"", @"item_applied_taxes": @[ @{ @"applied_taxes": @[ @{  } ], @"associated_item_id": @0, @"extension_attributes": @{  }, @"item_id": @0, @"type": @"" } ], @"payment_additional_info": @[ @{ @"key": @"", @"value": @"" } ], @"reward_currency_amount": @"", @"reward_points_balance": @0, @"shipping_assignments": @[ @{ @"extension_attributes": @{  }, @"items": @[ @{ @"additional_data": @"", @"amount_refunded": @"", @"applied_rule_ids": @"", @"base_amount_refunded": @"", @"base_cost": @"", @"base_discount_amount": @"", @"base_discount_invoiced": @"", @"base_discount_refunded": @"", @"base_discount_tax_compensation_amount": @"", @"base_discount_tax_compensation_invoiced": @"", @"base_discount_tax_compensation_refunded": @"", @"base_original_price": @"", @"base_price": @"", @"base_price_incl_tax": @"", @"base_row_invoiced": @"", @"base_row_total": @"", @"base_row_total_incl_tax": @"", @"base_tax_amount": @"", @"base_tax_before_discount": @"", @"base_tax_invoiced": @"", @"base_tax_refunded": @"", @"base_weee_tax_applied_amount": @"", @"base_weee_tax_applied_row_amnt": @"", @"base_weee_tax_disposition": @"", @"base_weee_tax_row_disposition": @"", @"created_at": @"", @"description": @"", @"discount_amount": @"", @"discount_invoiced": @"", @"discount_percent": @"", @"discount_refunded": @"", @"discount_tax_compensation_amount": @"", @"discount_tax_compensation_canceled": @"", @"discount_tax_compensation_invoiced": @"", @"discount_tax_compensation_refunded": @"", @"event_id": @0, @"ext_order_item_id": @"", @"extension_attributes": @{ @"gift_message": @{  }, @"gw_base_price": @"", @"gw_base_price_invoiced": @"", @"gw_base_price_refunded": @"", @"gw_base_tax_amount": @"", @"gw_base_tax_amount_invoiced": @"", @"gw_base_tax_amount_refunded": @"", @"gw_id": @"", @"gw_price": @"", @"gw_price_invoiced": @"", @"gw_price_refunded": @"", @"gw_tax_amount": @"", @"gw_tax_amount_invoiced": @"", @"gw_tax_amount_refunded": @"", @"invoice_text_codes": @[  ], @"tax_codes": @[  ], @"vertex_tax_codes": @[  ] }, @"free_shipping": @0, @"gw_base_price": @"", @"gw_base_price_invoiced": @"", @"gw_base_price_refunded": @"", @"gw_base_tax_amount": @"", @"gw_base_tax_amount_invoiced": @"", @"gw_base_tax_amount_refunded": @"", @"gw_id": @0, @"gw_price": @"", @"gw_price_invoiced": @"", @"gw_price_refunded": @"", @"gw_tax_amount": @"", @"gw_tax_amount_invoiced": @"", @"gw_tax_amount_refunded": @"", @"is_qty_decimal": @0, @"is_virtual": @0, @"item_id": @0, @"locked_do_invoice": @0, @"locked_do_ship": @0, @"name": @"", @"no_discount": @0, @"order_id": @0, @"original_price": @"", @"parent_item": @"", @"parent_item_id": @0, @"price": @"", @"price_incl_tax": @"", @"product_id": @0, @"product_option": @{ @"extension_attributes": @{ @"bundle_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @0, @"option_qty": @0, @"option_selections": @[  ] } ], @"configurable_item_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @"", @"option_value": @0 } ], @"custom_options": @[ @{ @"extension_attributes": @{ @"file_info": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" } }, @"option_id": @"", @"option_value": @"" } ], @"downloadable_option": @{ @"downloadable_links": @[  ] }, @"giftcard_item_option": @{ @"custom_giftcard_amount": @"", @"extension_attributes": @{  }, @"giftcard_amount": @"", @"giftcard_message": @"", @"giftcard_recipient_email": @"", @"giftcard_recipient_name": @"", @"giftcard_sender_email": @"", @"giftcard_sender_name": @"" } } }, @"product_type": @"", @"qty_backordered": @"", @"qty_canceled": @"", @"qty_invoiced": @"", @"qty_ordered": @"", @"qty_refunded": @"", @"qty_returned": @"", @"qty_shipped": @"", @"quote_item_id": @0, @"row_invoiced": @"", @"row_total": @"", @"row_total_incl_tax": @"", @"row_weight": @"", @"sku": @"", @"store_id": @0, @"tax_amount": @"", @"tax_before_discount": @"", @"tax_canceled": @"", @"tax_invoiced": @"", @"tax_percent": @"", @"tax_refunded": @"", @"updated_at": @"", @"weee_tax_applied": @"", @"weee_tax_applied_amount": @"", @"weee_tax_applied_row_amount": @"", @"weee_tax_disposition": @"", @"weee_tax_row_disposition": @"", @"weight": @"" } ], @"shipping": @{ @"address": @{  }, @"extension_attributes": @{ @"collection_point": @{ @"city": @"", @"collection_point_id": @"", @"country": @"", @"name": @"", @"postcode": @"", @"recipient_address_id": @0, @"region": @"", @"street": @[  ] }, @"ext_order_id": @"", @"shipping_experience": @{ @"code": @"", @"cost": @"", @"label": @"" } }, @"method": @"", @"total": @{ @"base_shipping_amount": @"", @"base_shipping_canceled": @"", @"base_shipping_discount_amount": @"", @"base_shipping_discount_tax_compensation_amnt": @"", @"base_shipping_incl_tax": @"", @"base_shipping_invoiced": @"", @"base_shipping_refunded": @"", @"base_shipping_tax_amount": @"", @"base_shipping_tax_refunded": @"", @"extension_attributes": @{  }, @"shipping_amount": @"", @"shipping_canceled": @"", @"shipping_discount_amount": @"", @"shipping_discount_tax_compensation_amount": @"", @"shipping_incl_tax": @"", @"shipping_invoiced": @"", @"shipping_refunded": @"", @"shipping_tax_amount": @"", @"shipping_tax_refunded": @"" } }, @"stock_id": @0 } ] }, @"forced_shipment_with_invoice": @0, @"global_currency_code": @"", @"grand_total": @"", @"hold_before_state": @"", @"hold_before_status": @"", @"increment_id": @"", @"is_virtual": @0, @"items": @[ @{  } ], @"order_currency_code": @"", @"original_increment_id": @"", @"payment": @{ @"account_status": @"", @"additional_data": @"", @"additional_information": @[  ], @"address_status": @"", @"amount_authorized": @"", @"amount_canceled": @"", @"amount_ordered": @"", @"amount_paid": @"", @"amount_refunded": @"", @"anet_trans_method": @"", @"base_amount_authorized": @"", @"base_amount_canceled": @"", @"base_amount_ordered": @"", @"base_amount_paid": @"", @"base_amount_paid_online": @"", @"base_amount_refunded": @"", @"base_amount_refunded_online": @"", @"base_shipping_amount": @"", @"base_shipping_captured": @"", @"base_shipping_refunded": @"", @"cc_approval": @"", @"cc_avs_status": @"", @"cc_cid_status": @"", @"cc_debug_request_body": @"", @"cc_debug_response_body": @"", @"cc_debug_response_serialized": @"", @"cc_exp_month": @"", @"cc_exp_year": @"", @"cc_last4": @"", @"cc_number_enc": @"", @"cc_owner": @"", @"cc_secure_verify": @"", @"cc_ss_issue": @"", @"cc_ss_start_month": @"", @"cc_ss_start_year": @"", @"cc_status": @"", @"cc_status_description": @"", @"cc_trans_id": @"", @"cc_type": @"", @"echeck_account_name": @"", @"echeck_account_type": @"", @"echeck_bank_name": @"", @"echeck_routing_number": @"", @"echeck_type": @"", @"entity_id": @0, @"extension_attributes": @{ @"vault_payment_token": @{ @"created_at": @"", @"customer_id": @0, @"entity_id": @0, @"expires_at": @"", @"gateway_token": @"", @"is_active": @NO, @"is_visible": @NO, @"payment_method_code": @"", @"public_hash": @"", @"token_details": @"", @"type": @"" } }, @"last_trans_id": @"", @"method": @"", @"parent_id": @0, @"po_number": @"", @"protection_eligibility": @"", @"quote_payment_id": @0, @"shipping_amount": @"", @"shipping_captured": @"", @"shipping_refunded": @"" }, @"payment_auth_expiration": @0, @"payment_authorization_amount": @"", @"protect_code": @"", @"quote_address_id": @0, @"quote_id": @0, @"relation_child_id": @"", @"relation_child_real_id": @"", @"relation_parent_id": @"", @"relation_parent_real_id": @"", @"remote_ip": @"", @"shipping_amount": @"", @"shipping_canceled": @"", @"shipping_description": @"", @"shipping_discount_amount": @"", @"shipping_discount_tax_compensation_amount": @"", @"shipping_incl_tax": @"", @"shipping_invoiced": @"", @"shipping_refunded": @"", @"shipping_tax_amount": @"", @"shipping_tax_refunded": @"", @"state": @"", @"status": @"", @"status_histories": @[ @{ @"comment": @"", @"created_at": @"", @"entity_id": @0, @"entity_name": @"", @"extension_attributes": @{  }, @"is_customer_notified": @0, @"is_visible_on_front": @0, @"parent_id": @0, @"status": @"" } ], @"store_currency_code": @"", @"store_id": @0, @"store_name": @"", @"store_to_base_rate": @"", @"store_to_order_rate": @"", @"subtotal": @"", @"subtotal_canceled": @"", @"subtotal_incl_tax": @"", @"subtotal_invoiced": @"", @"subtotal_refunded": @"", @"tax_amount": @"", @"tax_canceled": @"", @"tax_invoiced": @"", @"tax_refunded": @"", @"total_canceled": @"", @"total_due": @"", @"total_invoiced": @"", @"total_item_count": @0, @"total_offline_refunded": @"", @"total_online_refunded": @"", @"total_paid": @"", @"total_qty_ordered": @"", @"total_refunded": @"", @"updated_at": @"", @"weight": @"", @"x_forwarded_for": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/orders/"]
                                                       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}}/V1/orders/" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/orders/",
  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([
    'entity' => [
        'adjustment_negative' => '',
        'adjustment_positive' => '',
        'applied_rule_ids' => '',
        'base_adjustment_negative' => '',
        'base_adjustment_positive' => '',
        'base_currency_code' => '',
        'base_discount_amount' => '',
        'base_discount_canceled' => '',
        'base_discount_invoiced' => '',
        'base_discount_refunded' => '',
        'base_discount_tax_compensation_amount' => '',
        'base_discount_tax_compensation_invoiced' => '',
        'base_discount_tax_compensation_refunded' => '',
        'base_grand_total' => '',
        'base_shipping_amount' => '',
        'base_shipping_canceled' => '',
        'base_shipping_discount_amount' => '',
        'base_shipping_discount_tax_compensation_amnt' => '',
        'base_shipping_incl_tax' => '',
        'base_shipping_invoiced' => '',
        'base_shipping_refunded' => '',
        'base_shipping_tax_amount' => '',
        'base_shipping_tax_refunded' => '',
        'base_subtotal' => '',
        'base_subtotal_canceled' => '',
        'base_subtotal_incl_tax' => '',
        'base_subtotal_invoiced' => '',
        'base_subtotal_refunded' => '',
        'base_tax_amount' => '',
        'base_tax_canceled' => '',
        'base_tax_invoiced' => '',
        'base_tax_refunded' => '',
        'base_to_global_rate' => '',
        'base_to_order_rate' => '',
        'base_total_canceled' => '',
        'base_total_due' => '',
        'base_total_invoiced' => '',
        'base_total_invoiced_cost' => '',
        'base_total_offline_refunded' => '',
        'base_total_online_refunded' => '',
        'base_total_paid' => '',
        'base_total_qty_ordered' => '',
        'base_total_refunded' => '',
        'billing_address' => [
                'address_type' => '',
                'city' => '',
                'company' => '',
                'country_id' => '',
                'customer_address_id' => 0,
                'customer_id' => 0,
                'email' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                'checkout_fields' => [
                                                                [
                                                                                                                                'attribute_code' => '',
                                                                                                                                'value' => ''
                                                                ]
                                ]
                ],
                'fax' => '',
                'firstname' => '',
                'lastname' => '',
                'middlename' => '',
                'parent_id' => 0,
                'postcode' => '',
                'prefix' => '',
                'region' => '',
                'region_code' => '',
                'region_id' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => '',
                'vat_is_valid' => 0,
                'vat_request_date' => '',
                'vat_request_id' => '',
                'vat_request_success' => 0
        ],
        'billing_address_id' => 0,
        'can_ship_partially' => 0,
        'can_ship_partially_item' => 0,
        'coupon_code' => '',
        'created_at' => '',
        'customer_dob' => '',
        'customer_email' => '',
        'customer_firstname' => '',
        'customer_gender' => 0,
        'customer_group_id' => 0,
        'customer_id' => 0,
        'customer_is_guest' => 0,
        'customer_lastname' => '',
        'customer_middlename' => '',
        'customer_note' => '',
        'customer_note_notify' => 0,
        'customer_prefix' => '',
        'customer_suffix' => '',
        'customer_taxvat' => '',
        'discount_amount' => '',
        'discount_canceled' => '',
        'discount_description' => '',
        'discount_invoiced' => '',
        'discount_refunded' => '',
        'discount_tax_compensation_amount' => '',
        'discount_tax_compensation_invoiced' => '',
        'discount_tax_compensation_refunded' => '',
        'edit_increment' => 0,
        'email_sent' => 0,
        'entity_id' => 0,
        'ext_customer_id' => '',
        'ext_order_id' => '',
        'extension_attributes' => [
                'amazon_order_reference_id' => '',
                'applied_taxes' => [
                                [
                                                                'amount' => '',
                                                                'base_amount' => '',
                                                                'code' => '',
                                                                'extension_attributes' => [
                                                                                                                                'rates' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'percent' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'title' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ],
                                                                'percent' => '',
                                                                'title' => ''
                                ]
                ],
                'base_customer_balance_amount' => '',
                'base_customer_balance_invoiced' => '',
                'base_customer_balance_refunded' => '',
                'base_customer_balance_total_refunded' => '',
                'base_gift_cards_amount' => '',
                'base_gift_cards_invoiced' => '',
                'base_gift_cards_refunded' => '',
                'base_reward_currency_amount' => '',
                'company_order_attributes' => [
                                'company_id' => 0,
                                'company_name' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'order_id' => 0
                ],
                'converting_from_quote' => null,
                'customer_balance_amount' => '',
                'customer_balance_invoiced' => '',
                'customer_balance_refunded' => '',
                'customer_balance_total_refunded' => '',
                'gift_cards' => [
                                [
                                                                'amount' => '',
                                                                'base_amount' => '',
                                                                'code' => '',
                                                                'id' => 0
                                ]
                ],
                'gift_cards_amount' => '',
                'gift_cards_invoiced' => '',
                'gift_cards_refunded' => '',
                'gift_message' => [
                                'customer_id' => 0,
                                'extension_attributes' => [
                                                                'entity_id' => '',
                                                                'entity_type' => '',
                                                                'wrapping_add_printed_card' => null,
                                                                'wrapping_allow_gift_receipt' => null,
                                                                'wrapping_id' => 0
                                ],
                                'gift_message_id' => 0,
                                'message' => '',
                                'recipient' => '',
                                'sender' => ''
                ],
                'gw_add_card' => '',
                'gw_allow_gift_receipt' => '',
                'gw_base_price' => '',
                'gw_base_price_incl_tax' => '',
                'gw_base_price_invoiced' => '',
                'gw_base_price_refunded' => '',
                'gw_base_tax_amount' => '',
                'gw_base_tax_amount_invoiced' => '',
                'gw_base_tax_amount_refunded' => '',
                'gw_card_base_price' => '',
                'gw_card_base_price_incl_tax' => '',
                'gw_card_base_price_invoiced' => '',
                'gw_card_base_price_refunded' => '',
                'gw_card_base_tax_amount' => '',
                'gw_card_base_tax_invoiced' => '',
                'gw_card_base_tax_refunded' => '',
                'gw_card_price' => '',
                'gw_card_price_incl_tax' => '',
                'gw_card_price_invoiced' => '',
                'gw_card_price_refunded' => '',
                'gw_card_tax_amount' => '',
                'gw_card_tax_invoiced' => '',
                'gw_card_tax_refunded' => '',
                'gw_id' => '',
                'gw_items_base_price' => '',
                'gw_items_base_price_incl_tax' => '',
                'gw_items_base_price_invoiced' => '',
                'gw_items_base_price_refunded' => '',
                'gw_items_base_tax_amount' => '',
                'gw_items_base_tax_invoiced' => '',
                'gw_items_base_tax_refunded' => '',
                'gw_items_price' => '',
                'gw_items_price_incl_tax' => '',
                'gw_items_price_invoiced' => '',
                'gw_items_price_refunded' => '',
                'gw_items_tax_amount' => '',
                'gw_items_tax_invoiced' => '',
                'gw_items_tax_refunded' => '',
                'gw_price' => '',
                'gw_price_incl_tax' => '',
                'gw_price_invoiced' => '',
                'gw_price_refunded' => '',
                'gw_tax_amount' => '',
                'gw_tax_amount_invoiced' => '',
                'gw_tax_amount_refunded' => '',
                'item_applied_taxes' => [
                                [
                                                                'applied_taxes' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'associated_item_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'item_id' => 0,
                                                                'type' => ''
                                ]
                ],
                'payment_additional_info' => [
                                [
                                                                'key' => '',
                                                                'value' => ''
                                ]
                ],
                'reward_currency_amount' => '',
                'reward_points_balance' => 0,
                'shipping_assignments' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'items' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'additional_data' => '',
                                                                                                                                                                                                                                                                'amount_refunded' => '',
                                                                                                                                                                                                                                                                'applied_rule_ids' => '',
                                                                                                                                                                                                                                                                'base_amount_refunded' => '',
                                                                                                                                                                                                                                                                'base_cost' => '',
                                                                                                                                                                                                                                                                'base_discount_amount' => '',
                                                                                                                                                                                                                                                                'base_discount_invoiced' => '',
                                                                                                                                                                                                                                                                'base_discount_refunded' => '',
                                                                                                                                                                                                                                                                'base_discount_tax_compensation_amount' => '',
                                                                                                                                                                                                                                                                'base_discount_tax_compensation_invoiced' => '',
                                                                                                                                                                                                                                                                'base_discount_tax_compensation_refunded' => '',
                                                                                                                                                                                                                                                                'base_original_price' => '',
                                                                                                                                                                                                                                                                'base_price' => '',
                                                                                                                                                                                                                                                                'base_price_incl_tax' => '',
                                                                                                                                                                                                                                                                'base_row_invoiced' => '',
                                                                                                                                                                                                                                                                'base_row_total' => '',
                                                                                                                                                                                                                                                                'base_row_total_incl_tax' => '',
                                                                                                                                                                                                                                                                'base_tax_amount' => '',
                                                                                                                                                                                                                                                                'base_tax_before_discount' => '',
                                                                                                                                                                                                                                                                'base_tax_invoiced' => '',
                                                                                                                                                                                                                                                                'base_tax_refunded' => '',
                                                                                                                                                                                                                                                                'base_weee_tax_applied_amount' => '',
                                                                                                                                                                                                                                                                'base_weee_tax_applied_row_amnt' => '',
                                                                                                                                                                                                                                                                'base_weee_tax_disposition' => '',
                                                                                                                                                                                                                                                                'base_weee_tax_row_disposition' => '',
                                                                                                                                                                                                                                                                'created_at' => '',
                                                                                                                                                                                                                                                                'description' => '',
                                                                                                                                                                                                                                                                'discount_amount' => '',
                                                                                                                                                                                                                                                                'discount_invoiced' => '',
                                                                                                                                                                                                                                                                'discount_percent' => '',
                                                                                                                                                                                                                                                                'discount_refunded' => '',
                                                                                                                                                                                                                                                                'discount_tax_compensation_amount' => '',
                                                                                                                                                                                                                                                                'discount_tax_compensation_canceled' => '',
                                                                                                                                                                                                                                                                'discount_tax_compensation_invoiced' => '',
                                                                                                                                                                                                                                                                'discount_tax_compensation_refunded' => '',
                                                                                                                                                                                                                                                                'event_id' => 0,
                                                                                                                                                                                                                                                                'ext_order_item_id' => '',
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gift_message' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'invoice_text_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'vertex_tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'free_shipping' => 0,
                                                                                                                                                                                                                                                                'gw_base_price' => '',
                                                                                                                                                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                'gw_id' => 0,
                                                                                                                                                                                                                                                                'gw_price' => '',
                                                                                                                                                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                'is_qty_decimal' => 0,
                                                                                                                                                                                                                                                                'is_virtual' => 0,
                                                                                                                                                                                                                                                                'item_id' => 0,
                                                                                                                                                                                                                                                                'locked_do_invoice' => 0,
                                                                                                                                                                                                                                                                'locked_do_ship' => 0,
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'no_discount' => 0,
                                                                                                                                                                                                                                                                'order_id' => 0,
                                                                                                                                                                                                                                                                'original_price' => '',
                                                                                                                                                                                                                                                                'parent_item' => '',
                                                                                                                                                                                                                                                                'parent_item_id' => 0,
                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                'price_incl_tax' => '',
                                                                                                                                                                                                                                                                'product_id' => 0,
                                                                                                                                                                                                                                                                'product_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'bundle_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_qty' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'configurable_item_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_links' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_item_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_message' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_name' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'product_type' => '',
                                                                                                                                                                                                                                                                'qty_backordered' => '',
                                                                                                                                                                                                                                                                'qty_canceled' => '',
                                                                                                                                                                                                                                                                'qty_invoiced' => '',
                                                                                                                                                                                                                                                                'qty_ordered' => '',
                                                                                                                                                                                                                                                                'qty_refunded' => '',
                                                                                                                                                                                                                                                                'qty_returned' => '',
                                                                                                                                                                                                                                                                'qty_shipped' => '',
                                                                                                                                                                                                                                                                'quote_item_id' => 0,
                                                                                                                                                                                                                                                                'row_invoiced' => '',
                                                                                                                                                                                                                                                                'row_total' => '',
                                                                                                                                                                                                                                                                'row_total_incl_tax' => '',
                                                                                                                                                                                                                                                                'row_weight' => '',
                                                                                                                                                                                                                                                                'sku' => '',
                                                                                                                                                                                                                                                                'store_id' => 0,
                                                                                                                                                                                                                                                                'tax_amount' => '',
                                                                                                                                                                                                                                                                'tax_before_discount' => '',
                                                                                                                                                                                                                                                                'tax_canceled' => '',
                                                                                                                                                                                                                                                                'tax_invoiced' => '',
                                                                                                                                                                                                                                                                'tax_percent' => '',
                                                                                                                                                                                                                                                                'tax_refunded' => '',
                                                                                                                                                                                                                                                                'updated_at' => '',
                                                                                                                                                                                                                                                                'weee_tax_applied' => '',
                                                                                                                                                                                                                                                                'weee_tax_applied_amount' => '',
                                                                                                                                                                                                                                                                'weee_tax_applied_row_amount' => '',
                                                                                                                                                                                                                                                                'weee_tax_disposition' => '',
                                                                                                                                                                                                                                                                'weee_tax_row_disposition' => '',
                                                                                                                                                                                                                                                                'weight' => ''
                                                                                                                                ]
                                                                ],
                                                                'shipping' => [
                                                                                                                                'address' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'collection_point' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'city' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'collection_point_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'country' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'postcode' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'recipient_address_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'region' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'street' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'ext_order_id' => '',
                                                                                                                                                                                                                                                                'shipping_experience' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'cost' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'label' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'method' => '',
                                                                                                                                'total' => [
                                                                                                                                                                                                                                                                'base_shipping_amount' => '',
                                                                                                                                                                                                                                                                'base_shipping_canceled' => '',
                                                                                                                                                                                                                                                                'base_shipping_discount_amount' => '',
                                                                                                                                                                                                                                                                'base_shipping_discount_tax_compensation_amnt' => '',
                                                                                                                                                                                                                                                                'base_shipping_incl_tax' => '',
                                                                                                                                                                                                                                                                'base_shipping_invoiced' => '',
                                                                                                                                                                                                                                                                'base_shipping_refunded' => '',
                                                                                                                                                                                                                                                                'base_shipping_tax_amount' => '',
                                                                                                                                                                                                                                                                'base_shipping_tax_refunded' => '',
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'shipping_amount' => '',
                                                                                                                                                                                                                                                                'shipping_canceled' => '',
                                                                                                                                                                                                                                                                'shipping_discount_amount' => '',
                                                                                                                                                                                                                                                                'shipping_discount_tax_compensation_amount' => '',
                                                                                                                                                                                                                                                                'shipping_incl_tax' => '',
                                                                                                                                                                                                                                                                'shipping_invoiced' => '',
                                                                                                                                                                                                                                                                'shipping_refunded' => '',
                                                                                                                                                                                                                                                                'shipping_tax_amount' => '',
                                                                                                                                                                                                                                                                'shipping_tax_refunded' => ''
                                                                                                                                ]
                                                                ],
                                                                'stock_id' => 0
                                ]
                ]
        ],
        'forced_shipment_with_invoice' => 0,
        'global_currency_code' => '',
        'grand_total' => '',
        'hold_before_state' => '',
        'hold_before_status' => '',
        'increment_id' => '',
        'is_virtual' => 0,
        'items' => [
                [
                                
                ]
        ],
        'order_currency_code' => '',
        'original_increment_id' => '',
        'payment' => [
                'account_status' => '',
                'additional_data' => '',
                'additional_information' => [
                                
                ],
                'address_status' => '',
                'amount_authorized' => '',
                'amount_canceled' => '',
                'amount_ordered' => '',
                'amount_paid' => '',
                'amount_refunded' => '',
                'anet_trans_method' => '',
                'base_amount_authorized' => '',
                'base_amount_canceled' => '',
                'base_amount_ordered' => '',
                'base_amount_paid' => '',
                'base_amount_paid_online' => '',
                'base_amount_refunded' => '',
                'base_amount_refunded_online' => '',
                'base_shipping_amount' => '',
                'base_shipping_captured' => '',
                'base_shipping_refunded' => '',
                'cc_approval' => '',
                'cc_avs_status' => '',
                'cc_cid_status' => '',
                'cc_debug_request_body' => '',
                'cc_debug_response_body' => '',
                'cc_debug_response_serialized' => '',
                'cc_exp_month' => '',
                'cc_exp_year' => '',
                'cc_last4' => '',
                'cc_number_enc' => '',
                'cc_owner' => '',
                'cc_secure_verify' => '',
                'cc_ss_issue' => '',
                'cc_ss_start_month' => '',
                'cc_ss_start_year' => '',
                'cc_status' => '',
                'cc_status_description' => '',
                'cc_trans_id' => '',
                'cc_type' => '',
                'echeck_account_name' => '',
                'echeck_account_type' => '',
                'echeck_bank_name' => '',
                'echeck_routing_number' => '',
                'echeck_type' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                'vault_payment_token' => [
                                                                'created_at' => '',
                                                                'customer_id' => 0,
                                                                'entity_id' => 0,
                                                                'expires_at' => '',
                                                                'gateway_token' => '',
                                                                'is_active' => null,
                                                                'is_visible' => null,
                                                                'payment_method_code' => '',
                                                                'public_hash' => '',
                                                                'token_details' => '',
                                                                'type' => ''
                                ]
                ],
                'last_trans_id' => '',
                'method' => '',
                'parent_id' => 0,
                'po_number' => '',
                'protection_eligibility' => '',
                'quote_payment_id' => 0,
                'shipping_amount' => '',
                'shipping_captured' => '',
                'shipping_refunded' => ''
        ],
        'payment_auth_expiration' => 0,
        'payment_authorization_amount' => '',
        'protect_code' => '',
        'quote_address_id' => 0,
        'quote_id' => 0,
        'relation_child_id' => '',
        'relation_child_real_id' => '',
        'relation_parent_id' => '',
        'relation_parent_real_id' => '',
        'remote_ip' => '',
        'shipping_amount' => '',
        'shipping_canceled' => '',
        'shipping_description' => '',
        'shipping_discount_amount' => '',
        'shipping_discount_tax_compensation_amount' => '',
        'shipping_incl_tax' => '',
        'shipping_invoiced' => '',
        'shipping_refunded' => '',
        'shipping_tax_amount' => '',
        'shipping_tax_refunded' => '',
        'state' => '',
        'status' => '',
        'status_histories' => [
                [
                                'comment' => '',
                                'created_at' => '',
                                'entity_id' => 0,
                                'entity_name' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'is_customer_notified' => 0,
                                'is_visible_on_front' => 0,
                                'parent_id' => 0,
                                'status' => ''
                ]
        ],
        'store_currency_code' => '',
        'store_id' => 0,
        'store_name' => '',
        'store_to_base_rate' => '',
        'store_to_order_rate' => '',
        'subtotal' => '',
        'subtotal_canceled' => '',
        'subtotal_incl_tax' => '',
        'subtotal_invoiced' => '',
        'subtotal_refunded' => '',
        'tax_amount' => '',
        'tax_canceled' => '',
        'tax_invoiced' => '',
        'tax_refunded' => '',
        'total_canceled' => '',
        'total_due' => '',
        'total_invoiced' => '',
        'total_item_count' => 0,
        'total_offline_refunded' => '',
        'total_online_refunded' => '',
        'total_paid' => '',
        'total_qty_ordered' => '',
        'total_refunded' => '',
        'updated_at' => '',
        'weight' => '',
        'x_forwarded_for' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/orders/', [
  'body' => '{
  "entity": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "applied_rule_ids": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_canceled": "",
    "base_discount_invoiced": "",
    "base_discount_refunded": "",
    "base_discount_tax_compensation_amount": "",
    "base_discount_tax_compensation_invoiced": "",
    "base_discount_tax_compensation_refunded": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_canceled": "",
    "base_shipping_discount_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_invoiced": "",
    "base_shipping_refunded": "",
    "base_shipping_tax_amount": "",
    "base_shipping_tax_refunded": "",
    "base_subtotal": "",
    "base_subtotal_canceled": "",
    "base_subtotal_incl_tax": "",
    "base_subtotal_invoiced": "",
    "base_subtotal_refunded": "",
    "base_tax_amount": "",
    "base_tax_canceled": "",
    "base_tax_invoiced": "",
    "base_tax_refunded": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_canceled": "",
    "base_total_due": "",
    "base_total_invoiced": "",
    "base_total_invoiced_cost": "",
    "base_total_offline_refunded": "",
    "base_total_online_refunded": "",
    "base_total_paid": "",
    "base_total_qty_ordered": "",
    "base_total_refunded": "",
    "billing_address": {
      "address_type": "",
      "city": "",
      "company": "",
      "country_id": "",
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "entity_id": 0,
      "extension_attributes": {
        "checkout_fields": [
          {
            "attribute_code": "",
            "value": ""
          }
        ]
      },
      "fax": "",
      "firstname": "",
      "lastname": "",
      "middlename": "",
      "parent_id": 0,
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": "",
      "vat_is_valid": 0,
      "vat_request_date": "",
      "vat_request_id": "",
      "vat_request_success": 0
    },
    "billing_address_id": 0,
    "can_ship_partially": 0,
    "can_ship_partially_item": 0,
    "coupon_code": "",
    "created_at": "",
    "customer_dob": "",
    "customer_email": "",
    "customer_firstname": "",
    "customer_gender": 0,
    "customer_group_id": 0,
    "customer_id": 0,
    "customer_is_guest": 0,
    "customer_lastname": "",
    "customer_middlename": "",
    "customer_note": "",
    "customer_note_notify": 0,
    "customer_prefix": "",
    "customer_suffix": "",
    "customer_taxvat": "",
    "discount_amount": "",
    "discount_canceled": "",
    "discount_description": "",
    "discount_invoiced": "",
    "discount_refunded": "",
    "discount_tax_compensation_amount": "",
    "discount_tax_compensation_invoiced": "",
    "discount_tax_compensation_refunded": "",
    "edit_increment": 0,
    "email_sent": 0,
    "entity_id": 0,
    "ext_customer_id": "",
    "ext_order_id": "",
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "applied_taxes": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "extension_attributes": {
            "rates": [
              {
                "code": "",
                "extension_attributes": {},
                "percent": "",
                "title": ""
              }
            ]
          },
          "percent": "",
          "title": ""
        }
      ],
      "base_customer_balance_amount": "",
      "base_customer_balance_invoiced": "",
      "base_customer_balance_refunded": "",
      "base_customer_balance_total_refunded": "",
      "base_gift_cards_amount": "",
      "base_gift_cards_invoiced": "",
      "base_gift_cards_refunded": "",
      "base_reward_currency_amount": "",
      "company_order_attributes": {
        "company_id": 0,
        "company_name": "",
        "extension_attributes": {},
        "order_id": 0
      },
      "converting_from_quote": false,
      "customer_balance_amount": "",
      "customer_balance_invoiced": "",
      "customer_balance_refunded": "",
      "customer_balance_total_refunded": "",
      "gift_cards": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "id": 0
        }
      ],
      "gift_cards_amount": "",
      "gift_cards_invoiced": "",
      "gift_cards_refunded": "",
      "gift_message": {
        "customer_id": 0,
        "extension_attributes": {
          "entity_id": "",
          "entity_type": "",
          "wrapping_add_printed_card": false,
          "wrapping_allow_gift_receipt": false,
          "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
      },
      "gw_add_card": "",
      "gw_allow_gift_receipt": "",
      "gw_base_price": "",
      "gw_base_price_incl_tax": "",
      "gw_base_price_invoiced": "",
      "gw_base_price_refunded": "",
      "gw_base_tax_amount": "",
      "gw_base_tax_amount_invoiced": "",
      "gw_base_tax_amount_refunded": "",
      "gw_card_base_price": "",
      "gw_card_base_price_incl_tax": "",
      "gw_card_base_price_invoiced": "",
      "gw_card_base_price_refunded": "",
      "gw_card_base_tax_amount": "",
      "gw_card_base_tax_invoiced": "",
      "gw_card_base_tax_refunded": "",
      "gw_card_price": "",
      "gw_card_price_incl_tax": "",
      "gw_card_price_invoiced": "",
      "gw_card_price_refunded": "",
      "gw_card_tax_amount": "",
      "gw_card_tax_invoiced": "",
      "gw_card_tax_refunded": "",
      "gw_id": "",
      "gw_items_base_price": "",
      "gw_items_base_price_incl_tax": "",
      "gw_items_base_price_invoiced": "",
      "gw_items_base_price_refunded": "",
      "gw_items_base_tax_amount": "",
      "gw_items_base_tax_invoiced": "",
      "gw_items_base_tax_refunded": "",
      "gw_items_price": "",
      "gw_items_price_incl_tax": "",
      "gw_items_price_invoiced": "",
      "gw_items_price_refunded": "",
      "gw_items_tax_amount": "",
      "gw_items_tax_invoiced": "",
      "gw_items_tax_refunded": "",
      "gw_price": "",
      "gw_price_incl_tax": "",
      "gw_price_invoiced": "",
      "gw_price_refunded": "",
      "gw_tax_amount": "",
      "gw_tax_amount_invoiced": "",
      "gw_tax_amount_refunded": "",
      "item_applied_taxes": [
        {
          "applied_taxes": [
            {}
          ],
          "associated_item_id": 0,
          "extension_attributes": {},
          "item_id": 0,
          "type": ""
        }
      ],
      "payment_additional_info": [
        {
          "key": "",
          "value": ""
        }
      ],
      "reward_currency_amount": "",
      "reward_points_balance": 0,
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "additional_data": "",
              "amount_refunded": "",
              "applied_rule_ids": "",
              "base_amount_refunded": "",
              "base_cost": "",
              "base_discount_amount": "",
              "base_discount_invoiced": "",
              "base_discount_refunded": "",
              "base_discount_tax_compensation_amount": "",
              "base_discount_tax_compensation_invoiced": "",
              "base_discount_tax_compensation_refunded": "",
              "base_original_price": "",
              "base_price": "",
              "base_price_incl_tax": "",
              "base_row_invoiced": "",
              "base_row_total": "",
              "base_row_total_incl_tax": "",
              "base_tax_amount": "",
              "base_tax_before_discount": "",
              "base_tax_invoiced": "",
              "base_tax_refunded": "",
              "base_weee_tax_applied_amount": "",
              "base_weee_tax_applied_row_amnt": "",
              "base_weee_tax_disposition": "",
              "base_weee_tax_row_disposition": "",
              "created_at": "",
              "description": "",
              "discount_amount": "",
              "discount_invoiced": "",
              "discount_percent": "",
              "discount_refunded": "",
              "discount_tax_compensation_amount": "",
              "discount_tax_compensation_canceled": "",
              "discount_tax_compensation_invoiced": "",
              "discount_tax_compensation_refunded": "",
              "event_id": 0,
              "ext_order_item_id": "",
              "extension_attributes": {
                "gift_message": {},
                "gw_base_price": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_id": "",
                "gw_price": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "invoice_text_codes": [],
                "tax_codes": [],
                "vertex_tax_codes": []
              },
              "free_shipping": 0,
              "gw_base_price": "",
              "gw_base_price_invoiced": "",
              "gw_base_price_refunded": "",
              "gw_base_tax_amount": "",
              "gw_base_tax_amount_invoiced": "",
              "gw_base_tax_amount_refunded": "",
              "gw_id": 0,
              "gw_price": "",
              "gw_price_invoiced": "",
              "gw_price_refunded": "",
              "gw_tax_amount": "",
              "gw_tax_amount_invoiced": "",
              "gw_tax_amount_refunded": "",
              "is_qty_decimal": 0,
              "is_virtual": 0,
              "item_id": 0,
              "locked_do_invoice": 0,
              "locked_do_ship": 0,
              "name": "",
              "no_discount": 0,
              "order_id": 0,
              "original_price": "",
              "parent_item": "",
              "parent_item_id": 0,
              "price": "",
              "price_incl_tax": "",
              "product_id": 0,
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty_backordered": "",
              "qty_canceled": "",
              "qty_invoiced": "",
              "qty_ordered": "",
              "qty_refunded": "",
              "qty_returned": "",
              "qty_shipped": "",
              "quote_item_id": 0,
              "row_invoiced": "",
              "row_total": "",
              "row_total_incl_tax": "",
              "row_weight": "",
              "sku": "",
              "store_id": 0,
              "tax_amount": "",
              "tax_before_discount": "",
              "tax_canceled": "",
              "tax_invoiced": "",
              "tax_percent": "",
              "tax_refunded": "",
              "updated_at": "",
              "weee_tax_applied": "",
              "weee_tax_applied_amount": "",
              "weee_tax_applied_row_amount": "",
              "weee_tax_disposition": "",
              "weee_tax_row_disposition": "",
              "weight": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {
              "collection_point": {
                "city": "",
                "collection_point_id": "",
                "country": "",
                "name": "",
                "postcode": "",
                "recipient_address_id": 0,
                "region": "",
                "street": []
              },
              "ext_order_id": "",
              "shipping_experience": {
                "code": "",
                "cost": "",
                "label": ""
              }
            },
            "method": "",
            "total": {
              "base_shipping_amount": "",
              "base_shipping_canceled": "",
              "base_shipping_discount_amount": "",
              "base_shipping_discount_tax_compensation_amnt": "",
              "base_shipping_incl_tax": "",
              "base_shipping_invoiced": "",
              "base_shipping_refunded": "",
              "base_shipping_tax_amount": "",
              "base_shipping_tax_refunded": "",
              "extension_attributes": {},
              "shipping_amount": "",
              "shipping_canceled": "",
              "shipping_discount_amount": "",
              "shipping_discount_tax_compensation_amount": "",
              "shipping_incl_tax": "",
              "shipping_invoiced": "",
              "shipping_refunded": "",
              "shipping_tax_amount": "",
              "shipping_tax_refunded": ""
            }
          },
          "stock_id": 0
        }
      ]
    },
    "forced_shipment_with_invoice": 0,
    "global_currency_code": "",
    "grand_total": "",
    "hold_before_state": "",
    "hold_before_status": "",
    "increment_id": "",
    "is_virtual": 0,
    "items": [
      {}
    ],
    "order_currency_code": "",
    "original_increment_id": "",
    "payment": {
      "account_status": "",
      "additional_data": "",
      "additional_information": [],
      "address_status": "",
      "amount_authorized": "",
      "amount_canceled": "",
      "amount_ordered": "",
      "amount_paid": "",
      "amount_refunded": "",
      "anet_trans_method": "",
      "base_amount_authorized": "",
      "base_amount_canceled": "",
      "base_amount_ordered": "",
      "base_amount_paid": "",
      "base_amount_paid_online": "",
      "base_amount_refunded": "",
      "base_amount_refunded_online": "",
      "base_shipping_amount": "",
      "base_shipping_captured": "",
      "base_shipping_refunded": "",
      "cc_approval": "",
      "cc_avs_status": "",
      "cc_cid_status": "",
      "cc_debug_request_body": "",
      "cc_debug_response_body": "",
      "cc_debug_response_serialized": "",
      "cc_exp_month": "",
      "cc_exp_year": "",
      "cc_last4": "",
      "cc_number_enc": "",
      "cc_owner": "",
      "cc_secure_verify": "",
      "cc_ss_issue": "",
      "cc_ss_start_month": "",
      "cc_ss_start_year": "",
      "cc_status": "",
      "cc_status_description": "",
      "cc_trans_id": "",
      "cc_type": "",
      "echeck_account_name": "",
      "echeck_account_type": "",
      "echeck_bank_name": "",
      "echeck_routing_number": "",
      "echeck_type": "",
      "entity_id": 0,
      "extension_attributes": {
        "vault_payment_token": {
          "created_at": "",
          "customer_id": 0,
          "entity_id": 0,
          "expires_at": "",
          "gateway_token": "",
          "is_active": false,
          "is_visible": false,
          "payment_method_code": "",
          "public_hash": "",
          "token_details": "",
          "type": ""
        }
      },
      "last_trans_id": "",
      "method": "",
      "parent_id": 0,
      "po_number": "",
      "protection_eligibility": "",
      "quote_payment_id": 0,
      "shipping_amount": "",
      "shipping_captured": "",
      "shipping_refunded": ""
    },
    "payment_auth_expiration": 0,
    "payment_authorization_amount": "",
    "protect_code": "",
    "quote_address_id": 0,
    "quote_id": 0,
    "relation_child_id": "",
    "relation_child_real_id": "",
    "relation_parent_id": "",
    "relation_parent_real_id": "",
    "remote_ip": "",
    "shipping_amount": "",
    "shipping_canceled": "",
    "shipping_description": "",
    "shipping_discount_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_invoiced": "",
    "shipping_refunded": "",
    "shipping_tax_amount": "",
    "shipping_tax_refunded": "",
    "state": "",
    "status": "",
    "status_histories": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "entity_name": "",
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0,
        "status": ""
      }
    ],
    "store_currency_code": "",
    "store_id": 0,
    "store_name": "",
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_canceled": "",
    "subtotal_incl_tax": "",
    "subtotal_invoiced": "",
    "subtotal_refunded": "",
    "tax_amount": "",
    "tax_canceled": "",
    "tax_invoiced": "",
    "tax_refunded": "",
    "total_canceled": "",
    "total_due": "",
    "total_invoiced": "",
    "total_item_count": 0,
    "total_offline_refunded": "",
    "total_online_refunded": "",
    "total_paid": "",
    "total_qty_ordered": "",
    "total_refunded": "",
    "updated_at": "",
    "weight": "",
    "x_forwarded_for": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/orders/');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'entity' => [
    'adjustment_negative' => '',
    'adjustment_positive' => '',
    'applied_rule_ids' => '',
    'base_adjustment_negative' => '',
    'base_adjustment_positive' => '',
    'base_currency_code' => '',
    'base_discount_amount' => '',
    'base_discount_canceled' => '',
    'base_discount_invoiced' => '',
    'base_discount_refunded' => '',
    'base_discount_tax_compensation_amount' => '',
    'base_discount_tax_compensation_invoiced' => '',
    'base_discount_tax_compensation_refunded' => '',
    'base_grand_total' => '',
    'base_shipping_amount' => '',
    'base_shipping_canceled' => '',
    'base_shipping_discount_amount' => '',
    'base_shipping_discount_tax_compensation_amnt' => '',
    'base_shipping_incl_tax' => '',
    'base_shipping_invoiced' => '',
    'base_shipping_refunded' => '',
    'base_shipping_tax_amount' => '',
    'base_shipping_tax_refunded' => '',
    'base_subtotal' => '',
    'base_subtotal_canceled' => '',
    'base_subtotal_incl_tax' => '',
    'base_subtotal_invoiced' => '',
    'base_subtotal_refunded' => '',
    'base_tax_amount' => '',
    'base_tax_canceled' => '',
    'base_tax_invoiced' => '',
    'base_tax_refunded' => '',
    'base_to_global_rate' => '',
    'base_to_order_rate' => '',
    'base_total_canceled' => '',
    'base_total_due' => '',
    'base_total_invoiced' => '',
    'base_total_invoiced_cost' => '',
    'base_total_offline_refunded' => '',
    'base_total_online_refunded' => '',
    'base_total_paid' => '',
    'base_total_qty_ordered' => '',
    'base_total_refunded' => '',
    'billing_address' => [
        'address_type' => '',
        'city' => '',
        'company' => '',
        'country_id' => '',
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'entity_id' => 0,
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ]
        ],
        'fax' => '',
        'firstname' => '',
        'lastname' => '',
        'middlename' => '',
        'parent_id' => 0,
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => '',
        'vat_is_valid' => 0,
        'vat_request_date' => '',
        'vat_request_id' => '',
        'vat_request_success' => 0
    ],
    'billing_address_id' => 0,
    'can_ship_partially' => 0,
    'can_ship_partially_item' => 0,
    'coupon_code' => '',
    'created_at' => '',
    'customer_dob' => '',
    'customer_email' => '',
    'customer_firstname' => '',
    'customer_gender' => 0,
    'customer_group_id' => 0,
    'customer_id' => 0,
    'customer_is_guest' => 0,
    'customer_lastname' => '',
    'customer_middlename' => '',
    'customer_note' => '',
    'customer_note_notify' => 0,
    'customer_prefix' => '',
    'customer_suffix' => '',
    'customer_taxvat' => '',
    'discount_amount' => '',
    'discount_canceled' => '',
    'discount_description' => '',
    'discount_invoiced' => '',
    'discount_refunded' => '',
    'discount_tax_compensation_amount' => '',
    'discount_tax_compensation_invoiced' => '',
    'discount_tax_compensation_refunded' => '',
    'edit_increment' => 0,
    'email_sent' => 0,
    'entity_id' => 0,
    'ext_customer_id' => '',
    'ext_order_id' => '',
    'extension_attributes' => [
        'amazon_order_reference_id' => '',
        'applied_taxes' => [
                [
                                'amount' => '',
                                'base_amount' => '',
                                'code' => '',
                                'extension_attributes' => [
                                                                'rates' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'percent' => '',
                                                                                                                                                                                                                                                                'title' => ''
                                                                                                                                ]
                                                                ]
                                ],
                                'percent' => '',
                                'title' => ''
                ]
        ],
        'base_customer_balance_amount' => '',
        'base_customer_balance_invoiced' => '',
        'base_customer_balance_refunded' => '',
        'base_customer_balance_total_refunded' => '',
        'base_gift_cards_amount' => '',
        'base_gift_cards_invoiced' => '',
        'base_gift_cards_refunded' => '',
        'base_reward_currency_amount' => '',
        'company_order_attributes' => [
                'company_id' => 0,
                'company_name' => '',
                'extension_attributes' => [
                                
                ],
                'order_id' => 0
        ],
        'converting_from_quote' => null,
        'customer_balance_amount' => '',
        'customer_balance_invoiced' => '',
        'customer_balance_refunded' => '',
        'customer_balance_total_refunded' => '',
        'gift_cards' => [
                [
                                'amount' => '',
                                'base_amount' => '',
                                'code' => '',
                                'id' => 0
                ]
        ],
        'gift_cards_amount' => '',
        'gift_cards_invoiced' => '',
        'gift_cards_refunded' => '',
        'gift_message' => [
                'customer_id' => 0,
                'extension_attributes' => [
                                'entity_id' => '',
                                'entity_type' => '',
                                'wrapping_add_printed_card' => null,
                                'wrapping_allow_gift_receipt' => null,
                                'wrapping_id' => 0
                ],
                'gift_message_id' => 0,
                'message' => '',
                'recipient' => '',
                'sender' => ''
        ],
        'gw_add_card' => '',
        'gw_allow_gift_receipt' => '',
        'gw_base_price' => '',
        'gw_base_price_incl_tax' => '',
        'gw_base_price_invoiced' => '',
        'gw_base_price_refunded' => '',
        'gw_base_tax_amount' => '',
        'gw_base_tax_amount_invoiced' => '',
        'gw_base_tax_amount_refunded' => '',
        'gw_card_base_price' => '',
        'gw_card_base_price_incl_tax' => '',
        'gw_card_base_price_invoiced' => '',
        'gw_card_base_price_refunded' => '',
        'gw_card_base_tax_amount' => '',
        'gw_card_base_tax_invoiced' => '',
        'gw_card_base_tax_refunded' => '',
        'gw_card_price' => '',
        'gw_card_price_incl_tax' => '',
        'gw_card_price_invoiced' => '',
        'gw_card_price_refunded' => '',
        'gw_card_tax_amount' => '',
        'gw_card_tax_invoiced' => '',
        'gw_card_tax_refunded' => '',
        'gw_id' => '',
        'gw_items_base_price' => '',
        'gw_items_base_price_incl_tax' => '',
        'gw_items_base_price_invoiced' => '',
        'gw_items_base_price_refunded' => '',
        'gw_items_base_tax_amount' => '',
        'gw_items_base_tax_invoiced' => '',
        'gw_items_base_tax_refunded' => '',
        'gw_items_price' => '',
        'gw_items_price_incl_tax' => '',
        'gw_items_price_invoiced' => '',
        'gw_items_price_refunded' => '',
        'gw_items_tax_amount' => '',
        'gw_items_tax_invoiced' => '',
        'gw_items_tax_refunded' => '',
        'gw_price' => '',
        'gw_price_incl_tax' => '',
        'gw_price_invoiced' => '',
        'gw_price_refunded' => '',
        'gw_tax_amount' => '',
        'gw_tax_amount_invoiced' => '',
        'gw_tax_amount_refunded' => '',
        'item_applied_taxes' => [
                [
                                'applied_taxes' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'associated_item_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'item_id' => 0,
                                'type' => ''
                ]
        ],
        'payment_additional_info' => [
                [
                                'key' => '',
                                'value' => ''
                ]
        ],
        'reward_currency_amount' => '',
        'reward_points_balance' => 0,
        'shipping_assignments' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'items' => [
                                                                [
                                                                                                                                'additional_data' => '',
                                                                                                                                'amount_refunded' => '',
                                                                                                                                'applied_rule_ids' => '',
                                                                                                                                'base_amount_refunded' => '',
                                                                                                                                'base_cost' => '',
                                                                                                                                'base_discount_amount' => '',
                                                                                                                                'base_discount_invoiced' => '',
                                                                                                                                'base_discount_refunded' => '',
                                                                                                                                'base_discount_tax_compensation_amount' => '',
                                                                                                                                'base_discount_tax_compensation_invoiced' => '',
                                                                                                                                'base_discount_tax_compensation_refunded' => '',
                                                                                                                                'base_original_price' => '',
                                                                                                                                'base_price' => '',
                                                                                                                                'base_price_incl_tax' => '',
                                                                                                                                'base_row_invoiced' => '',
                                                                                                                                'base_row_total' => '',
                                                                                                                                'base_row_total_incl_tax' => '',
                                                                                                                                'base_tax_amount' => '',
                                                                                                                                'base_tax_before_discount' => '',
                                                                                                                                'base_tax_invoiced' => '',
                                                                                                                                'base_tax_refunded' => '',
                                                                                                                                'base_weee_tax_applied_amount' => '',
                                                                                                                                'base_weee_tax_applied_row_amnt' => '',
                                                                                                                                'base_weee_tax_disposition' => '',
                                                                                                                                'base_weee_tax_row_disposition' => '',
                                                                                                                                'created_at' => '',
                                                                                                                                'description' => '',
                                                                                                                                'discount_amount' => '',
                                                                                                                                'discount_invoiced' => '',
                                                                                                                                'discount_percent' => '',
                                                                                                                                'discount_refunded' => '',
                                                                                                                                'discount_tax_compensation_amount' => '',
                                                                                                                                'discount_tax_compensation_canceled' => '',
                                                                                                                                'discount_tax_compensation_invoiced' => '',
                                                                                                                                'discount_tax_compensation_refunded' => '',
                                                                                                                                'event_id' => 0,
                                                                                                                                'ext_order_item_id' => '',
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'gift_message' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'gw_base_price' => '',
                                                                                                                                                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                'gw_id' => '',
                                                                                                                                                                                                                                                                'gw_price' => '',
                                                                                                                                                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                'invoice_text_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'vertex_tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'free_shipping' => 0,
                                                                                                                                'gw_base_price' => '',
                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                'gw_id' => 0,
                                                                                                                                'gw_price' => '',
                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                'is_qty_decimal' => 0,
                                                                                                                                'is_virtual' => 0,
                                                                                                                                'item_id' => 0,
                                                                                                                                'locked_do_invoice' => 0,
                                                                                                                                'locked_do_ship' => 0,
                                                                                                                                'name' => '',
                                                                                                                                'no_discount' => 0,
                                                                                                                                'order_id' => 0,
                                                                                                                                'original_price' => '',
                                                                                                                                'parent_item' => '',
                                                                                                                                'parent_item_id' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'price_incl_tax' => '',
                                                                                                                                'product_id' => 0,
                                                                                                                                'product_option' => [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'bundle_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_qty' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'configurable_item_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_links' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_item_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_message' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_name' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'product_type' => '',
                                                                                                                                'qty_backordered' => '',
                                                                                                                                'qty_canceled' => '',
                                                                                                                                'qty_invoiced' => '',
                                                                                                                                'qty_ordered' => '',
                                                                                                                                'qty_refunded' => '',
                                                                                                                                'qty_returned' => '',
                                                                                                                                'qty_shipped' => '',
                                                                                                                                'quote_item_id' => 0,
                                                                                                                                'row_invoiced' => '',
                                                                                                                                'row_total' => '',
                                                                                                                                'row_total_incl_tax' => '',
                                                                                                                                'row_weight' => '',
                                                                                                                                'sku' => '',
                                                                                                                                'store_id' => 0,
                                                                                                                                'tax_amount' => '',
                                                                                                                                'tax_before_discount' => '',
                                                                                                                                'tax_canceled' => '',
                                                                                                                                'tax_invoiced' => '',
                                                                                                                                'tax_percent' => '',
                                                                                                                                'tax_refunded' => '',
                                                                                                                                'updated_at' => '',
                                                                                                                                'weee_tax_applied' => '',
                                                                                                                                'weee_tax_applied_amount' => '',
                                                                                                                                'weee_tax_applied_row_amount' => '',
                                                                                                                                'weee_tax_disposition' => '',
                                                                                                                                'weee_tax_row_disposition' => '',
                                                                                                                                'weight' => ''
                                                                ]
                                ],
                                'shipping' => [
                                                                'address' => [
                                                                                                                                
                                                                ],
                                                                'extension_attributes' => [
                                                                                                                                'collection_point' => [
                                                                                                                                                                                                                                                                'city' => '',
                                                                                                                                                                                                                                                                'collection_point_id' => '',
                                                                                                                                                                                                                                                                'country' => '',
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'postcode' => '',
                                                                                                                                                                                                                                                                'recipient_address_id' => 0,
                                                                                                                                                                                                                                                                'region' => '',
                                                                                                                                                                                                                                                                'street' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'ext_order_id' => '',
                                                                                                                                'shipping_experience' => [
                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                'cost' => '',
                                                                                                                                                                                                                                                                'label' => ''
                                                                                                                                ]
                                                                ],
                                                                'method' => '',
                                                                'total' => [
                                                                                                                                'base_shipping_amount' => '',
                                                                                                                                'base_shipping_canceled' => '',
                                                                                                                                'base_shipping_discount_amount' => '',
                                                                                                                                'base_shipping_discount_tax_compensation_amnt' => '',
                                                                                                                                'base_shipping_incl_tax' => '',
                                                                                                                                'base_shipping_invoiced' => '',
                                                                                                                                'base_shipping_refunded' => '',
                                                                                                                                'base_shipping_tax_amount' => '',
                                                                                                                                'base_shipping_tax_refunded' => '',
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'shipping_amount' => '',
                                                                                                                                'shipping_canceled' => '',
                                                                                                                                'shipping_discount_amount' => '',
                                                                                                                                'shipping_discount_tax_compensation_amount' => '',
                                                                                                                                'shipping_incl_tax' => '',
                                                                                                                                'shipping_invoiced' => '',
                                                                                                                                'shipping_refunded' => '',
                                                                                                                                'shipping_tax_amount' => '',
                                                                                                                                'shipping_tax_refunded' => ''
                                                                ]
                                ],
                                'stock_id' => 0
                ]
        ]
    ],
    'forced_shipment_with_invoice' => 0,
    'global_currency_code' => '',
    'grand_total' => '',
    'hold_before_state' => '',
    'hold_before_status' => '',
    'increment_id' => '',
    'is_virtual' => 0,
    'items' => [
        [
                
        ]
    ],
    'order_currency_code' => '',
    'original_increment_id' => '',
    'payment' => [
        'account_status' => '',
        'additional_data' => '',
        'additional_information' => [
                
        ],
        'address_status' => '',
        'amount_authorized' => '',
        'amount_canceled' => '',
        'amount_ordered' => '',
        'amount_paid' => '',
        'amount_refunded' => '',
        'anet_trans_method' => '',
        'base_amount_authorized' => '',
        'base_amount_canceled' => '',
        'base_amount_ordered' => '',
        'base_amount_paid' => '',
        'base_amount_paid_online' => '',
        'base_amount_refunded' => '',
        'base_amount_refunded_online' => '',
        'base_shipping_amount' => '',
        'base_shipping_captured' => '',
        'base_shipping_refunded' => '',
        'cc_approval' => '',
        'cc_avs_status' => '',
        'cc_cid_status' => '',
        'cc_debug_request_body' => '',
        'cc_debug_response_body' => '',
        'cc_debug_response_serialized' => '',
        'cc_exp_month' => '',
        'cc_exp_year' => '',
        'cc_last4' => '',
        'cc_number_enc' => '',
        'cc_owner' => '',
        'cc_secure_verify' => '',
        'cc_ss_issue' => '',
        'cc_ss_start_month' => '',
        'cc_ss_start_year' => '',
        'cc_status' => '',
        'cc_status_description' => '',
        'cc_trans_id' => '',
        'cc_type' => '',
        'echeck_account_name' => '',
        'echeck_account_type' => '',
        'echeck_bank_name' => '',
        'echeck_routing_number' => '',
        'echeck_type' => '',
        'entity_id' => 0,
        'extension_attributes' => [
                'vault_payment_token' => [
                                'created_at' => '',
                                'customer_id' => 0,
                                'entity_id' => 0,
                                'expires_at' => '',
                                'gateway_token' => '',
                                'is_active' => null,
                                'is_visible' => null,
                                'payment_method_code' => '',
                                'public_hash' => '',
                                'token_details' => '',
                                'type' => ''
                ]
        ],
        'last_trans_id' => '',
        'method' => '',
        'parent_id' => 0,
        'po_number' => '',
        'protection_eligibility' => '',
        'quote_payment_id' => 0,
        'shipping_amount' => '',
        'shipping_captured' => '',
        'shipping_refunded' => ''
    ],
    'payment_auth_expiration' => 0,
    'payment_authorization_amount' => '',
    'protect_code' => '',
    'quote_address_id' => 0,
    'quote_id' => 0,
    'relation_child_id' => '',
    'relation_child_real_id' => '',
    'relation_parent_id' => '',
    'relation_parent_real_id' => '',
    'remote_ip' => '',
    'shipping_amount' => '',
    'shipping_canceled' => '',
    'shipping_description' => '',
    'shipping_discount_amount' => '',
    'shipping_discount_tax_compensation_amount' => '',
    'shipping_incl_tax' => '',
    'shipping_invoiced' => '',
    'shipping_refunded' => '',
    'shipping_tax_amount' => '',
    'shipping_tax_refunded' => '',
    'state' => '',
    'status' => '',
    'status_histories' => [
        [
                'comment' => '',
                'created_at' => '',
                'entity_id' => 0,
                'entity_name' => '',
                'extension_attributes' => [
                                
                ],
                'is_customer_notified' => 0,
                'is_visible_on_front' => 0,
                'parent_id' => 0,
                'status' => ''
        ]
    ],
    'store_currency_code' => '',
    'store_id' => 0,
    'store_name' => '',
    'store_to_base_rate' => '',
    'store_to_order_rate' => '',
    'subtotal' => '',
    'subtotal_canceled' => '',
    'subtotal_incl_tax' => '',
    'subtotal_invoiced' => '',
    'subtotal_refunded' => '',
    'tax_amount' => '',
    'tax_canceled' => '',
    'tax_invoiced' => '',
    'tax_refunded' => '',
    'total_canceled' => '',
    'total_due' => '',
    'total_invoiced' => '',
    'total_item_count' => 0,
    'total_offline_refunded' => '',
    'total_online_refunded' => '',
    'total_paid' => '',
    'total_qty_ordered' => '',
    'total_refunded' => '',
    'updated_at' => '',
    'weight' => '',
    'x_forwarded_for' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'entity' => [
    'adjustment_negative' => '',
    'adjustment_positive' => '',
    'applied_rule_ids' => '',
    'base_adjustment_negative' => '',
    'base_adjustment_positive' => '',
    'base_currency_code' => '',
    'base_discount_amount' => '',
    'base_discount_canceled' => '',
    'base_discount_invoiced' => '',
    'base_discount_refunded' => '',
    'base_discount_tax_compensation_amount' => '',
    'base_discount_tax_compensation_invoiced' => '',
    'base_discount_tax_compensation_refunded' => '',
    'base_grand_total' => '',
    'base_shipping_amount' => '',
    'base_shipping_canceled' => '',
    'base_shipping_discount_amount' => '',
    'base_shipping_discount_tax_compensation_amnt' => '',
    'base_shipping_incl_tax' => '',
    'base_shipping_invoiced' => '',
    'base_shipping_refunded' => '',
    'base_shipping_tax_amount' => '',
    'base_shipping_tax_refunded' => '',
    'base_subtotal' => '',
    'base_subtotal_canceled' => '',
    'base_subtotal_incl_tax' => '',
    'base_subtotal_invoiced' => '',
    'base_subtotal_refunded' => '',
    'base_tax_amount' => '',
    'base_tax_canceled' => '',
    'base_tax_invoiced' => '',
    'base_tax_refunded' => '',
    'base_to_global_rate' => '',
    'base_to_order_rate' => '',
    'base_total_canceled' => '',
    'base_total_due' => '',
    'base_total_invoiced' => '',
    'base_total_invoiced_cost' => '',
    'base_total_offline_refunded' => '',
    'base_total_online_refunded' => '',
    'base_total_paid' => '',
    'base_total_qty_ordered' => '',
    'base_total_refunded' => '',
    'billing_address' => [
        'address_type' => '',
        'city' => '',
        'company' => '',
        'country_id' => '',
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'entity_id' => 0,
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ]
        ],
        'fax' => '',
        'firstname' => '',
        'lastname' => '',
        'middlename' => '',
        'parent_id' => 0,
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => '',
        'vat_is_valid' => 0,
        'vat_request_date' => '',
        'vat_request_id' => '',
        'vat_request_success' => 0
    ],
    'billing_address_id' => 0,
    'can_ship_partially' => 0,
    'can_ship_partially_item' => 0,
    'coupon_code' => '',
    'created_at' => '',
    'customer_dob' => '',
    'customer_email' => '',
    'customer_firstname' => '',
    'customer_gender' => 0,
    'customer_group_id' => 0,
    'customer_id' => 0,
    'customer_is_guest' => 0,
    'customer_lastname' => '',
    'customer_middlename' => '',
    'customer_note' => '',
    'customer_note_notify' => 0,
    'customer_prefix' => '',
    'customer_suffix' => '',
    'customer_taxvat' => '',
    'discount_amount' => '',
    'discount_canceled' => '',
    'discount_description' => '',
    'discount_invoiced' => '',
    'discount_refunded' => '',
    'discount_tax_compensation_amount' => '',
    'discount_tax_compensation_invoiced' => '',
    'discount_tax_compensation_refunded' => '',
    'edit_increment' => 0,
    'email_sent' => 0,
    'entity_id' => 0,
    'ext_customer_id' => '',
    'ext_order_id' => '',
    'extension_attributes' => [
        'amazon_order_reference_id' => '',
        'applied_taxes' => [
                [
                                'amount' => '',
                                'base_amount' => '',
                                'code' => '',
                                'extension_attributes' => [
                                                                'rates' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'percent' => '',
                                                                                                                                                                                                                                                                'title' => ''
                                                                                                                                ]
                                                                ]
                                ],
                                'percent' => '',
                                'title' => ''
                ]
        ],
        'base_customer_balance_amount' => '',
        'base_customer_balance_invoiced' => '',
        'base_customer_balance_refunded' => '',
        'base_customer_balance_total_refunded' => '',
        'base_gift_cards_amount' => '',
        'base_gift_cards_invoiced' => '',
        'base_gift_cards_refunded' => '',
        'base_reward_currency_amount' => '',
        'company_order_attributes' => [
                'company_id' => 0,
                'company_name' => '',
                'extension_attributes' => [
                                
                ],
                'order_id' => 0
        ],
        'converting_from_quote' => null,
        'customer_balance_amount' => '',
        'customer_balance_invoiced' => '',
        'customer_balance_refunded' => '',
        'customer_balance_total_refunded' => '',
        'gift_cards' => [
                [
                                'amount' => '',
                                'base_amount' => '',
                                'code' => '',
                                'id' => 0
                ]
        ],
        'gift_cards_amount' => '',
        'gift_cards_invoiced' => '',
        'gift_cards_refunded' => '',
        'gift_message' => [
                'customer_id' => 0,
                'extension_attributes' => [
                                'entity_id' => '',
                                'entity_type' => '',
                                'wrapping_add_printed_card' => null,
                                'wrapping_allow_gift_receipt' => null,
                                'wrapping_id' => 0
                ],
                'gift_message_id' => 0,
                'message' => '',
                'recipient' => '',
                'sender' => ''
        ],
        'gw_add_card' => '',
        'gw_allow_gift_receipt' => '',
        'gw_base_price' => '',
        'gw_base_price_incl_tax' => '',
        'gw_base_price_invoiced' => '',
        'gw_base_price_refunded' => '',
        'gw_base_tax_amount' => '',
        'gw_base_tax_amount_invoiced' => '',
        'gw_base_tax_amount_refunded' => '',
        'gw_card_base_price' => '',
        'gw_card_base_price_incl_tax' => '',
        'gw_card_base_price_invoiced' => '',
        'gw_card_base_price_refunded' => '',
        'gw_card_base_tax_amount' => '',
        'gw_card_base_tax_invoiced' => '',
        'gw_card_base_tax_refunded' => '',
        'gw_card_price' => '',
        'gw_card_price_incl_tax' => '',
        'gw_card_price_invoiced' => '',
        'gw_card_price_refunded' => '',
        'gw_card_tax_amount' => '',
        'gw_card_tax_invoiced' => '',
        'gw_card_tax_refunded' => '',
        'gw_id' => '',
        'gw_items_base_price' => '',
        'gw_items_base_price_incl_tax' => '',
        'gw_items_base_price_invoiced' => '',
        'gw_items_base_price_refunded' => '',
        'gw_items_base_tax_amount' => '',
        'gw_items_base_tax_invoiced' => '',
        'gw_items_base_tax_refunded' => '',
        'gw_items_price' => '',
        'gw_items_price_incl_tax' => '',
        'gw_items_price_invoiced' => '',
        'gw_items_price_refunded' => '',
        'gw_items_tax_amount' => '',
        'gw_items_tax_invoiced' => '',
        'gw_items_tax_refunded' => '',
        'gw_price' => '',
        'gw_price_incl_tax' => '',
        'gw_price_invoiced' => '',
        'gw_price_refunded' => '',
        'gw_tax_amount' => '',
        'gw_tax_amount_invoiced' => '',
        'gw_tax_amount_refunded' => '',
        'item_applied_taxes' => [
                [
                                'applied_taxes' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'associated_item_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'item_id' => 0,
                                'type' => ''
                ]
        ],
        'payment_additional_info' => [
                [
                                'key' => '',
                                'value' => ''
                ]
        ],
        'reward_currency_amount' => '',
        'reward_points_balance' => 0,
        'shipping_assignments' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'items' => [
                                                                [
                                                                                                                                'additional_data' => '',
                                                                                                                                'amount_refunded' => '',
                                                                                                                                'applied_rule_ids' => '',
                                                                                                                                'base_amount_refunded' => '',
                                                                                                                                'base_cost' => '',
                                                                                                                                'base_discount_amount' => '',
                                                                                                                                'base_discount_invoiced' => '',
                                                                                                                                'base_discount_refunded' => '',
                                                                                                                                'base_discount_tax_compensation_amount' => '',
                                                                                                                                'base_discount_tax_compensation_invoiced' => '',
                                                                                                                                'base_discount_tax_compensation_refunded' => '',
                                                                                                                                'base_original_price' => '',
                                                                                                                                'base_price' => '',
                                                                                                                                'base_price_incl_tax' => '',
                                                                                                                                'base_row_invoiced' => '',
                                                                                                                                'base_row_total' => '',
                                                                                                                                'base_row_total_incl_tax' => '',
                                                                                                                                'base_tax_amount' => '',
                                                                                                                                'base_tax_before_discount' => '',
                                                                                                                                'base_tax_invoiced' => '',
                                                                                                                                'base_tax_refunded' => '',
                                                                                                                                'base_weee_tax_applied_amount' => '',
                                                                                                                                'base_weee_tax_applied_row_amnt' => '',
                                                                                                                                'base_weee_tax_disposition' => '',
                                                                                                                                'base_weee_tax_row_disposition' => '',
                                                                                                                                'created_at' => '',
                                                                                                                                'description' => '',
                                                                                                                                'discount_amount' => '',
                                                                                                                                'discount_invoiced' => '',
                                                                                                                                'discount_percent' => '',
                                                                                                                                'discount_refunded' => '',
                                                                                                                                'discount_tax_compensation_amount' => '',
                                                                                                                                'discount_tax_compensation_canceled' => '',
                                                                                                                                'discount_tax_compensation_invoiced' => '',
                                                                                                                                'discount_tax_compensation_refunded' => '',
                                                                                                                                'event_id' => 0,
                                                                                                                                'ext_order_item_id' => '',
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'gift_message' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'gw_base_price' => '',
                                                                                                                                                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                'gw_id' => '',
                                                                                                                                                                                                                                                                'gw_price' => '',
                                                                                                                                                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                'invoice_text_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'vertex_tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'free_shipping' => 0,
                                                                                                                                'gw_base_price' => '',
                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                'gw_id' => 0,
                                                                                                                                'gw_price' => '',
                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                'is_qty_decimal' => 0,
                                                                                                                                'is_virtual' => 0,
                                                                                                                                'item_id' => 0,
                                                                                                                                'locked_do_invoice' => 0,
                                                                                                                                'locked_do_ship' => 0,
                                                                                                                                'name' => '',
                                                                                                                                'no_discount' => 0,
                                                                                                                                'order_id' => 0,
                                                                                                                                'original_price' => '',
                                                                                                                                'parent_item' => '',
                                                                                                                                'parent_item_id' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'price_incl_tax' => '',
                                                                                                                                'product_id' => 0,
                                                                                                                                'product_option' => [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'bundle_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_qty' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'configurable_item_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_links' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_item_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_message' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_name' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'product_type' => '',
                                                                                                                                'qty_backordered' => '',
                                                                                                                                'qty_canceled' => '',
                                                                                                                                'qty_invoiced' => '',
                                                                                                                                'qty_ordered' => '',
                                                                                                                                'qty_refunded' => '',
                                                                                                                                'qty_returned' => '',
                                                                                                                                'qty_shipped' => '',
                                                                                                                                'quote_item_id' => 0,
                                                                                                                                'row_invoiced' => '',
                                                                                                                                'row_total' => '',
                                                                                                                                'row_total_incl_tax' => '',
                                                                                                                                'row_weight' => '',
                                                                                                                                'sku' => '',
                                                                                                                                'store_id' => 0,
                                                                                                                                'tax_amount' => '',
                                                                                                                                'tax_before_discount' => '',
                                                                                                                                'tax_canceled' => '',
                                                                                                                                'tax_invoiced' => '',
                                                                                                                                'tax_percent' => '',
                                                                                                                                'tax_refunded' => '',
                                                                                                                                'updated_at' => '',
                                                                                                                                'weee_tax_applied' => '',
                                                                                                                                'weee_tax_applied_amount' => '',
                                                                                                                                'weee_tax_applied_row_amount' => '',
                                                                                                                                'weee_tax_disposition' => '',
                                                                                                                                'weee_tax_row_disposition' => '',
                                                                                                                                'weight' => ''
                                                                ]
                                ],
                                'shipping' => [
                                                                'address' => [
                                                                                                                                
                                                                ],
                                                                'extension_attributes' => [
                                                                                                                                'collection_point' => [
                                                                                                                                                                                                                                                                'city' => '',
                                                                                                                                                                                                                                                                'collection_point_id' => '',
                                                                                                                                                                                                                                                                'country' => '',
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'postcode' => '',
                                                                                                                                                                                                                                                                'recipient_address_id' => 0,
                                                                                                                                                                                                                                                                'region' => '',
                                                                                                                                                                                                                                                                'street' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'ext_order_id' => '',
                                                                                                                                'shipping_experience' => [
                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                'cost' => '',
                                                                                                                                                                                                                                                                'label' => ''
                                                                                                                                ]
                                                                ],
                                                                'method' => '',
                                                                'total' => [
                                                                                                                                'base_shipping_amount' => '',
                                                                                                                                'base_shipping_canceled' => '',
                                                                                                                                'base_shipping_discount_amount' => '',
                                                                                                                                'base_shipping_discount_tax_compensation_amnt' => '',
                                                                                                                                'base_shipping_incl_tax' => '',
                                                                                                                                'base_shipping_invoiced' => '',
                                                                                                                                'base_shipping_refunded' => '',
                                                                                                                                'base_shipping_tax_amount' => '',
                                                                                                                                'base_shipping_tax_refunded' => '',
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'shipping_amount' => '',
                                                                                                                                'shipping_canceled' => '',
                                                                                                                                'shipping_discount_amount' => '',
                                                                                                                                'shipping_discount_tax_compensation_amount' => '',
                                                                                                                                'shipping_incl_tax' => '',
                                                                                                                                'shipping_invoiced' => '',
                                                                                                                                'shipping_refunded' => '',
                                                                                                                                'shipping_tax_amount' => '',
                                                                                                                                'shipping_tax_refunded' => ''
                                                                ]
                                ],
                                'stock_id' => 0
                ]
        ]
    ],
    'forced_shipment_with_invoice' => 0,
    'global_currency_code' => '',
    'grand_total' => '',
    'hold_before_state' => '',
    'hold_before_status' => '',
    'increment_id' => '',
    'is_virtual' => 0,
    'items' => [
        [
                
        ]
    ],
    'order_currency_code' => '',
    'original_increment_id' => '',
    'payment' => [
        'account_status' => '',
        'additional_data' => '',
        'additional_information' => [
                
        ],
        'address_status' => '',
        'amount_authorized' => '',
        'amount_canceled' => '',
        'amount_ordered' => '',
        'amount_paid' => '',
        'amount_refunded' => '',
        'anet_trans_method' => '',
        'base_amount_authorized' => '',
        'base_amount_canceled' => '',
        'base_amount_ordered' => '',
        'base_amount_paid' => '',
        'base_amount_paid_online' => '',
        'base_amount_refunded' => '',
        'base_amount_refunded_online' => '',
        'base_shipping_amount' => '',
        'base_shipping_captured' => '',
        'base_shipping_refunded' => '',
        'cc_approval' => '',
        'cc_avs_status' => '',
        'cc_cid_status' => '',
        'cc_debug_request_body' => '',
        'cc_debug_response_body' => '',
        'cc_debug_response_serialized' => '',
        'cc_exp_month' => '',
        'cc_exp_year' => '',
        'cc_last4' => '',
        'cc_number_enc' => '',
        'cc_owner' => '',
        'cc_secure_verify' => '',
        'cc_ss_issue' => '',
        'cc_ss_start_month' => '',
        'cc_ss_start_year' => '',
        'cc_status' => '',
        'cc_status_description' => '',
        'cc_trans_id' => '',
        'cc_type' => '',
        'echeck_account_name' => '',
        'echeck_account_type' => '',
        'echeck_bank_name' => '',
        'echeck_routing_number' => '',
        'echeck_type' => '',
        'entity_id' => 0,
        'extension_attributes' => [
                'vault_payment_token' => [
                                'created_at' => '',
                                'customer_id' => 0,
                                'entity_id' => 0,
                                'expires_at' => '',
                                'gateway_token' => '',
                                'is_active' => null,
                                'is_visible' => null,
                                'payment_method_code' => '',
                                'public_hash' => '',
                                'token_details' => '',
                                'type' => ''
                ]
        ],
        'last_trans_id' => '',
        'method' => '',
        'parent_id' => 0,
        'po_number' => '',
        'protection_eligibility' => '',
        'quote_payment_id' => 0,
        'shipping_amount' => '',
        'shipping_captured' => '',
        'shipping_refunded' => ''
    ],
    'payment_auth_expiration' => 0,
    'payment_authorization_amount' => '',
    'protect_code' => '',
    'quote_address_id' => 0,
    'quote_id' => 0,
    'relation_child_id' => '',
    'relation_child_real_id' => '',
    'relation_parent_id' => '',
    'relation_parent_real_id' => '',
    'remote_ip' => '',
    'shipping_amount' => '',
    'shipping_canceled' => '',
    'shipping_description' => '',
    'shipping_discount_amount' => '',
    'shipping_discount_tax_compensation_amount' => '',
    'shipping_incl_tax' => '',
    'shipping_invoiced' => '',
    'shipping_refunded' => '',
    'shipping_tax_amount' => '',
    'shipping_tax_refunded' => '',
    'state' => '',
    'status' => '',
    'status_histories' => [
        [
                'comment' => '',
                'created_at' => '',
                'entity_id' => 0,
                'entity_name' => '',
                'extension_attributes' => [
                                
                ],
                'is_customer_notified' => 0,
                'is_visible_on_front' => 0,
                'parent_id' => 0,
                'status' => ''
        ]
    ],
    'store_currency_code' => '',
    'store_id' => 0,
    'store_name' => '',
    'store_to_base_rate' => '',
    'store_to_order_rate' => '',
    'subtotal' => '',
    'subtotal_canceled' => '',
    'subtotal_incl_tax' => '',
    'subtotal_invoiced' => '',
    'subtotal_refunded' => '',
    'tax_amount' => '',
    'tax_canceled' => '',
    'tax_invoiced' => '',
    'tax_refunded' => '',
    'total_canceled' => '',
    'total_due' => '',
    'total_invoiced' => '',
    'total_item_count' => 0,
    'total_offline_refunded' => '',
    'total_online_refunded' => '',
    'total_paid' => '',
    'total_qty_ordered' => '',
    'total_refunded' => '',
    'updated_at' => '',
    'weight' => '',
    'x_forwarded_for' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/orders/');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/orders/' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "applied_rule_ids": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_canceled": "",
    "base_discount_invoiced": "",
    "base_discount_refunded": "",
    "base_discount_tax_compensation_amount": "",
    "base_discount_tax_compensation_invoiced": "",
    "base_discount_tax_compensation_refunded": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_canceled": "",
    "base_shipping_discount_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_invoiced": "",
    "base_shipping_refunded": "",
    "base_shipping_tax_amount": "",
    "base_shipping_tax_refunded": "",
    "base_subtotal": "",
    "base_subtotal_canceled": "",
    "base_subtotal_incl_tax": "",
    "base_subtotal_invoiced": "",
    "base_subtotal_refunded": "",
    "base_tax_amount": "",
    "base_tax_canceled": "",
    "base_tax_invoiced": "",
    "base_tax_refunded": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_canceled": "",
    "base_total_due": "",
    "base_total_invoiced": "",
    "base_total_invoiced_cost": "",
    "base_total_offline_refunded": "",
    "base_total_online_refunded": "",
    "base_total_paid": "",
    "base_total_qty_ordered": "",
    "base_total_refunded": "",
    "billing_address": {
      "address_type": "",
      "city": "",
      "company": "",
      "country_id": "",
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "entity_id": 0,
      "extension_attributes": {
        "checkout_fields": [
          {
            "attribute_code": "",
            "value": ""
          }
        ]
      },
      "fax": "",
      "firstname": "",
      "lastname": "",
      "middlename": "",
      "parent_id": 0,
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": "",
      "vat_is_valid": 0,
      "vat_request_date": "",
      "vat_request_id": "",
      "vat_request_success": 0
    },
    "billing_address_id": 0,
    "can_ship_partially": 0,
    "can_ship_partially_item": 0,
    "coupon_code": "",
    "created_at": "",
    "customer_dob": "",
    "customer_email": "",
    "customer_firstname": "",
    "customer_gender": 0,
    "customer_group_id": 0,
    "customer_id": 0,
    "customer_is_guest": 0,
    "customer_lastname": "",
    "customer_middlename": "",
    "customer_note": "",
    "customer_note_notify": 0,
    "customer_prefix": "",
    "customer_suffix": "",
    "customer_taxvat": "",
    "discount_amount": "",
    "discount_canceled": "",
    "discount_description": "",
    "discount_invoiced": "",
    "discount_refunded": "",
    "discount_tax_compensation_amount": "",
    "discount_tax_compensation_invoiced": "",
    "discount_tax_compensation_refunded": "",
    "edit_increment": 0,
    "email_sent": 0,
    "entity_id": 0,
    "ext_customer_id": "",
    "ext_order_id": "",
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "applied_taxes": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "extension_attributes": {
            "rates": [
              {
                "code": "",
                "extension_attributes": {},
                "percent": "",
                "title": ""
              }
            ]
          },
          "percent": "",
          "title": ""
        }
      ],
      "base_customer_balance_amount": "",
      "base_customer_balance_invoiced": "",
      "base_customer_balance_refunded": "",
      "base_customer_balance_total_refunded": "",
      "base_gift_cards_amount": "",
      "base_gift_cards_invoiced": "",
      "base_gift_cards_refunded": "",
      "base_reward_currency_amount": "",
      "company_order_attributes": {
        "company_id": 0,
        "company_name": "",
        "extension_attributes": {},
        "order_id": 0
      },
      "converting_from_quote": false,
      "customer_balance_amount": "",
      "customer_balance_invoiced": "",
      "customer_balance_refunded": "",
      "customer_balance_total_refunded": "",
      "gift_cards": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "id": 0
        }
      ],
      "gift_cards_amount": "",
      "gift_cards_invoiced": "",
      "gift_cards_refunded": "",
      "gift_message": {
        "customer_id": 0,
        "extension_attributes": {
          "entity_id": "",
          "entity_type": "",
          "wrapping_add_printed_card": false,
          "wrapping_allow_gift_receipt": false,
          "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
      },
      "gw_add_card": "",
      "gw_allow_gift_receipt": "",
      "gw_base_price": "",
      "gw_base_price_incl_tax": "",
      "gw_base_price_invoiced": "",
      "gw_base_price_refunded": "",
      "gw_base_tax_amount": "",
      "gw_base_tax_amount_invoiced": "",
      "gw_base_tax_amount_refunded": "",
      "gw_card_base_price": "",
      "gw_card_base_price_incl_tax": "",
      "gw_card_base_price_invoiced": "",
      "gw_card_base_price_refunded": "",
      "gw_card_base_tax_amount": "",
      "gw_card_base_tax_invoiced": "",
      "gw_card_base_tax_refunded": "",
      "gw_card_price": "",
      "gw_card_price_incl_tax": "",
      "gw_card_price_invoiced": "",
      "gw_card_price_refunded": "",
      "gw_card_tax_amount": "",
      "gw_card_tax_invoiced": "",
      "gw_card_tax_refunded": "",
      "gw_id": "",
      "gw_items_base_price": "",
      "gw_items_base_price_incl_tax": "",
      "gw_items_base_price_invoiced": "",
      "gw_items_base_price_refunded": "",
      "gw_items_base_tax_amount": "",
      "gw_items_base_tax_invoiced": "",
      "gw_items_base_tax_refunded": "",
      "gw_items_price": "",
      "gw_items_price_incl_tax": "",
      "gw_items_price_invoiced": "",
      "gw_items_price_refunded": "",
      "gw_items_tax_amount": "",
      "gw_items_tax_invoiced": "",
      "gw_items_tax_refunded": "",
      "gw_price": "",
      "gw_price_incl_tax": "",
      "gw_price_invoiced": "",
      "gw_price_refunded": "",
      "gw_tax_amount": "",
      "gw_tax_amount_invoiced": "",
      "gw_tax_amount_refunded": "",
      "item_applied_taxes": [
        {
          "applied_taxes": [
            {}
          ],
          "associated_item_id": 0,
          "extension_attributes": {},
          "item_id": 0,
          "type": ""
        }
      ],
      "payment_additional_info": [
        {
          "key": "",
          "value": ""
        }
      ],
      "reward_currency_amount": "",
      "reward_points_balance": 0,
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "additional_data": "",
              "amount_refunded": "",
              "applied_rule_ids": "",
              "base_amount_refunded": "",
              "base_cost": "",
              "base_discount_amount": "",
              "base_discount_invoiced": "",
              "base_discount_refunded": "",
              "base_discount_tax_compensation_amount": "",
              "base_discount_tax_compensation_invoiced": "",
              "base_discount_tax_compensation_refunded": "",
              "base_original_price": "",
              "base_price": "",
              "base_price_incl_tax": "",
              "base_row_invoiced": "",
              "base_row_total": "",
              "base_row_total_incl_tax": "",
              "base_tax_amount": "",
              "base_tax_before_discount": "",
              "base_tax_invoiced": "",
              "base_tax_refunded": "",
              "base_weee_tax_applied_amount": "",
              "base_weee_tax_applied_row_amnt": "",
              "base_weee_tax_disposition": "",
              "base_weee_tax_row_disposition": "",
              "created_at": "",
              "description": "",
              "discount_amount": "",
              "discount_invoiced": "",
              "discount_percent": "",
              "discount_refunded": "",
              "discount_tax_compensation_amount": "",
              "discount_tax_compensation_canceled": "",
              "discount_tax_compensation_invoiced": "",
              "discount_tax_compensation_refunded": "",
              "event_id": 0,
              "ext_order_item_id": "",
              "extension_attributes": {
                "gift_message": {},
                "gw_base_price": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_id": "",
                "gw_price": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "invoice_text_codes": [],
                "tax_codes": [],
                "vertex_tax_codes": []
              },
              "free_shipping": 0,
              "gw_base_price": "",
              "gw_base_price_invoiced": "",
              "gw_base_price_refunded": "",
              "gw_base_tax_amount": "",
              "gw_base_tax_amount_invoiced": "",
              "gw_base_tax_amount_refunded": "",
              "gw_id": 0,
              "gw_price": "",
              "gw_price_invoiced": "",
              "gw_price_refunded": "",
              "gw_tax_amount": "",
              "gw_tax_amount_invoiced": "",
              "gw_tax_amount_refunded": "",
              "is_qty_decimal": 0,
              "is_virtual": 0,
              "item_id": 0,
              "locked_do_invoice": 0,
              "locked_do_ship": 0,
              "name": "",
              "no_discount": 0,
              "order_id": 0,
              "original_price": "",
              "parent_item": "",
              "parent_item_id": 0,
              "price": "",
              "price_incl_tax": "",
              "product_id": 0,
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty_backordered": "",
              "qty_canceled": "",
              "qty_invoiced": "",
              "qty_ordered": "",
              "qty_refunded": "",
              "qty_returned": "",
              "qty_shipped": "",
              "quote_item_id": 0,
              "row_invoiced": "",
              "row_total": "",
              "row_total_incl_tax": "",
              "row_weight": "",
              "sku": "",
              "store_id": 0,
              "tax_amount": "",
              "tax_before_discount": "",
              "tax_canceled": "",
              "tax_invoiced": "",
              "tax_percent": "",
              "tax_refunded": "",
              "updated_at": "",
              "weee_tax_applied": "",
              "weee_tax_applied_amount": "",
              "weee_tax_applied_row_amount": "",
              "weee_tax_disposition": "",
              "weee_tax_row_disposition": "",
              "weight": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {
              "collection_point": {
                "city": "",
                "collection_point_id": "",
                "country": "",
                "name": "",
                "postcode": "",
                "recipient_address_id": 0,
                "region": "",
                "street": []
              },
              "ext_order_id": "",
              "shipping_experience": {
                "code": "",
                "cost": "",
                "label": ""
              }
            },
            "method": "",
            "total": {
              "base_shipping_amount": "",
              "base_shipping_canceled": "",
              "base_shipping_discount_amount": "",
              "base_shipping_discount_tax_compensation_amnt": "",
              "base_shipping_incl_tax": "",
              "base_shipping_invoiced": "",
              "base_shipping_refunded": "",
              "base_shipping_tax_amount": "",
              "base_shipping_tax_refunded": "",
              "extension_attributes": {},
              "shipping_amount": "",
              "shipping_canceled": "",
              "shipping_discount_amount": "",
              "shipping_discount_tax_compensation_amount": "",
              "shipping_incl_tax": "",
              "shipping_invoiced": "",
              "shipping_refunded": "",
              "shipping_tax_amount": "",
              "shipping_tax_refunded": ""
            }
          },
          "stock_id": 0
        }
      ]
    },
    "forced_shipment_with_invoice": 0,
    "global_currency_code": "",
    "grand_total": "",
    "hold_before_state": "",
    "hold_before_status": "",
    "increment_id": "",
    "is_virtual": 0,
    "items": [
      {}
    ],
    "order_currency_code": "",
    "original_increment_id": "",
    "payment": {
      "account_status": "",
      "additional_data": "",
      "additional_information": [],
      "address_status": "",
      "amount_authorized": "",
      "amount_canceled": "",
      "amount_ordered": "",
      "amount_paid": "",
      "amount_refunded": "",
      "anet_trans_method": "",
      "base_amount_authorized": "",
      "base_amount_canceled": "",
      "base_amount_ordered": "",
      "base_amount_paid": "",
      "base_amount_paid_online": "",
      "base_amount_refunded": "",
      "base_amount_refunded_online": "",
      "base_shipping_amount": "",
      "base_shipping_captured": "",
      "base_shipping_refunded": "",
      "cc_approval": "",
      "cc_avs_status": "",
      "cc_cid_status": "",
      "cc_debug_request_body": "",
      "cc_debug_response_body": "",
      "cc_debug_response_serialized": "",
      "cc_exp_month": "",
      "cc_exp_year": "",
      "cc_last4": "",
      "cc_number_enc": "",
      "cc_owner": "",
      "cc_secure_verify": "",
      "cc_ss_issue": "",
      "cc_ss_start_month": "",
      "cc_ss_start_year": "",
      "cc_status": "",
      "cc_status_description": "",
      "cc_trans_id": "",
      "cc_type": "",
      "echeck_account_name": "",
      "echeck_account_type": "",
      "echeck_bank_name": "",
      "echeck_routing_number": "",
      "echeck_type": "",
      "entity_id": 0,
      "extension_attributes": {
        "vault_payment_token": {
          "created_at": "",
          "customer_id": 0,
          "entity_id": 0,
          "expires_at": "",
          "gateway_token": "",
          "is_active": false,
          "is_visible": false,
          "payment_method_code": "",
          "public_hash": "",
          "token_details": "",
          "type": ""
        }
      },
      "last_trans_id": "",
      "method": "",
      "parent_id": 0,
      "po_number": "",
      "protection_eligibility": "",
      "quote_payment_id": 0,
      "shipping_amount": "",
      "shipping_captured": "",
      "shipping_refunded": ""
    },
    "payment_auth_expiration": 0,
    "payment_authorization_amount": "",
    "protect_code": "",
    "quote_address_id": 0,
    "quote_id": 0,
    "relation_child_id": "",
    "relation_child_real_id": "",
    "relation_parent_id": "",
    "relation_parent_real_id": "",
    "remote_ip": "",
    "shipping_amount": "",
    "shipping_canceled": "",
    "shipping_description": "",
    "shipping_discount_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_invoiced": "",
    "shipping_refunded": "",
    "shipping_tax_amount": "",
    "shipping_tax_refunded": "",
    "state": "",
    "status": "",
    "status_histories": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "entity_name": "",
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0,
        "status": ""
      }
    ],
    "store_currency_code": "",
    "store_id": 0,
    "store_name": "",
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_canceled": "",
    "subtotal_incl_tax": "",
    "subtotal_invoiced": "",
    "subtotal_refunded": "",
    "tax_amount": "",
    "tax_canceled": "",
    "tax_invoiced": "",
    "tax_refunded": "",
    "total_canceled": "",
    "total_due": "",
    "total_invoiced": "",
    "total_item_count": 0,
    "total_offline_refunded": "",
    "total_online_refunded": "",
    "total_paid": "",
    "total_qty_ordered": "",
    "total_refunded": "",
    "updated_at": "",
    "weight": "",
    "x_forwarded_for": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/orders/' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "applied_rule_ids": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_canceled": "",
    "base_discount_invoiced": "",
    "base_discount_refunded": "",
    "base_discount_tax_compensation_amount": "",
    "base_discount_tax_compensation_invoiced": "",
    "base_discount_tax_compensation_refunded": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_canceled": "",
    "base_shipping_discount_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_invoiced": "",
    "base_shipping_refunded": "",
    "base_shipping_tax_amount": "",
    "base_shipping_tax_refunded": "",
    "base_subtotal": "",
    "base_subtotal_canceled": "",
    "base_subtotal_incl_tax": "",
    "base_subtotal_invoiced": "",
    "base_subtotal_refunded": "",
    "base_tax_amount": "",
    "base_tax_canceled": "",
    "base_tax_invoiced": "",
    "base_tax_refunded": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_canceled": "",
    "base_total_due": "",
    "base_total_invoiced": "",
    "base_total_invoiced_cost": "",
    "base_total_offline_refunded": "",
    "base_total_online_refunded": "",
    "base_total_paid": "",
    "base_total_qty_ordered": "",
    "base_total_refunded": "",
    "billing_address": {
      "address_type": "",
      "city": "",
      "company": "",
      "country_id": "",
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "entity_id": 0,
      "extension_attributes": {
        "checkout_fields": [
          {
            "attribute_code": "",
            "value": ""
          }
        ]
      },
      "fax": "",
      "firstname": "",
      "lastname": "",
      "middlename": "",
      "parent_id": 0,
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": "",
      "vat_is_valid": 0,
      "vat_request_date": "",
      "vat_request_id": "",
      "vat_request_success": 0
    },
    "billing_address_id": 0,
    "can_ship_partially": 0,
    "can_ship_partially_item": 0,
    "coupon_code": "",
    "created_at": "",
    "customer_dob": "",
    "customer_email": "",
    "customer_firstname": "",
    "customer_gender": 0,
    "customer_group_id": 0,
    "customer_id": 0,
    "customer_is_guest": 0,
    "customer_lastname": "",
    "customer_middlename": "",
    "customer_note": "",
    "customer_note_notify": 0,
    "customer_prefix": "",
    "customer_suffix": "",
    "customer_taxvat": "",
    "discount_amount": "",
    "discount_canceled": "",
    "discount_description": "",
    "discount_invoiced": "",
    "discount_refunded": "",
    "discount_tax_compensation_amount": "",
    "discount_tax_compensation_invoiced": "",
    "discount_tax_compensation_refunded": "",
    "edit_increment": 0,
    "email_sent": 0,
    "entity_id": 0,
    "ext_customer_id": "",
    "ext_order_id": "",
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "applied_taxes": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "extension_attributes": {
            "rates": [
              {
                "code": "",
                "extension_attributes": {},
                "percent": "",
                "title": ""
              }
            ]
          },
          "percent": "",
          "title": ""
        }
      ],
      "base_customer_balance_amount": "",
      "base_customer_balance_invoiced": "",
      "base_customer_balance_refunded": "",
      "base_customer_balance_total_refunded": "",
      "base_gift_cards_amount": "",
      "base_gift_cards_invoiced": "",
      "base_gift_cards_refunded": "",
      "base_reward_currency_amount": "",
      "company_order_attributes": {
        "company_id": 0,
        "company_name": "",
        "extension_attributes": {},
        "order_id": 0
      },
      "converting_from_quote": false,
      "customer_balance_amount": "",
      "customer_balance_invoiced": "",
      "customer_balance_refunded": "",
      "customer_balance_total_refunded": "",
      "gift_cards": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "id": 0
        }
      ],
      "gift_cards_amount": "",
      "gift_cards_invoiced": "",
      "gift_cards_refunded": "",
      "gift_message": {
        "customer_id": 0,
        "extension_attributes": {
          "entity_id": "",
          "entity_type": "",
          "wrapping_add_printed_card": false,
          "wrapping_allow_gift_receipt": false,
          "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
      },
      "gw_add_card": "",
      "gw_allow_gift_receipt": "",
      "gw_base_price": "",
      "gw_base_price_incl_tax": "",
      "gw_base_price_invoiced": "",
      "gw_base_price_refunded": "",
      "gw_base_tax_amount": "",
      "gw_base_tax_amount_invoiced": "",
      "gw_base_tax_amount_refunded": "",
      "gw_card_base_price": "",
      "gw_card_base_price_incl_tax": "",
      "gw_card_base_price_invoiced": "",
      "gw_card_base_price_refunded": "",
      "gw_card_base_tax_amount": "",
      "gw_card_base_tax_invoiced": "",
      "gw_card_base_tax_refunded": "",
      "gw_card_price": "",
      "gw_card_price_incl_tax": "",
      "gw_card_price_invoiced": "",
      "gw_card_price_refunded": "",
      "gw_card_tax_amount": "",
      "gw_card_tax_invoiced": "",
      "gw_card_tax_refunded": "",
      "gw_id": "",
      "gw_items_base_price": "",
      "gw_items_base_price_incl_tax": "",
      "gw_items_base_price_invoiced": "",
      "gw_items_base_price_refunded": "",
      "gw_items_base_tax_amount": "",
      "gw_items_base_tax_invoiced": "",
      "gw_items_base_tax_refunded": "",
      "gw_items_price": "",
      "gw_items_price_incl_tax": "",
      "gw_items_price_invoiced": "",
      "gw_items_price_refunded": "",
      "gw_items_tax_amount": "",
      "gw_items_tax_invoiced": "",
      "gw_items_tax_refunded": "",
      "gw_price": "",
      "gw_price_incl_tax": "",
      "gw_price_invoiced": "",
      "gw_price_refunded": "",
      "gw_tax_amount": "",
      "gw_tax_amount_invoiced": "",
      "gw_tax_amount_refunded": "",
      "item_applied_taxes": [
        {
          "applied_taxes": [
            {}
          ],
          "associated_item_id": 0,
          "extension_attributes": {},
          "item_id": 0,
          "type": ""
        }
      ],
      "payment_additional_info": [
        {
          "key": "",
          "value": ""
        }
      ],
      "reward_currency_amount": "",
      "reward_points_balance": 0,
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "additional_data": "",
              "amount_refunded": "",
              "applied_rule_ids": "",
              "base_amount_refunded": "",
              "base_cost": "",
              "base_discount_amount": "",
              "base_discount_invoiced": "",
              "base_discount_refunded": "",
              "base_discount_tax_compensation_amount": "",
              "base_discount_tax_compensation_invoiced": "",
              "base_discount_tax_compensation_refunded": "",
              "base_original_price": "",
              "base_price": "",
              "base_price_incl_tax": "",
              "base_row_invoiced": "",
              "base_row_total": "",
              "base_row_total_incl_tax": "",
              "base_tax_amount": "",
              "base_tax_before_discount": "",
              "base_tax_invoiced": "",
              "base_tax_refunded": "",
              "base_weee_tax_applied_amount": "",
              "base_weee_tax_applied_row_amnt": "",
              "base_weee_tax_disposition": "",
              "base_weee_tax_row_disposition": "",
              "created_at": "",
              "description": "",
              "discount_amount": "",
              "discount_invoiced": "",
              "discount_percent": "",
              "discount_refunded": "",
              "discount_tax_compensation_amount": "",
              "discount_tax_compensation_canceled": "",
              "discount_tax_compensation_invoiced": "",
              "discount_tax_compensation_refunded": "",
              "event_id": 0,
              "ext_order_item_id": "",
              "extension_attributes": {
                "gift_message": {},
                "gw_base_price": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_id": "",
                "gw_price": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "invoice_text_codes": [],
                "tax_codes": [],
                "vertex_tax_codes": []
              },
              "free_shipping": 0,
              "gw_base_price": "",
              "gw_base_price_invoiced": "",
              "gw_base_price_refunded": "",
              "gw_base_tax_amount": "",
              "gw_base_tax_amount_invoiced": "",
              "gw_base_tax_amount_refunded": "",
              "gw_id": 0,
              "gw_price": "",
              "gw_price_invoiced": "",
              "gw_price_refunded": "",
              "gw_tax_amount": "",
              "gw_tax_amount_invoiced": "",
              "gw_tax_amount_refunded": "",
              "is_qty_decimal": 0,
              "is_virtual": 0,
              "item_id": 0,
              "locked_do_invoice": 0,
              "locked_do_ship": 0,
              "name": "",
              "no_discount": 0,
              "order_id": 0,
              "original_price": "",
              "parent_item": "",
              "parent_item_id": 0,
              "price": "",
              "price_incl_tax": "",
              "product_id": 0,
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty_backordered": "",
              "qty_canceled": "",
              "qty_invoiced": "",
              "qty_ordered": "",
              "qty_refunded": "",
              "qty_returned": "",
              "qty_shipped": "",
              "quote_item_id": 0,
              "row_invoiced": "",
              "row_total": "",
              "row_total_incl_tax": "",
              "row_weight": "",
              "sku": "",
              "store_id": 0,
              "tax_amount": "",
              "tax_before_discount": "",
              "tax_canceled": "",
              "tax_invoiced": "",
              "tax_percent": "",
              "tax_refunded": "",
              "updated_at": "",
              "weee_tax_applied": "",
              "weee_tax_applied_amount": "",
              "weee_tax_applied_row_amount": "",
              "weee_tax_disposition": "",
              "weee_tax_row_disposition": "",
              "weight": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {
              "collection_point": {
                "city": "",
                "collection_point_id": "",
                "country": "",
                "name": "",
                "postcode": "",
                "recipient_address_id": 0,
                "region": "",
                "street": []
              },
              "ext_order_id": "",
              "shipping_experience": {
                "code": "",
                "cost": "",
                "label": ""
              }
            },
            "method": "",
            "total": {
              "base_shipping_amount": "",
              "base_shipping_canceled": "",
              "base_shipping_discount_amount": "",
              "base_shipping_discount_tax_compensation_amnt": "",
              "base_shipping_incl_tax": "",
              "base_shipping_invoiced": "",
              "base_shipping_refunded": "",
              "base_shipping_tax_amount": "",
              "base_shipping_tax_refunded": "",
              "extension_attributes": {},
              "shipping_amount": "",
              "shipping_canceled": "",
              "shipping_discount_amount": "",
              "shipping_discount_tax_compensation_amount": "",
              "shipping_incl_tax": "",
              "shipping_invoiced": "",
              "shipping_refunded": "",
              "shipping_tax_amount": "",
              "shipping_tax_refunded": ""
            }
          },
          "stock_id": 0
        }
      ]
    },
    "forced_shipment_with_invoice": 0,
    "global_currency_code": "",
    "grand_total": "",
    "hold_before_state": "",
    "hold_before_status": "",
    "increment_id": "",
    "is_virtual": 0,
    "items": [
      {}
    ],
    "order_currency_code": "",
    "original_increment_id": "",
    "payment": {
      "account_status": "",
      "additional_data": "",
      "additional_information": [],
      "address_status": "",
      "amount_authorized": "",
      "amount_canceled": "",
      "amount_ordered": "",
      "amount_paid": "",
      "amount_refunded": "",
      "anet_trans_method": "",
      "base_amount_authorized": "",
      "base_amount_canceled": "",
      "base_amount_ordered": "",
      "base_amount_paid": "",
      "base_amount_paid_online": "",
      "base_amount_refunded": "",
      "base_amount_refunded_online": "",
      "base_shipping_amount": "",
      "base_shipping_captured": "",
      "base_shipping_refunded": "",
      "cc_approval": "",
      "cc_avs_status": "",
      "cc_cid_status": "",
      "cc_debug_request_body": "",
      "cc_debug_response_body": "",
      "cc_debug_response_serialized": "",
      "cc_exp_month": "",
      "cc_exp_year": "",
      "cc_last4": "",
      "cc_number_enc": "",
      "cc_owner": "",
      "cc_secure_verify": "",
      "cc_ss_issue": "",
      "cc_ss_start_month": "",
      "cc_ss_start_year": "",
      "cc_status": "",
      "cc_status_description": "",
      "cc_trans_id": "",
      "cc_type": "",
      "echeck_account_name": "",
      "echeck_account_type": "",
      "echeck_bank_name": "",
      "echeck_routing_number": "",
      "echeck_type": "",
      "entity_id": 0,
      "extension_attributes": {
        "vault_payment_token": {
          "created_at": "",
          "customer_id": 0,
          "entity_id": 0,
          "expires_at": "",
          "gateway_token": "",
          "is_active": false,
          "is_visible": false,
          "payment_method_code": "",
          "public_hash": "",
          "token_details": "",
          "type": ""
        }
      },
      "last_trans_id": "",
      "method": "",
      "parent_id": 0,
      "po_number": "",
      "protection_eligibility": "",
      "quote_payment_id": 0,
      "shipping_amount": "",
      "shipping_captured": "",
      "shipping_refunded": ""
    },
    "payment_auth_expiration": 0,
    "payment_authorization_amount": "",
    "protect_code": "",
    "quote_address_id": 0,
    "quote_id": 0,
    "relation_child_id": "",
    "relation_child_real_id": "",
    "relation_parent_id": "",
    "relation_parent_real_id": "",
    "remote_ip": "",
    "shipping_amount": "",
    "shipping_canceled": "",
    "shipping_description": "",
    "shipping_discount_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_invoiced": "",
    "shipping_refunded": "",
    "shipping_tax_amount": "",
    "shipping_tax_refunded": "",
    "state": "",
    "status": "",
    "status_histories": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "entity_name": "",
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0,
        "status": ""
      }
    ],
    "store_currency_code": "",
    "store_id": 0,
    "store_name": "",
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_canceled": "",
    "subtotal_incl_tax": "",
    "subtotal_invoiced": "",
    "subtotal_refunded": "",
    "tax_amount": "",
    "tax_canceled": "",
    "tax_invoiced": "",
    "tax_refunded": "",
    "total_canceled": "",
    "total_due": "",
    "total_invoiced": "",
    "total_item_count": 0,
    "total_offline_refunded": "",
    "total_online_refunded": "",
    "total_paid": "",
    "total_qty_ordered": "",
    "total_refunded": "",
    "updated_at": "",
    "weight": "",
    "x_forwarded_for": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/orders/", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/orders/"

payload = { "entity": {
        "adjustment_negative": "",
        "adjustment_positive": "",
        "applied_rule_ids": "",
        "base_adjustment_negative": "",
        "base_adjustment_positive": "",
        "base_currency_code": "",
        "base_discount_amount": "",
        "base_discount_canceled": "",
        "base_discount_invoiced": "",
        "base_discount_refunded": "",
        "base_discount_tax_compensation_amount": "",
        "base_discount_tax_compensation_invoiced": "",
        "base_discount_tax_compensation_refunded": "",
        "base_grand_total": "",
        "base_shipping_amount": "",
        "base_shipping_canceled": "",
        "base_shipping_discount_amount": "",
        "base_shipping_discount_tax_compensation_amnt": "",
        "base_shipping_incl_tax": "",
        "base_shipping_invoiced": "",
        "base_shipping_refunded": "",
        "base_shipping_tax_amount": "",
        "base_shipping_tax_refunded": "",
        "base_subtotal": "",
        "base_subtotal_canceled": "",
        "base_subtotal_incl_tax": "",
        "base_subtotal_invoiced": "",
        "base_subtotal_refunded": "",
        "base_tax_amount": "",
        "base_tax_canceled": "",
        "base_tax_invoiced": "",
        "base_tax_refunded": "",
        "base_to_global_rate": "",
        "base_to_order_rate": "",
        "base_total_canceled": "",
        "base_total_due": "",
        "base_total_invoiced": "",
        "base_total_invoiced_cost": "",
        "base_total_offline_refunded": "",
        "base_total_online_refunded": "",
        "base_total_paid": "",
        "base_total_qty_ordered": "",
        "base_total_refunded": "",
        "billing_address": {
            "address_type": "",
            "city": "",
            "company": "",
            "country_id": "",
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "entity_id": 0,
            "extension_attributes": { "checkout_fields": [
                    {
                        "attribute_code": "",
                        "value": ""
                    }
                ] },
            "fax": "",
            "firstname": "",
            "lastname": "",
            "middlename": "",
            "parent_id": 0,
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "street": [],
            "suffix": "",
            "telephone": "",
            "vat_id": "",
            "vat_is_valid": 0,
            "vat_request_date": "",
            "vat_request_id": "",
            "vat_request_success": 0
        },
        "billing_address_id": 0,
        "can_ship_partially": 0,
        "can_ship_partially_item": 0,
        "coupon_code": "",
        "created_at": "",
        "customer_dob": "",
        "customer_email": "",
        "customer_firstname": "",
        "customer_gender": 0,
        "customer_group_id": 0,
        "customer_id": 0,
        "customer_is_guest": 0,
        "customer_lastname": "",
        "customer_middlename": "",
        "customer_note": "",
        "customer_note_notify": 0,
        "customer_prefix": "",
        "customer_suffix": "",
        "customer_taxvat": "",
        "discount_amount": "",
        "discount_canceled": "",
        "discount_description": "",
        "discount_invoiced": "",
        "discount_refunded": "",
        "discount_tax_compensation_amount": "",
        "discount_tax_compensation_invoiced": "",
        "discount_tax_compensation_refunded": "",
        "edit_increment": 0,
        "email_sent": 0,
        "entity_id": 0,
        "ext_customer_id": "",
        "ext_order_id": "",
        "extension_attributes": {
            "amazon_order_reference_id": "",
            "applied_taxes": [
                {
                    "amount": "",
                    "base_amount": "",
                    "code": "",
                    "extension_attributes": { "rates": [
                            {
                                "code": "",
                                "extension_attributes": {},
                                "percent": "",
                                "title": ""
                            }
                        ] },
                    "percent": "",
                    "title": ""
                }
            ],
            "base_customer_balance_amount": "",
            "base_customer_balance_invoiced": "",
            "base_customer_balance_refunded": "",
            "base_customer_balance_total_refunded": "",
            "base_gift_cards_amount": "",
            "base_gift_cards_invoiced": "",
            "base_gift_cards_refunded": "",
            "base_reward_currency_amount": "",
            "company_order_attributes": {
                "company_id": 0,
                "company_name": "",
                "extension_attributes": {},
                "order_id": 0
            },
            "converting_from_quote": False,
            "customer_balance_amount": "",
            "customer_balance_invoiced": "",
            "customer_balance_refunded": "",
            "customer_balance_total_refunded": "",
            "gift_cards": [
                {
                    "amount": "",
                    "base_amount": "",
                    "code": "",
                    "id": 0
                }
            ],
            "gift_cards_amount": "",
            "gift_cards_invoiced": "",
            "gift_cards_refunded": "",
            "gift_message": {
                "customer_id": 0,
                "extension_attributes": {
                    "entity_id": "",
                    "entity_type": "",
                    "wrapping_add_printed_card": False,
                    "wrapping_allow_gift_receipt": False,
                    "wrapping_id": 0
                },
                "gift_message_id": 0,
                "message": "",
                "recipient": "",
                "sender": ""
            },
            "gw_add_card": "",
            "gw_allow_gift_receipt": "",
            "gw_base_price": "",
            "gw_base_price_incl_tax": "",
            "gw_base_price_invoiced": "",
            "gw_base_price_refunded": "",
            "gw_base_tax_amount": "",
            "gw_base_tax_amount_invoiced": "",
            "gw_base_tax_amount_refunded": "",
            "gw_card_base_price": "",
            "gw_card_base_price_incl_tax": "",
            "gw_card_base_price_invoiced": "",
            "gw_card_base_price_refunded": "",
            "gw_card_base_tax_amount": "",
            "gw_card_base_tax_invoiced": "",
            "gw_card_base_tax_refunded": "",
            "gw_card_price": "",
            "gw_card_price_incl_tax": "",
            "gw_card_price_invoiced": "",
            "gw_card_price_refunded": "",
            "gw_card_tax_amount": "",
            "gw_card_tax_invoiced": "",
            "gw_card_tax_refunded": "",
            "gw_id": "",
            "gw_items_base_price": "",
            "gw_items_base_price_incl_tax": "",
            "gw_items_base_price_invoiced": "",
            "gw_items_base_price_refunded": "",
            "gw_items_base_tax_amount": "",
            "gw_items_base_tax_invoiced": "",
            "gw_items_base_tax_refunded": "",
            "gw_items_price": "",
            "gw_items_price_incl_tax": "",
            "gw_items_price_invoiced": "",
            "gw_items_price_refunded": "",
            "gw_items_tax_amount": "",
            "gw_items_tax_invoiced": "",
            "gw_items_tax_refunded": "",
            "gw_price": "",
            "gw_price_incl_tax": "",
            "gw_price_invoiced": "",
            "gw_price_refunded": "",
            "gw_tax_amount": "",
            "gw_tax_amount_invoiced": "",
            "gw_tax_amount_refunded": "",
            "item_applied_taxes": [
                {
                    "applied_taxes": [{}],
                    "associated_item_id": 0,
                    "extension_attributes": {},
                    "item_id": 0,
                    "type": ""
                }
            ],
            "payment_additional_info": [
                {
                    "key": "",
                    "value": ""
                }
            ],
            "reward_currency_amount": "",
            "reward_points_balance": 0,
            "shipping_assignments": [
                {
                    "extension_attributes": {},
                    "items": [
                        {
                            "additional_data": "",
                            "amount_refunded": "",
                            "applied_rule_ids": "",
                            "base_amount_refunded": "",
                            "base_cost": "",
                            "base_discount_amount": "",
                            "base_discount_invoiced": "",
                            "base_discount_refunded": "",
                            "base_discount_tax_compensation_amount": "",
                            "base_discount_tax_compensation_invoiced": "",
                            "base_discount_tax_compensation_refunded": "",
                            "base_original_price": "",
                            "base_price": "",
                            "base_price_incl_tax": "",
                            "base_row_invoiced": "",
                            "base_row_total": "",
                            "base_row_total_incl_tax": "",
                            "base_tax_amount": "",
                            "base_tax_before_discount": "",
                            "base_tax_invoiced": "",
                            "base_tax_refunded": "",
                            "base_weee_tax_applied_amount": "",
                            "base_weee_tax_applied_row_amnt": "",
                            "base_weee_tax_disposition": "",
                            "base_weee_tax_row_disposition": "",
                            "created_at": "",
                            "description": "",
                            "discount_amount": "",
                            "discount_invoiced": "",
                            "discount_percent": "",
                            "discount_refunded": "",
                            "discount_tax_compensation_amount": "",
                            "discount_tax_compensation_canceled": "",
                            "discount_tax_compensation_invoiced": "",
                            "discount_tax_compensation_refunded": "",
                            "event_id": 0,
                            "ext_order_item_id": "",
                            "extension_attributes": {
                                "gift_message": {},
                                "gw_base_price": "",
                                "gw_base_price_invoiced": "",
                                "gw_base_price_refunded": "",
                                "gw_base_tax_amount": "",
                                "gw_base_tax_amount_invoiced": "",
                                "gw_base_tax_amount_refunded": "",
                                "gw_id": "",
                                "gw_price": "",
                                "gw_price_invoiced": "",
                                "gw_price_refunded": "",
                                "gw_tax_amount": "",
                                "gw_tax_amount_invoiced": "",
                                "gw_tax_amount_refunded": "",
                                "invoice_text_codes": [],
                                "tax_codes": [],
                                "vertex_tax_codes": []
                            },
                            "free_shipping": 0,
                            "gw_base_price": "",
                            "gw_base_price_invoiced": "",
                            "gw_base_price_refunded": "",
                            "gw_base_tax_amount": "",
                            "gw_base_tax_amount_invoiced": "",
                            "gw_base_tax_amount_refunded": "",
                            "gw_id": 0,
                            "gw_price": "",
                            "gw_price_invoiced": "",
                            "gw_price_refunded": "",
                            "gw_tax_amount": "",
                            "gw_tax_amount_invoiced": "",
                            "gw_tax_amount_refunded": "",
                            "is_qty_decimal": 0,
                            "is_virtual": 0,
                            "item_id": 0,
                            "locked_do_invoice": 0,
                            "locked_do_ship": 0,
                            "name": "",
                            "no_discount": 0,
                            "order_id": 0,
                            "original_price": "",
                            "parent_item": "",
                            "parent_item_id": 0,
                            "price": "",
                            "price_incl_tax": "",
                            "product_id": 0,
                            "product_option": { "extension_attributes": {
                                    "bundle_options": [
                                        {
                                            "extension_attributes": {},
                                            "option_id": 0,
                                            "option_qty": 0,
                                            "option_selections": []
                                        }
                                    ],
                                    "configurable_item_options": [
                                        {
                                            "extension_attributes": {},
                                            "option_id": "",
                                            "option_value": 0
                                        }
                                    ],
                                    "custom_options": [
                                        {
                                            "extension_attributes": { "file_info": {
                                                    "base64_encoded_data": "",
                                                    "name": "",
                                                    "type": ""
                                                } },
                                            "option_id": "",
                                            "option_value": ""
                                        }
                                    ],
                                    "downloadable_option": { "downloadable_links": [] },
                                    "giftcard_item_option": {
                                        "custom_giftcard_amount": "",
                                        "extension_attributes": {},
                                        "giftcard_amount": "",
                                        "giftcard_message": "",
                                        "giftcard_recipient_email": "",
                                        "giftcard_recipient_name": "",
                                        "giftcard_sender_email": "",
                                        "giftcard_sender_name": ""
                                    }
                                } },
                            "product_type": "",
                            "qty_backordered": "",
                            "qty_canceled": "",
                            "qty_invoiced": "",
                            "qty_ordered": "",
                            "qty_refunded": "",
                            "qty_returned": "",
                            "qty_shipped": "",
                            "quote_item_id": 0,
                            "row_invoiced": "",
                            "row_total": "",
                            "row_total_incl_tax": "",
                            "row_weight": "",
                            "sku": "",
                            "store_id": 0,
                            "tax_amount": "",
                            "tax_before_discount": "",
                            "tax_canceled": "",
                            "tax_invoiced": "",
                            "tax_percent": "",
                            "tax_refunded": "",
                            "updated_at": "",
                            "weee_tax_applied": "",
                            "weee_tax_applied_amount": "",
                            "weee_tax_applied_row_amount": "",
                            "weee_tax_disposition": "",
                            "weee_tax_row_disposition": "",
                            "weight": ""
                        }
                    ],
                    "shipping": {
                        "address": {},
                        "extension_attributes": {
                            "collection_point": {
                                "city": "",
                                "collection_point_id": "",
                                "country": "",
                                "name": "",
                                "postcode": "",
                                "recipient_address_id": 0,
                                "region": "",
                                "street": []
                            },
                            "ext_order_id": "",
                            "shipping_experience": {
                                "code": "",
                                "cost": "",
                                "label": ""
                            }
                        },
                        "method": "",
                        "total": {
                            "base_shipping_amount": "",
                            "base_shipping_canceled": "",
                            "base_shipping_discount_amount": "",
                            "base_shipping_discount_tax_compensation_amnt": "",
                            "base_shipping_incl_tax": "",
                            "base_shipping_invoiced": "",
                            "base_shipping_refunded": "",
                            "base_shipping_tax_amount": "",
                            "base_shipping_tax_refunded": "",
                            "extension_attributes": {},
                            "shipping_amount": "",
                            "shipping_canceled": "",
                            "shipping_discount_amount": "",
                            "shipping_discount_tax_compensation_amount": "",
                            "shipping_incl_tax": "",
                            "shipping_invoiced": "",
                            "shipping_refunded": "",
                            "shipping_tax_amount": "",
                            "shipping_tax_refunded": ""
                        }
                    },
                    "stock_id": 0
                }
            ]
        },
        "forced_shipment_with_invoice": 0,
        "global_currency_code": "",
        "grand_total": "",
        "hold_before_state": "",
        "hold_before_status": "",
        "increment_id": "",
        "is_virtual": 0,
        "items": [{}],
        "order_currency_code": "",
        "original_increment_id": "",
        "payment": {
            "account_status": "",
            "additional_data": "",
            "additional_information": [],
            "address_status": "",
            "amount_authorized": "",
            "amount_canceled": "",
            "amount_ordered": "",
            "amount_paid": "",
            "amount_refunded": "",
            "anet_trans_method": "",
            "base_amount_authorized": "",
            "base_amount_canceled": "",
            "base_amount_ordered": "",
            "base_amount_paid": "",
            "base_amount_paid_online": "",
            "base_amount_refunded": "",
            "base_amount_refunded_online": "",
            "base_shipping_amount": "",
            "base_shipping_captured": "",
            "base_shipping_refunded": "",
            "cc_approval": "",
            "cc_avs_status": "",
            "cc_cid_status": "",
            "cc_debug_request_body": "",
            "cc_debug_response_body": "",
            "cc_debug_response_serialized": "",
            "cc_exp_month": "",
            "cc_exp_year": "",
            "cc_last4": "",
            "cc_number_enc": "",
            "cc_owner": "",
            "cc_secure_verify": "",
            "cc_ss_issue": "",
            "cc_ss_start_month": "",
            "cc_ss_start_year": "",
            "cc_status": "",
            "cc_status_description": "",
            "cc_trans_id": "",
            "cc_type": "",
            "echeck_account_name": "",
            "echeck_account_type": "",
            "echeck_bank_name": "",
            "echeck_routing_number": "",
            "echeck_type": "",
            "entity_id": 0,
            "extension_attributes": { "vault_payment_token": {
                    "created_at": "",
                    "customer_id": 0,
                    "entity_id": 0,
                    "expires_at": "",
                    "gateway_token": "",
                    "is_active": False,
                    "is_visible": False,
                    "payment_method_code": "",
                    "public_hash": "",
                    "token_details": "",
                    "type": ""
                } },
            "last_trans_id": "",
            "method": "",
            "parent_id": 0,
            "po_number": "",
            "protection_eligibility": "",
            "quote_payment_id": 0,
            "shipping_amount": "",
            "shipping_captured": "",
            "shipping_refunded": ""
        },
        "payment_auth_expiration": 0,
        "payment_authorization_amount": "",
        "protect_code": "",
        "quote_address_id": 0,
        "quote_id": 0,
        "relation_child_id": "",
        "relation_child_real_id": "",
        "relation_parent_id": "",
        "relation_parent_real_id": "",
        "remote_ip": "",
        "shipping_amount": "",
        "shipping_canceled": "",
        "shipping_description": "",
        "shipping_discount_amount": "",
        "shipping_discount_tax_compensation_amount": "",
        "shipping_incl_tax": "",
        "shipping_invoiced": "",
        "shipping_refunded": "",
        "shipping_tax_amount": "",
        "shipping_tax_refunded": "",
        "state": "",
        "status": "",
        "status_histories": [
            {
                "comment": "",
                "created_at": "",
                "entity_id": 0,
                "entity_name": "",
                "extension_attributes": {},
                "is_customer_notified": 0,
                "is_visible_on_front": 0,
                "parent_id": 0,
                "status": ""
            }
        ],
        "store_currency_code": "",
        "store_id": 0,
        "store_name": "",
        "store_to_base_rate": "",
        "store_to_order_rate": "",
        "subtotal": "",
        "subtotal_canceled": "",
        "subtotal_incl_tax": "",
        "subtotal_invoiced": "",
        "subtotal_refunded": "",
        "tax_amount": "",
        "tax_canceled": "",
        "tax_invoiced": "",
        "tax_refunded": "",
        "total_canceled": "",
        "total_due": "",
        "total_invoiced": "",
        "total_item_count": 0,
        "total_offline_refunded": "",
        "total_online_refunded": "",
        "total_paid": "",
        "total_qty_ordered": "",
        "total_refunded": "",
        "updated_at": "",
        "weight": "",
        "x_forwarded_for": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/orders/"

payload <- "{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/orders/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\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/V1/orders/') do |req|
  req.body = "{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/orders/";

    let payload = json!({"entity": json!({
            "adjustment_negative": "",
            "adjustment_positive": "",
            "applied_rule_ids": "",
            "base_adjustment_negative": "",
            "base_adjustment_positive": "",
            "base_currency_code": "",
            "base_discount_amount": "",
            "base_discount_canceled": "",
            "base_discount_invoiced": "",
            "base_discount_refunded": "",
            "base_discount_tax_compensation_amount": "",
            "base_discount_tax_compensation_invoiced": "",
            "base_discount_tax_compensation_refunded": "",
            "base_grand_total": "",
            "base_shipping_amount": "",
            "base_shipping_canceled": "",
            "base_shipping_discount_amount": "",
            "base_shipping_discount_tax_compensation_amnt": "",
            "base_shipping_incl_tax": "",
            "base_shipping_invoiced": "",
            "base_shipping_refunded": "",
            "base_shipping_tax_amount": "",
            "base_shipping_tax_refunded": "",
            "base_subtotal": "",
            "base_subtotal_canceled": "",
            "base_subtotal_incl_tax": "",
            "base_subtotal_invoiced": "",
            "base_subtotal_refunded": "",
            "base_tax_amount": "",
            "base_tax_canceled": "",
            "base_tax_invoiced": "",
            "base_tax_refunded": "",
            "base_to_global_rate": "",
            "base_to_order_rate": "",
            "base_total_canceled": "",
            "base_total_due": "",
            "base_total_invoiced": "",
            "base_total_invoiced_cost": "",
            "base_total_offline_refunded": "",
            "base_total_online_refunded": "",
            "base_total_paid": "",
            "base_total_qty_ordered": "",
            "base_total_refunded": "",
            "billing_address": json!({
                "address_type": "",
                "city": "",
                "company": "",
                "country_id": "",
                "customer_address_id": 0,
                "customer_id": 0,
                "email": "",
                "entity_id": 0,
                "extension_attributes": json!({"checkout_fields": (
                        json!({
                            "attribute_code": "",
                            "value": ""
                        })
                    )}),
                "fax": "",
                "firstname": "",
                "lastname": "",
                "middlename": "",
                "parent_id": 0,
                "postcode": "",
                "prefix": "",
                "region": "",
                "region_code": "",
                "region_id": 0,
                "street": (),
                "suffix": "",
                "telephone": "",
                "vat_id": "",
                "vat_is_valid": 0,
                "vat_request_date": "",
                "vat_request_id": "",
                "vat_request_success": 0
            }),
            "billing_address_id": 0,
            "can_ship_partially": 0,
            "can_ship_partially_item": 0,
            "coupon_code": "",
            "created_at": "",
            "customer_dob": "",
            "customer_email": "",
            "customer_firstname": "",
            "customer_gender": 0,
            "customer_group_id": 0,
            "customer_id": 0,
            "customer_is_guest": 0,
            "customer_lastname": "",
            "customer_middlename": "",
            "customer_note": "",
            "customer_note_notify": 0,
            "customer_prefix": "",
            "customer_suffix": "",
            "customer_taxvat": "",
            "discount_amount": "",
            "discount_canceled": "",
            "discount_description": "",
            "discount_invoiced": "",
            "discount_refunded": "",
            "discount_tax_compensation_amount": "",
            "discount_tax_compensation_invoiced": "",
            "discount_tax_compensation_refunded": "",
            "edit_increment": 0,
            "email_sent": 0,
            "entity_id": 0,
            "ext_customer_id": "",
            "ext_order_id": "",
            "extension_attributes": json!({
                "amazon_order_reference_id": "",
                "applied_taxes": (
                    json!({
                        "amount": "",
                        "base_amount": "",
                        "code": "",
                        "extension_attributes": json!({"rates": (
                                json!({
                                    "code": "",
                                    "extension_attributes": json!({}),
                                    "percent": "",
                                    "title": ""
                                })
                            )}),
                        "percent": "",
                        "title": ""
                    })
                ),
                "base_customer_balance_amount": "",
                "base_customer_balance_invoiced": "",
                "base_customer_balance_refunded": "",
                "base_customer_balance_total_refunded": "",
                "base_gift_cards_amount": "",
                "base_gift_cards_invoiced": "",
                "base_gift_cards_refunded": "",
                "base_reward_currency_amount": "",
                "company_order_attributes": json!({
                    "company_id": 0,
                    "company_name": "",
                    "extension_attributes": json!({}),
                    "order_id": 0
                }),
                "converting_from_quote": false,
                "customer_balance_amount": "",
                "customer_balance_invoiced": "",
                "customer_balance_refunded": "",
                "customer_balance_total_refunded": "",
                "gift_cards": (
                    json!({
                        "amount": "",
                        "base_amount": "",
                        "code": "",
                        "id": 0
                    })
                ),
                "gift_cards_amount": "",
                "gift_cards_invoiced": "",
                "gift_cards_refunded": "",
                "gift_message": json!({
                    "customer_id": 0,
                    "extension_attributes": json!({
                        "entity_id": "",
                        "entity_type": "",
                        "wrapping_add_printed_card": false,
                        "wrapping_allow_gift_receipt": false,
                        "wrapping_id": 0
                    }),
                    "gift_message_id": 0,
                    "message": "",
                    "recipient": "",
                    "sender": ""
                }),
                "gw_add_card": "",
                "gw_allow_gift_receipt": "",
                "gw_base_price": "",
                "gw_base_price_incl_tax": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_card_base_price": "",
                "gw_card_base_price_incl_tax": "",
                "gw_card_base_price_invoiced": "",
                "gw_card_base_price_refunded": "",
                "gw_card_base_tax_amount": "",
                "gw_card_base_tax_invoiced": "",
                "gw_card_base_tax_refunded": "",
                "gw_card_price": "",
                "gw_card_price_incl_tax": "",
                "gw_card_price_invoiced": "",
                "gw_card_price_refunded": "",
                "gw_card_tax_amount": "",
                "gw_card_tax_invoiced": "",
                "gw_card_tax_refunded": "",
                "gw_id": "",
                "gw_items_base_price": "",
                "gw_items_base_price_incl_tax": "",
                "gw_items_base_price_invoiced": "",
                "gw_items_base_price_refunded": "",
                "gw_items_base_tax_amount": "",
                "gw_items_base_tax_invoiced": "",
                "gw_items_base_tax_refunded": "",
                "gw_items_price": "",
                "gw_items_price_incl_tax": "",
                "gw_items_price_invoiced": "",
                "gw_items_price_refunded": "",
                "gw_items_tax_amount": "",
                "gw_items_tax_invoiced": "",
                "gw_items_tax_refunded": "",
                "gw_price": "",
                "gw_price_incl_tax": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "item_applied_taxes": (
                    json!({
                        "applied_taxes": (json!({})),
                        "associated_item_id": 0,
                        "extension_attributes": json!({}),
                        "item_id": 0,
                        "type": ""
                    })
                ),
                "payment_additional_info": (
                    json!({
                        "key": "",
                        "value": ""
                    })
                ),
                "reward_currency_amount": "",
                "reward_points_balance": 0,
                "shipping_assignments": (
                    json!({
                        "extension_attributes": json!({}),
                        "items": (
                            json!({
                                "additional_data": "",
                                "amount_refunded": "",
                                "applied_rule_ids": "",
                                "base_amount_refunded": "",
                                "base_cost": "",
                                "base_discount_amount": "",
                                "base_discount_invoiced": "",
                                "base_discount_refunded": "",
                                "base_discount_tax_compensation_amount": "",
                                "base_discount_tax_compensation_invoiced": "",
                                "base_discount_tax_compensation_refunded": "",
                                "base_original_price": "",
                                "base_price": "",
                                "base_price_incl_tax": "",
                                "base_row_invoiced": "",
                                "base_row_total": "",
                                "base_row_total_incl_tax": "",
                                "base_tax_amount": "",
                                "base_tax_before_discount": "",
                                "base_tax_invoiced": "",
                                "base_tax_refunded": "",
                                "base_weee_tax_applied_amount": "",
                                "base_weee_tax_applied_row_amnt": "",
                                "base_weee_tax_disposition": "",
                                "base_weee_tax_row_disposition": "",
                                "created_at": "",
                                "description": "",
                                "discount_amount": "",
                                "discount_invoiced": "",
                                "discount_percent": "",
                                "discount_refunded": "",
                                "discount_tax_compensation_amount": "",
                                "discount_tax_compensation_canceled": "",
                                "discount_tax_compensation_invoiced": "",
                                "discount_tax_compensation_refunded": "",
                                "event_id": 0,
                                "ext_order_item_id": "",
                                "extension_attributes": json!({
                                    "gift_message": json!({}),
                                    "gw_base_price": "",
                                    "gw_base_price_invoiced": "",
                                    "gw_base_price_refunded": "",
                                    "gw_base_tax_amount": "",
                                    "gw_base_tax_amount_invoiced": "",
                                    "gw_base_tax_amount_refunded": "",
                                    "gw_id": "",
                                    "gw_price": "",
                                    "gw_price_invoiced": "",
                                    "gw_price_refunded": "",
                                    "gw_tax_amount": "",
                                    "gw_tax_amount_invoiced": "",
                                    "gw_tax_amount_refunded": "",
                                    "invoice_text_codes": (),
                                    "tax_codes": (),
                                    "vertex_tax_codes": ()
                                }),
                                "free_shipping": 0,
                                "gw_base_price": "",
                                "gw_base_price_invoiced": "",
                                "gw_base_price_refunded": "",
                                "gw_base_tax_amount": "",
                                "gw_base_tax_amount_invoiced": "",
                                "gw_base_tax_amount_refunded": "",
                                "gw_id": 0,
                                "gw_price": "",
                                "gw_price_invoiced": "",
                                "gw_price_refunded": "",
                                "gw_tax_amount": "",
                                "gw_tax_amount_invoiced": "",
                                "gw_tax_amount_refunded": "",
                                "is_qty_decimal": 0,
                                "is_virtual": 0,
                                "item_id": 0,
                                "locked_do_invoice": 0,
                                "locked_do_ship": 0,
                                "name": "",
                                "no_discount": 0,
                                "order_id": 0,
                                "original_price": "",
                                "parent_item": "",
                                "parent_item_id": 0,
                                "price": "",
                                "price_incl_tax": "",
                                "product_id": 0,
                                "product_option": json!({"extension_attributes": json!({
                                        "bundle_options": (
                                            json!({
                                                "extension_attributes": json!({}),
                                                "option_id": 0,
                                                "option_qty": 0,
                                                "option_selections": ()
                                            })
                                        ),
                                        "configurable_item_options": (
                                            json!({
                                                "extension_attributes": json!({}),
                                                "option_id": "",
                                                "option_value": 0
                                            })
                                        ),
                                        "custom_options": (
                                            json!({
                                                "extension_attributes": json!({"file_info": json!({
                                                        "base64_encoded_data": "",
                                                        "name": "",
                                                        "type": ""
                                                    })}),
                                                "option_id": "",
                                                "option_value": ""
                                            })
                                        ),
                                        "downloadable_option": json!({"downloadable_links": ()}),
                                        "giftcard_item_option": json!({
                                            "custom_giftcard_amount": "",
                                            "extension_attributes": json!({}),
                                            "giftcard_amount": "",
                                            "giftcard_message": "",
                                            "giftcard_recipient_email": "",
                                            "giftcard_recipient_name": "",
                                            "giftcard_sender_email": "",
                                            "giftcard_sender_name": ""
                                        })
                                    })}),
                                "product_type": "",
                                "qty_backordered": "",
                                "qty_canceled": "",
                                "qty_invoiced": "",
                                "qty_ordered": "",
                                "qty_refunded": "",
                                "qty_returned": "",
                                "qty_shipped": "",
                                "quote_item_id": 0,
                                "row_invoiced": "",
                                "row_total": "",
                                "row_total_incl_tax": "",
                                "row_weight": "",
                                "sku": "",
                                "store_id": 0,
                                "tax_amount": "",
                                "tax_before_discount": "",
                                "tax_canceled": "",
                                "tax_invoiced": "",
                                "tax_percent": "",
                                "tax_refunded": "",
                                "updated_at": "",
                                "weee_tax_applied": "",
                                "weee_tax_applied_amount": "",
                                "weee_tax_applied_row_amount": "",
                                "weee_tax_disposition": "",
                                "weee_tax_row_disposition": "",
                                "weight": ""
                            })
                        ),
                        "shipping": json!({
                            "address": json!({}),
                            "extension_attributes": json!({
                                "collection_point": json!({
                                    "city": "",
                                    "collection_point_id": "",
                                    "country": "",
                                    "name": "",
                                    "postcode": "",
                                    "recipient_address_id": 0,
                                    "region": "",
                                    "street": ()
                                }),
                                "ext_order_id": "",
                                "shipping_experience": json!({
                                    "code": "",
                                    "cost": "",
                                    "label": ""
                                })
                            }),
                            "method": "",
                            "total": json!({
                                "base_shipping_amount": "",
                                "base_shipping_canceled": "",
                                "base_shipping_discount_amount": "",
                                "base_shipping_discount_tax_compensation_amnt": "",
                                "base_shipping_incl_tax": "",
                                "base_shipping_invoiced": "",
                                "base_shipping_refunded": "",
                                "base_shipping_tax_amount": "",
                                "base_shipping_tax_refunded": "",
                                "extension_attributes": json!({}),
                                "shipping_amount": "",
                                "shipping_canceled": "",
                                "shipping_discount_amount": "",
                                "shipping_discount_tax_compensation_amount": "",
                                "shipping_incl_tax": "",
                                "shipping_invoiced": "",
                                "shipping_refunded": "",
                                "shipping_tax_amount": "",
                                "shipping_tax_refunded": ""
                            })
                        }),
                        "stock_id": 0
                    })
                )
            }),
            "forced_shipment_with_invoice": 0,
            "global_currency_code": "",
            "grand_total": "",
            "hold_before_state": "",
            "hold_before_status": "",
            "increment_id": "",
            "is_virtual": 0,
            "items": (json!({})),
            "order_currency_code": "",
            "original_increment_id": "",
            "payment": json!({
                "account_status": "",
                "additional_data": "",
                "additional_information": (),
                "address_status": "",
                "amount_authorized": "",
                "amount_canceled": "",
                "amount_ordered": "",
                "amount_paid": "",
                "amount_refunded": "",
                "anet_trans_method": "",
                "base_amount_authorized": "",
                "base_amount_canceled": "",
                "base_amount_ordered": "",
                "base_amount_paid": "",
                "base_amount_paid_online": "",
                "base_amount_refunded": "",
                "base_amount_refunded_online": "",
                "base_shipping_amount": "",
                "base_shipping_captured": "",
                "base_shipping_refunded": "",
                "cc_approval": "",
                "cc_avs_status": "",
                "cc_cid_status": "",
                "cc_debug_request_body": "",
                "cc_debug_response_body": "",
                "cc_debug_response_serialized": "",
                "cc_exp_month": "",
                "cc_exp_year": "",
                "cc_last4": "",
                "cc_number_enc": "",
                "cc_owner": "",
                "cc_secure_verify": "",
                "cc_ss_issue": "",
                "cc_ss_start_month": "",
                "cc_ss_start_year": "",
                "cc_status": "",
                "cc_status_description": "",
                "cc_trans_id": "",
                "cc_type": "",
                "echeck_account_name": "",
                "echeck_account_type": "",
                "echeck_bank_name": "",
                "echeck_routing_number": "",
                "echeck_type": "",
                "entity_id": 0,
                "extension_attributes": json!({"vault_payment_token": json!({
                        "created_at": "",
                        "customer_id": 0,
                        "entity_id": 0,
                        "expires_at": "",
                        "gateway_token": "",
                        "is_active": false,
                        "is_visible": false,
                        "payment_method_code": "",
                        "public_hash": "",
                        "token_details": "",
                        "type": ""
                    })}),
                "last_trans_id": "",
                "method": "",
                "parent_id": 0,
                "po_number": "",
                "protection_eligibility": "",
                "quote_payment_id": 0,
                "shipping_amount": "",
                "shipping_captured": "",
                "shipping_refunded": ""
            }),
            "payment_auth_expiration": 0,
            "payment_authorization_amount": "",
            "protect_code": "",
            "quote_address_id": 0,
            "quote_id": 0,
            "relation_child_id": "",
            "relation_child_real_id": "",
            "relation_parent_id": "",
            "relation_parent_real_id": "",
            "remote_ip": "",
            "shipping_amount": "",
            "shipping_canceled": "",
            "shipping_description": "",
            "shipping_discount_amount": "",
            "shipping_discount_tax_compensation_amount": "",
            "shipping_incl_tax": "",
            "shipping_invoiced": "",
            "shipping_refunded": "",
            "shipping_tax_amount": "",
            "shipping_tax_refunded": "",
            "state": "",
            "status": "",
            "status_histories": (
                json!({
                    "comment": "",
                    "created_at": "",
                    "entity_id": 0,
                    "entity_name": "",
                    "extension_attributes": json!({}),
                    "is_customer_notified": 0,
                    "is_visible_on_front": 0,
                    "parent_id": 0,
                    "status": ""
                })
            ),
            "store_currency_code": "",
            "store_id": 0,
            "store_name": "",
            "store_to_base_rate": "",
            "store_to_order_rate": "",
            "subtotal": "",
            "subtotal_canceled": "",
            "subtotal_incl_tax": "",
            "subtotal_invoiced": "",
            "subtotal_refunded": "",
            "tax_amount": "",
            "tax_canceled": "",
            "tax_invoiced": "",
            "tax_refunded": "",
            "total_canceled": "",
            "total_due": "",
            "total_invoiced": "",
            "total_item_count": 0,
            "total_offline_refunded": "",
            "total_online_refunded": "",
            "total_paid": "",
            "total_qty_ordered": "",
            "total_refunded": "",
            "updated_at": "",
            "weight": "",
            "x_forwarded_for": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/orders/ \
  --header 'content-type: application/json' \
  --data '{
  "entity": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "applied_rule_ids": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_canceled": "",
    "base_discount_invoiced": "",
    "base_discount_refunded": "",
    "base_discount_tax_compensation_amount": "",
    "base_discount_tax_compensation_invoiced": "",
    "base_discount_tax_compensation_refunded": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_canceled": "",
    "base_shipping_discount_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_invoiced": "",
    "base_shipping_refunded": "",
    "base_shipping_tax_amount": "",
    "base_shipping_tax_refunded": "",
    "base_subtotal": "",
    "base_subtotal_canceled": "",
    "base_subtotal_incl_tax": "",
    "base_subtotal_invoiced": "",
    "base_subtotal_refunded": "",
    "base_tax_amount": "",
    "base_tax_canceled": "",
    "base_tax_invoiced": "",
    "base_tax_refunded": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_canceled": "",
    "base_total_due": "",
    "base_total_invoiced": "",
    "base_total_invoiced_cost": "",
    "base_total_offline_refunded": "",
    "base_total_online_refunded": "",
    "base_total_paid": "",
    "base_total_qty_ordered": "",
    "base_total_refunded": "",
    "billing_address": {
      "address_type": "",
      "city": "",
      "company": "",
      "country_id": "",
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "entity_id": 0,
      "extension_attributes": {
        "checkout_fields": [
          {
            "attribute_code": "",
            "value": ""
          }
        ]
      },
      "fax": "",
      "firstname": "",
      "lastname": "",
      "middlename": "",
      "parent_id": 0,
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": "",
      "vat_is_valid": 0,
      "vat_request_date": "",
      "vat_request_id": "",
      "vat_request_success": 0
    },
    "billing_address_id": 0,
    "can_ship_partially": 0,
    "can_ship_partially_item": 0,
    "coupon_code": "",
    "created_at": "",
    "customer_dob": "",
    "customer_email": "",
    "customer_firstname": "",
    "customer_gender": 0,
    "customer_group_id": 0,
    "customer_id": 0,
    "customer_is_guest": 0,
    "customer_lastname": "",
    "customer_middlename": "",
    "customer_note": "",
    "customer_note_notify": 0,
    "customer_prefix": "",
    "customer_suffix": "",
    "customer_taxvat": "",
    "discount_amount": "",
    "discount_canceled": "",
    "discount_description": "",
    "discount_invoiced": "",
    "discount_refunded": "",
    "discount_tax_compensation_amount": "",
    "discount_tax_compensation_invoiced": "",
    "discount_tax_compensation_refunded": "",
    "edit_increment": 0,
    "email_sent": 0,
    "entity_id": 0,
    "ext_customer_id": "",
    "ext_order_id": "",
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "applied_taxes": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "extension_attributes": {
            "rates": [
              {
                "code": "",
                "extension_attributes": {},
                "percent": "",
                "title": ""
              }
            ]
          },
          "percent": "",
          "title": ""
        }
      ],
      "base_customer_balance_amount": "",
      "base_customer_balance_invoiced": "",
      "base_customer_balance_refunded": "",
      "base_customer_balance_total_refunded": "",
      "base_gift_cards_amount": "",
      "base_gift_cards_invoiced": "",
      "base_gift_cards_refunded": "",
      "base_reward_currency_amount": "",
      "company_order_attributes": {
        "company_id": 0,
        "company_name": "",
        "extension_attributes": {},
        "order_id": 0
      },
      "converting_from_quote": false,
      "customer_balance_amount": "",
      "customer_balance_invoiced": "",
      "customer_balance_refunded": "",
      "customer_balance_total_refunded": "",
      "gift_cards": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "id": 0
        }
      ],
      "gift_cards_amount": "",
      "gift_cards_invoiced": "",
      "gift_cards_refunded": "",
      "gift_message": {
        "customer_id": 0,
        "extension_attributes": {
          "entity_id": "",
          "entity_type": "",
          "wrapping_add_printed_card": false,
          "wrapping_allow_gift_receipt": false,
          "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
      },
      "gw_add_card": "",
      "gw_allow_gift_receipt": "",
      "gw_base_price": "",
      "gw_base_price_incl_tax": "",
      "gw_base_price_invoiced": "",
      "gw_base_price_refunded": "",
      "gw_base_tax_amount": "",
      "gw_base_tax_amount_invoiced": "",
      "gw_base_tax_amount_refunded": "",
      "gw_card_base_price": "",
      "gw_card_base_price_incl_tax": "",
      "gw_card_base_price_invoiced": "",
      "gw_card_base_price_refunded": "",
      "gw_card_base_tax_amount": "",
      "gw_card_base_tax_invoiced": "",
      "gw_card_base_tax_refunded": "",
      "gw_card_price": "",
      "gw_card_price_incl_tax": "",
      "gw_card_price_invoiced": "",
      "gw_card_price_refunded": "",
      "gw_card_tax_amount": "",
      "gw_card_tax_invoiced": "",
      "gw_card_tax_refunded": "",
      "gw_id": "",
      "gw_items_base_price": "",
      "gw_items_base_price_incl_tax": "",
      "gw_items_base_price_invoiced": "",
      "gw_items_base_price_refunded": "",
      "gw_items_base_tax_amount": "",
      "gw_items_base_tax_invoiced": "",
      "gw_items_base_tax_refunded": "",
      "gw_items_price": "",
      "gw_items_price_incl_tax": "",
      "gw_items_price_invoiced": "",
      "gw_items_price_refunded": "",
      "gw_items_tax_amount": "",
      "gw_items_tax_invoiced": "",
      "gw_items_tax_refunded": "",
      "gw_price": "",
      "gw_price_incl_tax": "",
      "gw_price_invoiced": "",
      "gw_price_refunded": "",
      "gw_tax_amount": "",
      "gw_tax_amount_invoiced": "",
      "gw_tax_amount_refunded": "",
      "item_applied_taxes": [
        {
          "applied_taxes": [
            {}
          ],
          "associated_item_id": 0,
          "extension_attributes": {},
          "item_id": 0,
          "type": ""
        }
      ],
      "payment_additional_info": [
        {
          "key": "",
          "value": ""
        }
      ],
      "reward_currency_amount": "",
      "reward_points_balance": 0,
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "additional_data": "",
              "amount_refunded": "",
              "applied_rule_ids": "",
              "base_amount_refunded": "",
              "base_cost": "",
              "base_discount_amount": "",
              "base_discount_invoiced": "",
              "base_discount_refunded": "",
              "base_discount_tax_compensation_amount": "",
              "base_discount_tax_compensation_invoiced": "",
              "base_discount_tax_compensation_refunded": "",
              "base_original_price": "",
              "base_price": "",
              "base_price_incl_tax": "",
              "base_row_invoiced": "",
              "base_row_total": "",
              "base_row_total_incl_tax": "",
              "base_tax_amount": "",
              "base_tax_before_discount": "",
              "base_tax_invoiced": "",
              "base_tax_refunded": "",
              "base_weee_tax_applied_amount": "",
              "base_weee_tax_applied_row_amnt": "",
              "base_weee_tax_disposition": "",
              "base_weee_tax_row_disposition": "",
              "created_at": "",
              "description": "",
              "discount_amount": "",
              "discount_invoiced": "",
              "discount_percent": "",
              "discount_refunded": "",
              "discount_tax_compensation_amount": "",
              "discount_tax_compensation_canceled": "",
              "discount_tax_compensation_invoiced": "",
              "discount_tax_compensation_refunded": "",
              "event_id": 0,
              "ext_order_item_id": "",
              "extension_attributes": {
                "gift_message": {},
                "gw_base_price": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_id": "",
                "gw_price": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "invoice_text_codes": [],
                "tax_codes": [],
                "vertex_tax_codes": []
              },
              "free_shipping": 0,
              "gw_base_price": "",
              "gw_base_price_invoiced": "",
              "gw_base_price_refunded": "",
              "gw_base_tax_amount": "",
              "gw_base_tax_amount_invoiced": "",
              "gw_base_tax_amount_refunded": "",
              "gw_id": 0,
              "gw_price": "",
              "gw_price_invoiced": "",
              "gw_price_refunded": "",
              "gw_tax_amount": "",
              "gw_tax_amount_invoiced": "",
              "gw_tax_amount_refunded": "",
              "is_qty_decimal": 0,
              "is_virtual": 0,
              "item_id": 0,
              "locked_do_invoice": 0,
              "locked_do_ship": 0,
              "name": "",
              "no_discount": 0,
              "order_id": 0,
              "original_price": "",
              "parent_item": "",
              "parent_item_id": 0,
              "price": "",
              "price_incl_tax": "",
              "product_id": 0,
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty_backordered": "",
              "qty_canceled": "",
              "qty_invoiced": "",
              "qty_ordered": "",
              "qty_refunded": "",
              "qty_returned": "",
              "qty_shipped": "",
              "quote_item_id": 0,
              "row_invoiced": "",
              "row_total": "",
              "row_total_incl_tax": "",
              "row_weight": "",
              "sku": "",
              "store_id": 0,
              "tax_amount": "",
              "tax_before_discount": "",
              "tax_canceled": "",
              "tax_invoiced": "",
              "tax_percent": "",
              "tax_refunded": "",
              "updated_at": "",
              "weee_tax_applied": "",
              "weee_tax_applied_amount": "",
              "weee_tax_applied_row_amount": "",
              "weee_tax_disposition": "",
              "weee_tax_row_disposition": "",
              "weight": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {
              "collection_point": {
                "city": "",
                "collection_point_id": "",
                "country": "",
                "name": "",
                "postcode": "",
                "recipient_address_id": 0,
                "region": "",
                "street": []
              },
              "ext_order_id": "",
              "shipping_experience": {
                "code": "",
                "cost": "",
                "label": ""
              }
            },
            "method": "",
            "total": {
              "base_shipping_amount": "",
              "base_shipping_canceled": "",
              "base_shipping_discount_amount": "",
              "base_shipping_discount_tax_compensation_amnt": "",
              "base_shipping_incl_tax": "",
              "base_shipping_invoiced": "",
              "base_shipping_refunded": "",
              "base_shipping_tax_amount": "",
              "base_shipping_tax_refunded": "",
              "extension_attributes": {},
              "shipping_amount": "",
              "shipping_canceled": "",
              "shipping_discount_amount": "",
              "shipping_discount_tax_compensation_amount": "",
              "shipping_incl_tax": "",
              "shipping_invoiced": "",
              "shipping_refunded": "",
              "shipping_tax_amount": "",
              "shipping_tax_refunded": ""
            }
          },
          "stock_id": 0
        }
      ]
    },
    "forced_shipment_with_invoice": 0,
    "global_currency_code": "",
    "grand_total": "",
    "hold_before_state": "",
    "hold_before_status": "",
    "increment_id": "",
    "is_virtual": 0,
    "items": [
      {}
    ],
    "order_currency_code": "",
    "original_increment_id": "",
    "payment": {
      "account_status": "",
      "additional_data": "",
      "additional_information": [],
      "address_status": "",
      "amount_authorized": "",
      "amount_canceled": "",
      "amount_ordered": "",
      "amount_paid": "",
      "amount_refunded": "",
      "anet_trans_method": "",
      "base_amount_authorized": "",
      "base_amount_canceled": "",
      "base_amount_ordered": "",
      "base_amount_paid": "",
      "base_amount_paid_online": "",
      "base_amount_refunded": "",
      "base_amount_refunded_online": "",
      "base_shipping_amount": "",
      "base_shipping_captured": "",
      "base_shipping_refunded": "",
      "cc_approval": "",
      "cc_avs_status": "",
      "cc_cid_status": "",
      "cc_debug_request_body": "",
      "cc_debug_response_body": "",
      "cc_debug_response_serialized": "",
      "cc_exp_month": "",
      "cc_exp_year": "",
      "cc_last4": "",
      "cc_number_enc": "",
      "cc_owner": "",
      "cc_secure_verify": "",
      "cc_ss_issue": "",
      "cc_ss_start_month": "",
      "cc_ss_start_year": "",
      "cc_status": "",
      "cc_status_description": "",
      "cc_trans_id": "",
      "cc_type": "",
      "echeck_account_name": "",
      "echeck_account_type": "",
      "echeck_bank_name": "",
      "echeck_routing_number": "",
      "echeck_type": "",
      "entity_id": 0,
      "extension_attributes": {
        "vault_payment_token": {
          "created_at": "",
          "customer_id": 0,
          "entity_id": 0,
          "expires_at": "",
          "gateway_token": "",
          "is_active": false,
          "is_visible": false,
          "payment_method_code": "",
          "public_hash": "",
          "token_details": "",
          "type": ""
        }
      },
      "last_trans_id": "",
      "method": "",
      "parent_id": 0,
      "po_number": "",
      "protection_eligibility": "",
      "quote_payment_id": 0,
      "shipping_amount": "",
      "shipping_captured": "",
      "shipping_refunded": ""
    },
    "payment_auth_expiration": 0,
    "payment_authorization_amount": "",
    "protect_code": "",
    "quote_address_id": 0,
    "quote_id": 0,
    "relation_child_id": "",
    "relation_child_real_id": "",
    "relation_parent_id": "",
    "relation_parent_real_id": "",
    "remote_ip": "",
    "shipping_amount": "",
    "shipping_canceled": "",
    "shipping_description": "",
    "shipping_discount_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_invoiced": "",
    "shipping_refunded": "",
    "shipping_tax_amount": "",
    "shipping_tax_refunded": "",
    "state": "",
    "status": "",
    "status_histories": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "entity_name": "",
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0,
        "status": ""
      }
    ],
    "store_currency_code": "",
    "store_id": 0,
    "store_name": "",
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_canceled": "",
    "subtotal_incl_tax": "",
    "subtotal_invoiced": "",
    "subtotal_refunded": "",
    "tax_amount": "",
    "tax_canceled": "",
    "tax_invoiced": "",
    "tax_refunded": "",
    "total_canceled": "",
    "total_due": "",
    "total_invoiced": "",
    "total_item_count": 0,
    "total_offline_refunded": "",
    "total_online_refunded": "",
    "total_paid": "",
    "total_qty_ordered": "",
    "total_refunded": "",
    "updated_at": "",
    "weight": "",
    "x_forwarded_for": ""
  }
}'
echo '{
  "entity": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "applied_rule_ids": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_canceled": "",
    "base_discount_invoiced": "",
    "base_discount_refunded": "",
    "base_discount_tax_compensation_amount": "",
    "base_discount_tax_compensation_invoiced": "",
    "base_discount_tax_compensation_refunded": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_canceled": "",
    "base_shipping_discount_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_invoiced": "",
    "base_shipping_refunded": "",
    "base_shipping_tax_amount": "",
    "base_shipping_tax_refunded": "",
    "base_subtotal": "",
    "base_subtotal_canceled": "",
    "base_subtotal_incl_tax": "",
    "base_subtotal_invoiced": "",
    "base_subtotal_refunded": "",
    "base_tax_amount": "",
    "base_tax_canceled": "",
    "base_tax_invoiced": "",
    "base_tax_refunded": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_canceled": "",
    "base_total_due": "",
    "base_total_invoiced": "",
    "base_total_invoiced_cost": "",
    "base_total_offline_refunded": "",
    "base_total_online_refunded": "",
    "base_total_paid": "",
    "base_total_qty_ordered": "",
    "base_total_refunded": "",
    "billing_address": {
      "address_type": "",
      "city": "",
      "company": "",
      "country_id": "",
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "entity_id": 0,
      "extension_attributes": {
        "checkout_fields": [
          {
            "attribute_code": "",
            "value": ""
          }
        ]
      },
      "fax": "",
      "firstname": "",
      "lastname": "",
      "middlename": "",
      "parent_id": 0,
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": "",
      "vat_is_valid": 0,
      "vat_request_date": "",
      "vat_request_id": "",
      "vat_request_success": 0
    },
    "billing_address_id": 0,
    "can_ship_partially": 0,
    "can_ship_partially_item": 0,
    "coupon_code": "",
    "created_at": "",
    "customer_dob": "",
    "customer_email": "",
    "customer_firstname": "",
    "customer_gender": 0,
    "customer_group_id": 0,
    "customer_id": 0,
    "customer_is_guest": 0,
    "customer_lastname": "",
    "customer_middlename": "",
    "customer_note": "",
    "customer_note_notify": 0,
    "customer_prefix": "",
    "customer_suffix": "",
    "customer_taxvat": "",
    "discount_amount": "",
    "discount_canceled": "",
    "discount_description": "",
    "discount_invoiced": "",
    "discount_refunded": "",
    "discount_tax_compensation_amount": "",
    "discount_tax_compensation_invoiced": "",
    "discount_tax_compensation_refunded": "",
    "edit_increment": 0,
    "email_sent": 0,
    "entity_id": 0,
    "ext_customer_id": "",
    "ext_order_id": "",
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "applied_taxes": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "extension_attributes": {
            "rates": [
              {
                "code": "",
                "extension_attributes": {},
                "percent": "",
                "title": ""
              }
            ]
          },
          "percent": "",
          "title": ""
        }
      ],
      "base_customer_balance_amount": "",
      "base_customer_balance_invoiced": "",
      "base_customer_balance_refunded": "",
      "base_customer_balance_total_refunded": "",
      "base_gift_cards_amount": "",
      "base_gift_cards_invoiced": "",
      "base_gift_cards_refunded": "",
      "base_reward_currency_amount": "",
      "company_order_attributes": {
        "company_id": 0,
        "company_name": "",
        "extension_attributes": {},
        "order_id": 0
      },
      "converting_from_quote": false,
      "customer_balance_amount": "",
      "customer_balance_invoiced": "",
      "customer_balance_refunded": "",
      "customer_balance_total_refunded": "",
      "gift_cards": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "id": 0
        }
      ],
      "gift_cards_amount": "",
      "gift_cards_invoiced": "",
      "gift_cards_refunded": "",
      "gift_message": {
        "customer_id": 0,
        "extension_attributes": {
          "entity_id": "",
          "entity_type": "",
          "wrapping_add_printed_card": false,
          "wrapping_allow_gift_receipt": false,
          "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
      },
      "gw_add_card": "",
      "gw_allow_gift_receipt": "",
      "gw_base_price": "",
      "gw_base_price_incl_tax": "",
      "gw_base_price_invoiced": "",
      "gw_base_price_refunded": "",
      "gw_base_tax_amount": "",
      "gw_base_tax_amount_invoiced": "",
      "gw_base_tax_amount_refunded": "",
      "gw_card_base_price": "",
      "gw_card_base_price_incl_tax": "",
      "gw_card_base_price_invoiced": "",
      "gw_card_base_price_refunded": "",
      "gw_card_base_tax_amount": "",
      "gw_card_base_tax_invoiced": "",
      "gw_card_base_tax_refunded": "",
      "gw_card_price": "",
      "gw_card_price_incl_tax": "",
      "gw_card_price_invoiced": "",
      "gw_card_price_refunded": "",
      "gw_card_tax_amount": "",
      "gw_card_tax_invoiced": "",
      "gw_card_tax_refunded": "",
      "gw_id": "",
      "gw_items_base_price": "",
      "gw_items_base_price_incl_tax": "",
      "gw_items_base_price_invoiced": "",
      "gw_items_base_price_refunded": "",
      "gw_items_base_tax_amount": "",
      "gw_items_base_tax_invoiced": "",
      "gw_items_base_tax_refunded": "",
      "gw_items_price": "",
      "gw_items_price_incl_tax": "",
      "gw_items_price_invoiced": "",
      "gw_items_price_refunded": "",
      "gw_items_tax_amount": "",
      "gw_items_tax_invoiced": "",
      "gw_items_tax_refunded": "",
      "gw_price": "",
      "gw_price_incl_tax": "",
      "gw_price_invoiced": "",
      "gw_price_refunded": "",
      "gw_tax_amount": "",
      "gw_tax_amount_invoiced": "",
      "gw_tax_amount_refunded": "",
      "item_applied_taxes": [
        {
          "applied_taxes": [
            {}
          ],
          "associated_item_id": 0,
          "extension_attributes": {},
          "item_id": 0,
          "type": ""
        }
      ],
      "payment_additional_info": [
        {
          "key": "",
          "value": ""
        }
      ],
      "reward_currency_amount": "",
      "reward_points_balance": 0,
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "additional_data": "",
              "amount_refunded": "",
              "applied_rule_ids": "",
              "base_amount_refunded": "",
              "base_cost": "",
              "base_discount_amount": "",
              "base_discount_invoiced": "",
              "base_discount_refunded": "",
              "base_discount_tax_compensation_amount": "",
              "base_discount_tax_compensation_invoiced": "",
              "base_discount_tax_compensation_refunded": "",
              "base_original_price": "",
              "base_price": "",
              "base_price_incl_tax": "",
              "base_row_invoiced": "",
              "base_row_total": "",
              "base_row_total_incl_tax": "",
              "base_tax_amount": "",
              "base_tax_before_discount": "",
              "base_tax_invoiced": "",
              "base_tax_refunded": "",
              "base_weee_tax_applied_amount": "",
              "base_weee_tax_applied_row_amnt": "",
              "base_weee_tax_disposition": "",
              "base_weee_tax_row_disposition": "",
              "created_at": "",
              "description": "",
              "discount_amount": "",
              "discount_invoiced": "",
              "discount_percent": "",
              "discount_refunded": "",
              "discount_tax_compensation_amount": "",
              "discount_tax_compensation_canceled": "",
              "discount_tax_compensation_invoiced": "",
              "discount_tax_compensation_refunded": "",
              "event_id": 0,
              "ext_order_item_id": "",
              "extension_attributes": {
                "gift_message": {},
                "gw_base_price": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_id": "",
                "gw_price": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "invoice_text_codes": [],
                "tax_codes": [],
                "vertex_tax_codes": []
              },
              "free_shipping": 0,
              "gw_base_price": "",
              "gw_base_price_invoiced": "",
              "gw_base_price_refunded": "",
              "gw_base_tax_amount": "",
              "gw_base_tax_amount_invoiced": "",
              "gw_base_tax_amount_refunded": "",
              "gw_id": 0,
              "gw_price": "",
              "gw_price_invoiced": "",
              "gw_price_refunded": "",
              "gw_tax_amount": "",
              "gw_tax_amount_invoiced": "",
              "gw_tax_amount_refunded": "",
              "is_qty_decimal": 0,
              "is_virtual": 0,
              "item_id": 0,
              "locked_do_invoice": 0,
              "locked_do_ship": 0,
              "name": "",
              "no_discount": 0,
              "order_id": 0,
              "original_price": "",
              "parent_item": "",
              "parent_item_id": 0,
              "price": "",
              "price_incl_tax": "",
              "product_id": 0,
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty_backordered": "",
              "qty_canceled": "",
              "qty_invoiced": "",
              "qty_ordered": "",
              "qty_refunded": "",
              "qty_returned": "",
              "qty_shipped": "",
              "quote_item_id": 0,
              "row_invoiced": "",
              "row_total": "",
              "row_total_incl_tax": "",
              "row_weight": "",
              "sku": "",
              "store_id": 0,
              "tax_amount": "",
              "tax_before_discount": "",
              "tax_canceled": "",
              "tax_invoiced": "",
              "tax_percent": "",
              "tax_refunded": "",
              "updated_at": "",
              "weee_tax_applied": "",
              "weee_tax_applied_amount": "",
              "weee_tax_applied_row_amount": "",
              "weee_tax_disposition": "",
              "weee_tax_row_disposition": "",
              "weight": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {
              "collection_point": {
                "city": "",
                "collection_point_id": "",
                "country": "",
                "name": "",
                "postcode": "",
                "recipient_address_id": 0,
                "region": "",
                "street": []
              },
              "ext_order_id": "",
              "shipping_experience": {
                "code": "",
                "cost": "",
                "label": ""
              }
            },
            "method": "",
            "total": {
              "base_shipping_amount": "",
              "base_shipping_canceled": "",
              "base_shipping_discount_amount": "",
              "base_shipping_discount_tax_compensation_amnt": "",
              "base_shipping_incl_tax": "",
              "base_shipping_invoiced": "",
              "base_shipping_refunded": "",
              "base_shipping_tax_amount": "",
              "base_shipping_tax_refunded": "",
              "extension_attributes": {},
              "shipping_amount": "",
              "shipping_canceled": "",
              "shipping_discount_amount": "",
              "shipping_discount_tax_compensation_amount": "",
              "shipping_incl_tax": "",
              "shipping_invoiced": "",
              "shipping_refunded": "",
              "shipping_tax_amount": "",
              "shipping_tax_refunded": ""
            }
          },
          "stock_id": 0
        }
      ]
    },
    "forced_shipment_with_invoice": 0,
    "global_currency_code": "",
    "grand_total": "",
    "hold_before_state": "",
    "hold_before_status": "",
    "increment_id": "",
    "is_virtual": 0,
    "items": [
      {}
    ],
    "order_currency_code": "",
    "original_increment_id": "",
    "payment": {
      "account_status": "",
      "additional_data": "",
      "additional_information": [],
      "address_status": "",
      "amount_authorized": "",
      "amount_canceled": "",
      "amount_ordered": "",
      "amount_paid": "",
      "amount_refunded": "",
      "anet_trans_method": "",
      "base_amount_authorized": "",
      "base_amount_canceled": "",
      "base_amount_ordered": "",
      "base_amount_paid": "",
      "base_amount_paid_online": "",
      "base_amount_refunded": "",
      "base_amount_refunded_online": "",
      "base_shipping_amount": "",
      "base_shipping_captured": "",
      "base_shipping_refunded": "",
      "cc_approval": "",
      "cc_avs_status": "",
      "cc_cid_status": "",
      "cc_debug_request_body": "",
      "cc_debug_response_body": "",
      "cc_debug_response_serialized": "",
      "cc_exp_month": "",
      "cc_exp_year": "",
      "cc_last4": "",
      "cc_number_enc": "",
      "cc_owner": "",
      "cc_secure_verify": "",
      "cc_ss_issue": "",
      "cc_ss_start_month": "",
      "cc_ss_start_year": "",
      "cc_status": "",
      "cc_status_description": "",
      "cc_trans_id": "",
      "cc_type": "",
      "echeck_account_name": "",
      "echeck_account_type": "",
      "echeck_bank_name": "",
      "echeck_routing_number": "",
      "echeck_type": "",
      "entity_id": 0,
      "extension_attributes": {
        "vault_payment_token": {
          "created_at": "",
          "customer_id": 0,
          "entity_id": 0,
          "expires_at": "",
          "gateway_token": "",
          "is_active": false,
          "is_visible": false,
          "payment_method_code": "",
          "public_hash": "",
          "token_details": "",
          "type": ""
        }
      },
      "last_trans_id": "",
      "method": "",
      "parent_id": 0,
      "po_number": "",
      "protection_eligibility": "",
      "quote_payment_id": 0,
      "shipping_amount": "",
      "shipping_captured": "",
      "shipping_refunded": ""
    },
    "payment_auth_expiration": 0,
    "payment_authorization_amount": "",
    "protect_code": "",
    "quote_address_id": 0,
    "quote_id": 0,
    "relation_child_id": "",
    "relation_child_real_id": "",
    "relation_parent_id": "",
    "relation_parent_real_id": "",
    "remote_ip": "",
    "shipping_amount": "",
    "shipping_canceled": "",
    "shipping_description": "",
    "shipping_discount_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_invoiced": "",
    "shipping_refunded": "",
    "shipping_tax_amount": "",
    "shipping_tax_refunded": "",
    "state": "",
    "status": "",
    "status_histories": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "entity_name": "",
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0,
        "status": ""
      }
    ],
    "store_currency_code": "",
    "store_id": 0,
    "store_name": "",
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_canceled": "",
    "subtotal_incl_tax": "",
    "subtotal_invoiced": "",
    "subtotal_refunded": "",
    "tax_amount": "",
    "tax_canceled": "",
    "tax_invoiced": "",
    "tax_refunded": "",
    "total_canceled": "",
    "total_due": "",
    "total_invoiced": "",
    "total_item_count": 0,
    "total_offline_refunded": "",
    "total_online_refunded": "",
    "total_paid": "",
    "total_qty_ordered": "",
    "total_refunded": "",
    "updated_at": "",
    "weight": "",
    "x_forwarded_for": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/orders/ \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "entity": {\n    "adjustment_negative": "",\n    "adjustment_positive": "",\n    "applied_rule_ids": "",\n    "base_adjustment_negative": "",\n    "base_adjustment_positive": "",\n    "base_currency_code": "",\n    "base_discount_amount": "",\n    "base_discount_canceled": "",\n    "base_discount_invoiced": "",\n    "base_discount_refunded": "",\n    "base_discount_tax_compensation_amount": "",\n    "base_discount_tax_compensation_invoiced": "",\n    "base_discount_tax_compensation_refunded": "",\n    "base_grand_total": "",\n    "base_shipping_amount": "",\n    "base_shipping_canceled": "",\n    "base_shipping_discount_amount": "",\n    "base_shipping_discount_tax_compensation_amnt": "",\n    "base_shipping_incl_tax": "",\n    "base_shipping_invoiced": "",\n    "base_shipping_refunded": "",\n    "base_shipping_tax_amount": "",\n    "base_shipping_tax_refunded": "",\n    "base_subtotal": "",\n    "base_subtotal_canceled": "",\n    "base_subtotal_incl_tax": "",\n    "base_subtotal_invoiced": "",\n    "base_subtotal_refunded": "",\n    "base_tax_amount": "",\n    "base_tax_canceled": "",\n    "base_tax_invoiced": "",\n    "base_tax_refunded": "",\n    "base_to_global_rate": "",\n    "base_to_order_rate": "",\n    "base_total_canceled": "",\n    "base_total_due": "",\n    "base_total_invoiced": "",\n    "base_total_invoiced_cost": "",\n    "base_total_offline_refunded": "",\n    "base_total_online_refunded": "",\n    "base_total_paid": "",\n    "base_total_qty_ordered": "",\n    "base_total_refunded": "",\n    "billing_address": {\n      "address_type": "",\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "entity_id": 0,\n      "extension_attributes": {\n        "checkout_fields": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ]\n      },\n      "fax": "",\n      "firstname": "",\n      "lastname": "",\n      "middlename": "",\n      "parent_id": 0,\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": "",\n      "vat_is_valid": 0,\n      "vat_request_date": "",\n      "vat_request_id": "",\n      "vat_request_success": 0\n    },\n    "billing_address_id": 0,\n    "can_ship_partially": 0,\n    "can_ship_partially_item": 0,\n    "coupon_code": "",\n    "created_at": "",\n    "customer_dob": "",\n    "customer_email": "",\n    "customer_firstname": "",\n    "customer_gender": 0,\n    "customer_group_id": 0,\n    "customer_id": 0,\n    "customer_is_guest": 0,\n    "customer_lastname": "",\n    "customer_middlename": "",\n    "customer_note": "",\n    "customer_note_notify": 0,\n    "customer_prefix": "",\n    "customer_suffix": "",\n    "customer_taxvat": "",\n    "discount_amount": "",\n    "discount_canceled": "",\n    "discount_description": "",\n    "discount_invoiced": "",\n    "discount_refunded": "",\n    "discount_tax_compensation_amount": "",\n    "discount_tax_compensation_invoiced": "",\n    "discount_tax_compensation_refunded": "",\n    "edit_increment": 0,\n    "email_sent": 0,\n    "entity_id": 0,\n    "ext_customer_id": "",\n    "ext_order_id": "",\n    "extension_attributes": {\n      "amazon_order_reference_id": "",\n      "applied_taxes": [\n        {\n          "amount": "",\n          "base_amount": "",\n          "code": "",\n          "extension_attributes": {\n            "rates": [\n              {\n                "code": "",\n                "extension_attributes": {},\n                "percent": "",\n                "title": ""\n              }\n            ]\n          },\n          "percent": "",\n          "title": ""\n        }\n      ],\n      "base_customer_balance_amount": "",\n      "base_customer_balance_invoiced": "",\n      "base_customer_balance_refunded": "",\n      "base_customer_balance_total_refunded": "",\n      "base_gift_cards_amount": "",\n      "base_gift_cards_invoiced": "",\n      "base_gift_cards_refunded": "",\n      "base_reward_currency_amount": "",\n      "company_order_attributes": {\n        "company_id": 0,\n        "company_name": "",\n        "extension_attributes": {},\n        "order_id": 0\n      },\n      "converting_from_quote": false,\n      "customer_balance_amount": "",\n      "customer_balance_invoiced": "",\n      "customer_balance_refunded": "",\n      "customer_balance_total_refunded": "",\n      "gift_cards": [\n        {\n          "amount": "",\n          "base_amount": "",\n          "code": "",\n          "id": 0\n        }\n      ],\n      "gift_cards_amount": "",\n      "gift_cards_invoiced": "",\n      "gift_cards_refunded": "",\n      "gift_message": {\n        "customer_id": 0,\n        "extension_attributes": {\n          "entity_id": "",\n          "entity_type": "",\n          "wrapping_add_printed_card": false,\n          "wrapping_allow_gift_receipt": false,\n          "wrapping_id": 0\n        },\n        "gift_message_id": 0,\n        "message": "",\n        "recipient": "",\n        "sender": ""\n      },\n      "gw_add_card": "",\n      "gw_allow_gift_receipt": "",\n      "gw_base_price": "",\n      "gw_base_price_incl_tax": "",\n      "gw_base_price_invoiced": "",\n      "gw_base_price_refunded": "",\n      "gw_base_tax_amount": "",\n      "gw_base_tax_amount_invoiced": "",\n      "gw_base_tax_amount_refunded": "",\n      "gw_card_base_price": "",\n      "gw_card_base_price_incl_tax": "",\n      "gw_card_base_price_invoiced": "",\n      "gw_card_base_price_refunded": "",\n      "gw_card_base_tax_amount": "",\n      "gw_card_base_tax_invoiced": "",\n      "gw_card_base_tax_refunded": "",\n      "gw_card_price": "",\n      "gw_card_price_incl_tax": "",\n      "gw_card_price_invoiced": "",\n      "gw_card_price_refunded": "",\n      "gw_card_tax_amount": "",\n      "gw_card_tax_invoiced": "",\n      "gw_card_tax_refunded": "",\n      "gw_id": "",\n      "gw_items_base_price": "",\n      "gw_items_base_price_incl_tax": "",\n      "gw_items_base_price_invoiced": "",\n      "gw_items_base_price_refunded": "",\n      "gw_items_base_tax_amount": "",\n      "gw_items_base_tax_invoiced": "",\n      "gw_items_base_tax_refunded": "",\n      "gw_items_price": "",\n      "gw_items_price_incl_tax": "",\n      "gw_items_price_invoiced": "",\n      "gw_items_price_refunded": "",\n      "gw_items_tax_amount": "",\n      "gw_items_tax_invoiced": "",\n      "gw_items_tax_refunded": "",\n      "gw_price": "",\n      "gw_price_incl_tax": "",\n      "gw_price_invoiced": "",\n      "gw_price_refunded": "",\n      "gw_tax_amount": "",\n      "gw_tax_amount_invoiced": "",\n      "gw_tax_amount_refunded": "",\n      "item_applied_taxes": [\n        {\n          "applied_taxes": [\n            {}\n          ],\n          "associated_item_id": 0,\n          "extension_attributes": {},\n          "item_id": 0,\n          "type": ""\n        }\n      ],\n      "payment_additional_info": [\n        {\n          "key": "",\n          "value": ""\n        }\n      ],\n      "reward_currency_amount": "",\n      "reward_points_balance": 0,\n      "shipping_assignments": [\n        {\n          "extension_attributes": {},\n          "items": [\n            {\n              "additional_data": "",\n              "amount_refunded": "",\n              "applied_rule_ids": "",\n              "base_amount_refunded": "",\n              "base_cost": "",\n              "base_discount_amount": "",\n              "base_discount_invoiced": "",\n              "base_discount_refunded": "",\n              "base_discount_tax_compensation_amount": "",\n              "base_discount_tax_compensation_invoiced": "",\n              "base_discount_tax_compensation_refunded": "",\n              "base_original_price": "",\n              "base_price": "",\n              "base_price_incl_tax": "",\n              "base_row_invoiced": "",\n              "base_row_total": "",\n              "base_row_total_incl_tax": "",\n              "base_tax_amount": "",\n              "base_tax_before_discount": "",\n              "base_tax_invoiced": "",\n              "base_tax_refunded": "",\n              "base_weee_tax_applied_amount": "",\n              "base_weee_tax_applied_row_amnt": "",\n              "base_weee_tax_disposition": "",\n              "base_weee_tax_row_disposition": "",\n              "created_at": "",\n              "description": "",\n              "discount_amount": "",\n              "discount_invoiced": "",\n              "discount_percent": "",\n              "discount_refunded": "",\n              "discount_tax_compensation_amount": "",\n              "discount_tax_compensation_canceled": "",\n              "discount_tax_compensation_invoiced": "",\n              "discount_tax_compensation_refunded": "",\n              "event_id": 0,\n              "ext_order_item_id": "",\n              "extension_attributes": {\n                "gift_message": {},\n                "gw_base_price": "",\n                "gw_base_price_invoiced": "",\n                "gw_base_price_refunded": "",\n                "gw_base_tax_amount": "",\n                "gw_base_tax_amount_invoiced": "",\n                "gw_base_tax_amount_refunded": "",\n                "gw_id": "",\n                "gw_price": "",\n                "gw_price_invoiced": "",\n                "gw_price_refunded": "",\n                "gw_tax_amount": "",\n                "gw_tax_amount_invoiced": "",\n                "gw_tax_amount_refunded": "",\n                "invoice_text_codes": [],\n                "tax_codes": [],\n                "vertex_tax_codes": []\n              },\n              "free_shipping": 0,\n              "gw_base_price": "",\n              "gw_base_price_invoiced": "",\n              "gw_base_price_refunded": "",\n              "gw_base_tax_amount": "",\n              "gw_base_tax_amount_invoiced": "",\n              "gw_base_tax_amount_refunded": "",\n              "gw_id": 0,\n              "gw_price": "",\n              "gw_price_invoiced": "",\n              "gw_price_refunded": "",\n              "gw_tax_amount": "",\n              "gw_tax_amount_invoiced": "",\n              "gw_tax_amount_refunded": "",\n              "is_qty_decimal": 0,\n              "is_virtual": 0,\n              "item_id": 0,\n              "locked_do_invoice": 0,\n              "locked_do_ship": 0,\n              "name": "",\n              "no_discount": 0,\n              "order_id": 0,\n              "original_price": "",\n              "parent_item": "",\n              "parent_item_id": 0,\n              "price": "",\n              "price_incl_tax": "",\n              "product_id": 0,\n              "product_option": {\n                "extension_attributes": {\n                  "bundle_options": [\n                    {\n                      "extension_attributes": {},\n                      "option_id": 0,\n                      "option_qty": 0,\n                      "option_selections": []\n                    }\n                  ],\n                  "configurable_item_options": [\n                    {\n                      "extension_attributes": {},\n                      "option_id": "",\n                      "option_value": 0\n                    }\n                  ],\n                  "custom_options": [\n                    {\n                      "extension_attributes": {\n                        "file_info": {\n                          "base64_encoded_data": "",\n                          "name": "",\n                          "type": ""\n                        }\n                      },\n                      "option_id": "",\n                      "option_value": ""\n                    }\n                  ],\n                  "downloadable_option": {\n                    "downloadable_links": []\n                  },\n                  "giftcard_item_option": {\n                    "custom_giftcard_amount": "",\n                    "extension_attributes": {},\n                    "giftcard_amount": "",\n                    "giftcard_message": "",\n                    "giftcard_recipient_email": "",\n                    "giftcard_recipient_name": "",\n                    "giftcard_sender_email": "",\n                    "giftcard_sender_name": ""\n                  }\n                }\n              },\n              "product_type": "",\n              "qty_backordered": "",\n              "qty_canceled": "",\n              "qty_invoiced": "",\n              "qty_ordered": "",\n              "qty_refunded": "",\n              "qty_returned": "",\n              "qty_shipped": "",\n              "quote_item_id": 0,\n              "row_invoiced": "",\n              "row_total": "",\n              "row_total_incl_tax": "",\n              "row_weight": "",\n              "sku": "",\n              "store_id": 0,\n              "tax_amount": "",\n              "tax_before_discount": "",\n              "tax_canceled": "",\n              "tax_invoiced": "",\n              "tax_percent": "",\n              "tax_refunded": "",\n              "updated_at": "",\n              "weee_tax_applied": "",\n              "weee_tax_applied_amount": "",\n              "weee_tax_applied_row_amount": "",\n              "weee_tax_disposition": "",\n              "weee_tax_row_disposition": "",\n              "weight": ""\n            }\n          ],\n          "shipping": {\n            "address": {},\n            "extension_attributes": {\n              "collection_point": {\n                "city": "",\n                "collection_point_id": "",\n                "country": "",\n                "name": "",\n                "postcode": "",\n                "recipient_address_id": 0,\n                "region": "",\n                "street": []\n              },\n              "ext_order_id": "",\n              "shipping_experience": {\n                "code": "",\n                "cost": "",\n                "label": ""\n              }\n            },\n            "method": "",\n            "total": {\n              "base_shipping_amount": "",\n              "base_shipping_canceled": "",\n              "base_shipping_discount_amount": "",\n              "base_shipping_discount_tax_compensation_amnt": "",\n              "base_shipping_incl_tax": "",\n              "base_shipping_invoiced": "",\n              "base_shipping_refunded": "",\n              "base_shipping_tax_amount": "",\n              "base_shipping_tax_refunded": "",\n              "extension_attributes": {},\n              "shipping_amount": "",\n              "shipping_canceled": "",\n              "shipping_discount_amount": "",\n              "shipping_discount_tax_compensation_amount": "",\n              "shipping_incl_tax": "",\n              "shipping_invoiced": "",\n              "shipping_refunded": "",\n              "shipping_tax_amount": "",\n              "shipping_tax_refunded": ""\n            }\n          },\n          "stock_id": 0\n        }\n      ]\n    },\n    "forced_shipment_with_invoice": 0,\n    "global_currency_code": "",\n    "grand_total": "",\n    "hold_before_state": "",\n    "hold_before_status": "",\n    "increment_id": "",\n    "is_virtual": 0,\n    "items": [\n      {}\n    ],\n    "order_currency_code": "",\n    "original_increment_id": "",\n    "payment": {\n      "account_status": "",\n      "additional_data": "",\n      "additional_information": [],\n      "address_status": "",\n      "amount_authorized": "",\n      "amount_canceled": "",\n      "amount_ordered": "",\n      "amount_paid": "",\n      "amount_refunded": "",\n      "anet_trans_method": "",\n      "base_amount_authorized": "",\n      "base_amount_canceled": "",\n      "base_amount_ordered": "",\n      "base_amount_paid": "",\n      "base_amount_paid_online": "",\n      "base_amount_refunded": "",\n      "base_amount_refunded_online": "",\n      "base_shipping_amount": "",\n      "base_shipping_captured": "",\n      "base_shipping_refunded": "",\n      "cc_approval": "",\n      "cc_avs_status": "",\n      "cc_cid_status": "",\n      "cc_debug_request_body": "",\n      "cc_debug_response_body": "",\n      "cc_debug_response_serialized": "",\n      "cc_exp_month": "",\n      "cc_exp_year": "",\n      "cc_last4": "",\n      "cc_number_enc": "",\n      "cc_owner": "",\n      "cc_secure_verify": "",\n      "cc_ss_issue": "",\n      "cc_ss_start_month": "",\n      "cc_ss_start_year": "",\n      "cc_status": "",\n      "cc_status_description": "",\n      "cc_trans_id": "",\n      "cc_type": "",\n      "echeck_account_name": "",\n      "echeck_account_type": "",\n      "echeck_bank_name": "",\n      "echeck_routing_number": "",\n      "echeck_type": "",\n      "entity_id": 0,\n      "extension_attributes": {\n        "vault_payment_token": {\n          "created_at": "",\n          "customer_id": 0,\n          "entity_id": 0,\n          "expires_at": "",\n          "gateway_token": "",\n          "is_active": false,\n          "is_visible": false,\n          "payment_method_code": "",\n          "public_hash": "",\n          "token_details": "",\n          "type": ""\n        }\n      },\n      "last_trans_id": "",\n      "method": "",\n      "parent_id": 0,\n      "po_number": "",\n      "protection_eligibility": "",\n      "quote_payment_id": 0,\n      "shipping_amount": "",\n      "shipping_captured": "",\n      "shipping_refunded": ""\n    },\n    "payment_auth_expiration": 0,\n    "payment_authorization_amount": "",\n    "protect_code": "",\n    "quote_address_id": 0,\n    "quote_id": 0,\n    "relation_child_id": "",\n    "relation_child_real_id": "",\n    "relation_parent_id": "",\n    "relation_parent_real_id": "",\n    "remote_ip": "",\n    "shipping_amount": "",\n    "shipping_canceled": "",\n    "shipping_description": "",\n    "shipping_discount_amount": "",\n    "shipping_discount_tax_compensation_amount": "",\n    "shipping_incl_tax": "",\n    "shipping_invoiced": "",\n    "shipping_refunded": "",\n    "shipping_tax_amount": "",\n    "shipping_tax_refunded": "",\n    "state": "",\n    "status": "",\n    "status_histories": [\n      {\n        "comment": "",\n        "created_at": "",\n        "entity_id": 0,\n        "entity_name": "",\n        "extension_attributes": {},\n        "is_customer_notified": 0,\n        "is_visible_on_front": 0,\n        "parent_id": 0,\n        "status": ""\n      }\n    ],\n    "store_currency_code": "",\n    "store_id": 0,\n    "store_name": "",\n    "store_to_base_rate": "",\n    "store_to_order_rate": "",\n    "subtotal": "",\n    "subtotal_canceled": "",\n    "subtotal_incl_tax": "",\n    "subtotal_invoiced": "",\n    "subtotal_refunded": "",\n    "tax_amount": "",\n    "tax_canceled": "",\n    "tax_invoiced": "",\n    "tax_refunded": "",\n    "total_canceled": "",\n    "total_due": "",\n    "total_invoiced": "",\n    "total_item_count": 0,\n    "total_offline_refunded": "",\n    "total_online_refunded": "",\n    "total_paid": "",\n    "total_qty_ordered": "",\n    "total_refunded": "",\n    "updated_at": "",\n    "weight": "",\n    "x_forwarded_for": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/orders/
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["entity": [
    "adjustment_negative": "",
    "adjustment_positive": "",
    "applied_rule_ids": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_canceled": "",
    "base_discount_invoiced": "",
    "base_discount_refunded": "",
    "base_discount_tax_compensation_amount": "",
    "base_discount_tax_compensation_invoiced": "",
    "base_discount_tax_compensation_refunded": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_canceled": "",
    "base_shipping_discount_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_invoiced": "",
    "base_shipping_refunded": "",
    "base_shipping_tax_amount": "",
    "base_shipping_tax_refunded": "",
    "base_subtotal": "",
    "base_subtotal_canceled": "",
    "base_subtotal_incl_tax": "",
    "base_subtotal_invoiced": "",
    "base_subtotal_refunded": "",
    "base_tax_amount": "",
    "base_tax_canceled": "",
    "base_tax_invoiced": "",
    "base_tax_refunded": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_canceled": "",
    "base_total_due": "",
    "base_total_invoiced": "",
    "base_total_invoiced_cost": "",
    "base_total_offline_refunded": "",
    "base_total_online_refunded": "",
    "base_total_paid": "",
    "base_total_qty_ordered": "",
    "base_total_refunded": "",
    "billing_address": [
      "address_type": "",
      "city": "",
      "company": "",
      "country_id": "",
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "entity_id": 0,
      "extension_attributes": ["checkout_fields": [
          [
            "attribute_code": "",
            "value": ""
          ]
        ]],
      "fax": "",
      "firstname": "",
      "lastname": "",
      "middlename": "",
      "parent_id": 0,
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": "",
      "vat_is_valid": 0,
      "vat_request_date": "",
      "vat_request_id": "",
      "vat_request_success": 0
    ],
    "billing_address_id": 0,
    "can_ship_partially": 0,
    "can_ship_partially_item": 0,
    "coupon_code": "",
    "created_at": "",
    "customer_dob": "",
    "customer_email": "",
    "customer_firstname": "",
    "customer_gender": 0,
    "customer_group_id": 0,
    "customer_id": 0,
    "customer_is_guest": 0,
    "customer_lastname": "",
    "customer_middlename": "",
    "customer_note": "",
    "customer_note_notify": 0,
    "customer_prefix": "",
    "customer_suffix": "",
    "customer_taxvat": "",
    "discount_amount": "",
    "discount_canceled": "",
    "discount_description": "",
    "discount_invoiced": "",
    "discount_refunded": "",
    "discount_tax_compensation_amount": "",
    "discount_tax_compensation_invoiced": "",
    "discount_tax_compensation_refunded": "",
    "edit_increment": 0,
    "email_sent": 0,
    "entity_id": 0,
    "ext_customer_id": "",
    "ext_order_id": "",
    "extension_attributes": [
      "amazon_order_reference_id": "",
      "applied_taxes": [
        [
          "amount": "",
          "base_amount": "",
          "code": "",
          "extension_attributes": ["rates": [
              [
                "code": "",
                "extension_attributes": [],
                "percent": "",
                "title": ""
              ]
            ]],
          "percent": "",
          "title": ""
        ]
      ],
      "base_customer_balance_amount": "",
      "base_customer_balance_invoiced": "",
      "base_customer_balance_refunded": "",
      "base_customer_balance_total_refunded": "",
      "base_gift_cards_amount": "",
      "base_gift_cards_invoiced": "",
      "base_gift_cards_refunded": "",
      "base_reward_currency_amount": "",
      "company_order_attributes": [
        "company_id": 0,
        "company_name": "",
        "extension_attributes": [],
        "order_id": 0
      ],
      "converting_from_quote": false,
      "customer_balance_amount": "",
      "customer_balance_invoiced": "",
      "customer_balance_refunded": "",
      "customer_balance_total_refunded": "",
      "gift_cards": [
        [
          "amount": "",
          "base_amount": "",
          "code": "",
          "id": 0
        ]
      ],
      "gift_cards_amount": "",
      "gift_cards_invoiced": "",
      "gift_cards_refunded": "",
      "gift_message": [
        "customer_id": 0,
        "extension_attributes": [
          "entity_id": "",
          "entity_type": "",
          "wrapping_add_printed_card": false,
          "wrapping_allow_gift_receipt": false,
          "wrapping_id": 0
        ],
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
      ],
      "gw_add_card": "",
      "gw_allow_gift_receipt": "",
      "gw_base_price": "",
      "gw_base_price_incl_tax": "",
      "gw_base_price_invoiced": "",
      "gw_base_price_refunded": "",
      "gw_base_tax_amount": "",
      "gw_base_tax_amount_invoiced": "",
      "gw_base_tax_amount_refunded": "",
      "gw_card_base_price": "",
      "gw_card_base_price_incl_tax": "",
      "gw_card_base_price_invoiced": "",
      "gw_card_base_price_refunded": "",
      "gw_card_base_tax_amount": "",
      "gw_card_base_tax_invoiced": "",
      "gw_card_base_tax_refunded": "",
      "gw_card_price": "",
      "gw_card_price_incl_tax": "",
      "gw_card_price_invoiced": "",
      "gw_card_price_refunded": "",
      "gw_card_tax_amount": "",
      "gw_card_tax_invoiced": "",
      "gw_card_tax_refunded": "",
      "gw_id": "",
      "gw_items_base_price": "",
      "gw_items_base_price_incl_tax": "",
      "gw_items_base_price_invoiced": "",
      "gw_items_base_price_refunded": "",
      "gw_items_base_tax_amount": "",
      "gw_items_base_tax_invoiced": "",
      "gw_items_base_tax_refunded": "",
      "gw_items_price": "",
      "gw_items_price_incl_tax": "",
      "gw_items_price_invoiced": "",
      "gw_items_price_refunded": "",
      "gw_items_tax_amount": "",
      "gw_items_tax_invoiced": "",
      "gw_items_tax_refunded": "",
      "gw_price": "",
      "gw_price_incl_tax": "",
      "gw_price_invoiced": "",
      "gw_price_refunded": "",
      "gw_tax_amount": "",
      "gw_tax_amount_invoiced": "",
      "gw_tax_amount_refunded": "",
      "item_applied_taxes": [
        [
          "applied_taxes": [[]],
          "associated_item_id": 0,
          "extension_attributes": [],
          "item_id": 0,
          "type": ""
        ]
      ],
      "payment_additional_info": [
        [
          "key": "",
          "value": ""
        ]
      ],
      "reward_currency_amount": "",
      "reward_points_balance": 0,
      "shipping_assignments": [
        [
          "extension_attributes": [],
          "items": [
            [
              "additional_data": "",
              "amount_refunded": "",
              "applied_rule_ids": "",
              "base_amount_refunded": "",
              "base_cost": "",
              "base_discount_amount": "",
              "base_discount_invoiced": "",
              "base_discount_refunded": "",
              "base_discount_tax_compensation_amount": "",
              "base_discount_tax_compensation_invoiced": "",
              "base_discount_tax_compensation_refunded": "",
              "base_original_price": "",
              "base_price": "",
              "base_price_incl_tax": "",
              "base_row_invoiced": "",
              "base_row_total": "",
              "base_row_total_incl_tax": "",
              "base_tax_amount": "",
              "base_tax_before_discount": "",
              "base_tax_invoiced": "",
              "base_tax_refunded": "",
              "base_weee_tax_applied_amount": "",
              "base_weee_tax_applied_row_amnt": "",
              "base_weee_tax_disposition": "",
              "base_weee_tax_row_disposition": "",
              "created_at": "",
              "description": "",
              "discount_amount": "",
              "discount_invoiced": "",
              "discount_percent": "",
              "discount_refunded": "",
              "discount_tax_compensation_amount": "",
              "discount_tax_compensation_canceled": "",
              "discount_tax_compensation_invoiced": "",
              "discount_tax_compensation_refunded": "",
              "event_id": 0,
              "ext_order_item_id": "",
              "extension_attributes": [
                "gift_message": [],
                "gw_base_price": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_id": "",
                "gw_price": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "invoice_text_codes": [],
                "tax_codes": [],
                "vertex_tax_codes": []
              ],
              "free_shipping": 0,
              "gw_base_price": "",
              "gw_base_price_invoiced": "",
              "gw_base_price_refunded": "",
              "gw_base_tax_amount": "",
              "gw_base_tax_amount_invoiced": "",
              "gw_base_tax_amount_refunded": "",
              "gw_id": 0,
              "gw_price": "",
              "gw_price_invoiced": "",
              "gw_price_refunded": "",
              "gw_tax_amount": "",
              "gw_tax_amount_invoiced": "",
              "gw_tax_amount_refunded": "",
              "is_qty_decimal": 0,
              "is_virtual": 0,
              "item_id": 0,
              "locked_do_invoice": 0,
              "locked_do_ship": 0,
              "name": "",
              "no_discount": 0,
              "order_id": 0,
              "original_price": "",
              "parent_item": "",
              "parent_item_id": 0,
              "price": "",
              "price_incl_tax": "",
              "product_id": 0,
              "product_option": ["extension_attributes": [
                  "bundle_options": [
                    [
                      "extension_attributes": [],
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    ]
                  ],
                  "configurable_item_options": [
                    [
                      "extension_attributes": [],
                      "option_id": "",
                      "option_value": 0
                    ]
                  ],
                  "custom_options": [
                    [
                      "extension_attributes": ["file_info": [
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        ]],
                      "option_id": "",
                      "option_value": ""
                    ]
                  ],
                  "downloadable_option": ["downloadable_links": []],
                  "giftcard_item_option": [
                    "custom_giftcard_amount": "",
                    "extension_attributes": [],
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  ]
                ]],
              "product_type": "",
              "qty_backordered": "",
              "qty_canceled": "",
              "qty_invoiced": "",
              "qty_ordered": "",
              "qty_refunded": "",
              "qty_returned": "",
              "qty_shipped": "",
              "quote_item_id": 0,
              "row_invoiced": "",
              "row_total": "",
              "row_total_incl_tax": "",
              "row_weight": "",
              "sku": "",
              "store_id": 0,
              "tax_amount": "",
              "tax_before_discount": "",
              "tax_canceled": "",
              "tax_invoiced": "",
              "tax_percent": "",
              "tax_refunded": "",
              "updated_at": "",
              "weee_tax_applied": "",
              "weee_tax_applied_amount": "",
              "weee_tax_applied_row_amount": "",
              "weee_tax_disposition": "",
              "weee_tax_row_disposition": "",
              "weight": ""
            ]
          ],
          "shipping": [
            "address": [],
            "extension_attributes": [
              "collection_point": [
                "city": "",
                "collection_point_id": "",
                "country": "",
                "name": "",
                "postcode": "",
                "recipient_address_id": 0,
                "region": "",
                "street": []
              ],
              "ext_order_id": "",
              "shipping_experience": [
                "code": "",
                "cost": "",
                "label": ""
              ]
            ],
            "method": "",
            "total": [
              "base_shipping_amount": "",
              "base_shipping_canceled": "",
              "base_shipping_discount_amount": "",
              "base_shipping_discount_tax_compensation_amnt": "",
              "base_shipping_incl_tax": "",
              "base_shipping_invoiced": "",
              "base_shipping_refunded": "",
              "base_shipping_tax_amount": "",
              "base_shipping_tax_refunded": "",
              "extension_attributes": [],
              "shipping_amount": "",
              "shipping_canceled": "",
              "shipping_discount_amount": "",
              "shipping_discount_tax_compensation_amount": "",
              "shipping_incl_tax": "",
              "shipping_invoiced": "",
              "shipping_refunded": "",
              "shipping_tax_amount": "",
              "shipping_tax_refunded": ""
            ]
          ],
          "stock_id": 0
        ]
      ]
    ],
    "forced_shipment_with_invoice": 0,
    "global_currency_code": "",
    "grand_total": "",
    "hold_before_state": "",
    "hold_before_status": "",
    "increment_id": "",
    "is_virtual": 0,
    "items": [[]],
    "order_currency_code": "",
    "original_increment_id": "",
    "payment": [
      "account_status": "",
      "additional_data": "",
      "additional_information": [],
      "address_status": "",
      "amount_authorized": "",
      "amount_canceled": "",
      "amount_ordered": "",
      "amount_paid": "",
      "amount_refunded": "",
      "anet_trans_method": "",
      "base_amount_authorized": "",
      "base_amount_canceled": "",
      "base_amount_ordered": "",
      "base_amount_paid": "",
      "base_amount_paid_online": "",
      "base_amount_refunded": "",
      "base_amount_refunded_online": "",
      "base_shipping_amount": "",
      "base_shipping_captured": "",
      "base_shipping_refunded": "",
      "cc_approval": "",
      "cc_avs_status": "",
      "cc_cid_status": "",
      "cc_debug_request_body": "",
      "cc_debug_response_body": "",
      "cc_debug_response_serialized": "",
      "cc_exp_month": "",
      "cc_exp_year": "",
      "cc_last4": "",
      "cc_number_enc": "",
      "cc_owner": "",
      "cc_secure_verify": "",
      "cc_ss_issue": "",
      "cc_ss_start_month": "",
      "cc_ss_start_year": "",
      "cc_status": "",
      "cc_status_description": "",
      "cc_trans_id": "",
      "cc_type": "",
      "echeck_account_name": "",
      "echeck_account_type": "",
      "echeck_bank_name": "",
      "echeck_routing_number": "",
      "echeck_type": "",
      "entity_id": 0,
      "extension_attributes": ["vault_payment_token": [
          "created_at": "",
          "customer_id": 0,
          "entity_id": 0,
          "expires_at": "",
          "gateway_token": "",
          "is_active": false,
          "is_visible": false,
          "payment_method_code": "",
          "public_hash": "",
          "token_details": "",
          "type": ""
        ]],
      "last_trans_id": "",
      "method": "",
      "parent_id": 0,
      "po_number": "",
      "protection_eligibility": "",
      "quote_payment_id": 0,
      "shipping_amount": "",
      "shipping_captured": "",
      "shipping_refunded": ""
    ],
    "payment_auth_expiration": 0,
    "payment_authorization_amount": "",
    "protect_code": "",
    "quote_address_id": 0,
    "quote_id": 0,
    "relation_child_id": "",
    "relation_child_real_id": "",
    "relation_parent_id": "",
    "relation_parent_real_id": "",
    "remote_ip": "",
    "shipping_amount": "",
    "shipping_canceled": "",
    "shipping_description": "",
    "shipping_discount_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_invoiced": "",
    "shipping_refunded": "",
    "shipping_tax_amount": "",
    "shipping_tax_refunded": "",
    "state": "",
    "status": "",
    "status_histories": [
      [
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "entity_name": "",
        "extension_attributes": [],
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0,
        "status": ""
      ]
    ],
    "store_currency_code": "",
    "store_id": 0,
    "store_name": "",
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_canceled": "",
    "subtotal_incl_tax": "",
    "subtotal_invoiced": "",
    "subtotal_refunded": "",
    "tax_amount": "",
    "tax_canceled": "",
    "tax_invoiced": "",
    "tax_refunded": "",
    "total_canceled": "",
    "total_due": "",
    "total_invoiced": "",
    "total_item_count": 0,
    "total_offline_refunded": "",
    "total_online_refunded": "",
    "total_paid": "",
    "total_qty_ordered": "",
    "total_refunded": "",
    "updated_at": "",
    "weight": "",
    "x_forwarded_for": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/orders/")! 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 orders-{id}
{{baseUrl}}/V1/orders/:id
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/orders/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/orders/:id")
require "http/client"

url = "{{baseUrl}}/V1/orders/:id"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/orders/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/orders/:id");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/orders/:id"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/orders/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/orders/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/orders/:id"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/orders/:id")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/orders/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/orders/:id');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/orders/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/orders/:id',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/orders/:id")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/orders/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders/:id'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/orders/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/orders/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/orders/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/orders/:id" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/orders/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/orders/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/orders/:id');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/orders/:id');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/orders/:id' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/orders/:id' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/orders/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/orders/:id"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/orders/:id"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/orders/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/orders/:id') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/orders/:id";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/orders/:id
http GET {{baseUrl}}/V1/orders/:id
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/orders/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/orders/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST orders-{id}-cancel
{{baseUrl}}/V1/orders/:id/cancel
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/orders/:id/cancel");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/orders/:id/cancel")
require "http/client"

url = "{{baseUrl}}/V1/orders/:id/cancel"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/orders/:id/cancel"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/orders/:id/cancel");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/orders/:id/cancel"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/orders/:id/cancel HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/orders/:id/cancel")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/orders/:id/cancel"))
    .method("POST", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/orders/:id/cancel")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/orders/:id/cancel")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/orders/:id/cancel');

xhr.send(data);
import axios from 'axios';

const options = {method: 'POST', url: '{{baseUrl}}/V1/orders/:id/cancel'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/orders/:id/cancel';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/orders/:id/cancel',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/orders/:id/cancel")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/orders/:id/cancel',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'POST', url: '{{baseUrl}}/V1/orders/:id/cancel'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/orders/:id/cancel');

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}}/V1/orders/:id/cancel'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/orders/:id/cancel';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/orders/:id/cancel"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/orders/:id/cancel" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/orders/:id/cancel",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/orders/:id/cancel');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/orders/:id/cancel');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/orders/:id/cancel');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/orders/:id/cancel' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/orders/:id/cancel' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/V1/orders/:id/cancel")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/orders/:id/cancel"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/orders/:id/cancel"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/orders/:id/cancel")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/V1/orders/:id/cancel') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/orders/:id/cancel";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/orders/:id/cancel
http POST {{baseUrl}}/V1/orders/:id/cancel
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/V1/orders/:id/cancel
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/orders/:id/cancel")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST orders-{id}-comments (POST)
{{baseUrl}}/V1/orders/:id/comments
QUERY PARAMS

id
BODY json

{
  "statusHistory": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "entity_name": "",
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0,
    "status": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/orders/:id/comments");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"statusHistory\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"entity_name\": \"\",\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0,\n    \"status\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/orders/:id/comments" {:content-type :json
                                                                   :form-params {:statusHistory {:comment ""
                                                                                                 :created_at ""
                                                                                                 :entity_id 0
                                                                                                 :entity_name ""
                                                                                                 :extension_attributes {}
                                                                                                 :is_customer_notified 0
                                                                                                 :is_visible_on_front 0
                                                                                                 :parent_id 0
                                                                                                 :status ""}}})
require "http/client"

url = "{{baseUrl}}/V1/orders/:id/comments"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"statusHistory\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"entity_name\": \"\",\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0,\n    \"status\": \"\"\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}}/V1/orders/:id/comments"),
    Content = new StringContent("{\n  \"statusHistory\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"entity_name\": \"\",\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0,\n    \"status\": \"\"\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}}/V1/orders/:id/comments");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"statusHistory\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"entity_name\": \"\",\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0,\n    \"status\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/orders/:id/comments"

	payload := strings.NewReader("{\n  \"statusHistory\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"entity_name\": \"\",\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0,\n    \"status\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/orders/:id/comments HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 242

{
  "statusHistory": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "entity_name": "",
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0,
    "status": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/orders/:id/comments")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"statusHistory\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"entity_name\": \"\",\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0,\n    \"status\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/orders/:id/comments"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"statusHistory\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"entity_name\": \"\",\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0,\n    \"status\": \"\"\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  \"statusHistory\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"entity_name\": \"\",\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0,\n    \"status\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/orders/:id/comments")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/orders/:id/comments")
  .header("content-type", "application/json")
  .body("{\n  \"statusHistory\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"entity_name\": \"\",\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0,\n    \"status\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  statusHistory: {
    comment: '',
    created_at: '',
    entity_id: 0,
    entity_name: '',
    extension_attributes: {},
    is_customer_notified: 0,
    is_visible_on_front: 0,
    parent_id: 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}}/V1/orders/:id/comments');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/orders/:id/comments',
  headers: {'content-type': 'application/json'},
  data: {
    statusHistory: {
      comment: '',
      created_at: '',
      entity_id: 0,
      entity_name: '',
      extension_attributes: {},
      is_customer_notified: 0,
      is_visible_on_front: 0,
      parent_id: 0,
      status: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/orders/:id/comments';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"statusHistory":{"comment":"","created_at":"","entity_id":0,"entity_name":"","extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_id":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}}/V1/orders/:id/comments',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "statusHistory": {\n    "comment": "",\n    "created_at": "",\n    "entity_id": 0,\n    "entity_name": "",\n    "extension_attributes": {},\n    "is_customer_notified": 0,\n    "is_visible_on_front": 0,\n    "parent_id": 0,\n    "status": ""\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  \"statusHistory\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"entity_name\": \"\",\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0,\n    \"status\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/orders/:id/comments")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/orders/:id/comments',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  statusHistory: {
    comment: '',
    created_at: '',
    entity_id: 0,
    entity_name: '',
    extension_attributes: {},
    is_customer_notified: 0,
    is_visible_on_front: 0,
    parent_id: 0,
    status: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/orders/:id/comments',
  headers: {'content-type': 'application/json'},
  body: {
    statusHistory: {
      comment: '',
      created_at: '',
      entity_id: 0,
      entity_name: '',
      extension_attributes: {},
      is_customer_notified: 0,
      is_visible_on_front: 0,
      parent_id: 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}}/V1/orders/:id/comments');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  statusHistory: {
    comment: '',
    created_at: '',
    entity_id: 0,
    entity_name: '',
    extension_attributes: {},
    is_customer_notified: 0,
    is_visible_on_front: 0,
    parent_id: 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}}/V1/orders/:id/comments',
  headers: {'content-type': 'application/json'},
  data: {
    statusHistory: {
      comment: '',
      created_at: '',
      entity_id: 0,
      entity_name: '',
      extension_attributes: {},
      is_customer_notified: 0,
      is_visible_on_front: 0,
      parent_id: 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}}/V1/orders/:id/comments';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"statusHistory":{"comment":"","created_at":"","entity_id":0,"entity_name":"","extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_id":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 = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"statusHistory": @{ @"comment": @"", @"created_at": @"", @"entity_id": @0, @"entity_name": @"", @"extension_attributes": @{  }, @"is_customer_notified": @0, @"is_visible_on_front": @0, @"parent_id": @0, @"status": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/orders/:id/comments"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/orders/:id/comments" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"statusHistory\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"entity_name\": \"\",\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0,\n    \"status\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/orders/:id/comments",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'statusHistory' => [
        'comment' => '',
        'created_at' => '',
        'entity_id' => 0,
        'entity_name' => '',
        'extension_attributes' => [
                
        ],
        'is_customer_notified' => 0,
        'is_visible_on_front' => 0,
        'parent_id' => 0,
        'status' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/orders/:id/comments', [
  'body' => '{
  "statusHistory": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "entity_name": "",
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0,
    "status": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/orders/:id/comments');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'statusHistory' => [
    'comment' => '',
    'created_at' => '',
    'entity_id' => 0,
    'entity_name' => '',
    'extension_attributes' => [
        
    ],
    'is_customer_notified' => 0,
    'is_visible_on_front' => 0,
    'parent_id' => 0,
    'status' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'statusHistory' => [
    'comment' => '',
    'created_at' => '',
    'entity_id' => 0,
    'entity_name' => '',
    'extension_attributes' => [
        
    ],
    'is_customer_notified' => 0,
    'is_visible_on_front' => 0,
    'parent_id' => 0,
    'status' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/orders/:id/comments');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/orders/:id/comments' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "statusHistory": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "entity_name": "",
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0,
    "status": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/orders/:id/comments' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "statusHistory": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "entity_name": "",
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0,
    "status": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"statusHistory\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"entity_name\": \"\",\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0,\n    \"status\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/orders/:id/comments", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/orders/:id/comments"

payload = { "statusHistory": {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "entity_name": "",
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0,
        "status": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/orders/:id/comments"

payload <- "{\n  \"statusHistory\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"entity_name\": \"\",\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0,\n    \"status\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/orders/:id/comments")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"statusHistory\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"entity_name\": \"\",\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0,\n    \"status\": \"\"\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/V1/orders/:id/comments') do |req|
  req.body = "{\n  \"statusHistory\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"entity_name\": \"\",\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0,\n    \"status\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/orders/:id/comments";

    let payload = json!({"statusHistory": json!({
            "comment": "",
            "created_at": "",
            "entity_id": 0,
            "entity_name": "",
            "extension_attributes": json!({}),
            "is_customer_notified": 0,
            "is_visible_on_front": 0,
            "parent_id": 0,
            "status": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/orders/:id/comments \
  --header 'content-type: application/json' \
  --data '{
  "statusHistory": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "entity_name": "",
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0,
    "status": ""
  }
}'
echo '{
  "statusHistory": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "entity_name": "",
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0,
    "status": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/orders/:id/comments \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "statusHistory": {\n    "comment": "",\n    "created_at": "",\n    "entity_id": 0,\n    "entity_name": "",\n    "extension_attributes": {},\n    "is_customer_notified": 0,\n    "is_visible_on_front": 0,\n    "parent_id": 0,\n    "status": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/orders/:id/comments
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["statusHistory": [
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "entity_name": "",
    "extension_attributes": [],
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0,
    "status": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/orders/:id/comments")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET orders-{id}-comments
{{baseUrl}}/V1/orders/:id/comments
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/orders/:id/comments");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/orders/:id/comments")
require "http/client"

url = "{{baseUrl}}/V1/orders/:id/comments"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/orders/:id/comments"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/orders/:id/comments");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/orders/:id/comments"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/orders/:id/comments HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/orders/:id/comments")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/orders/:id/comments"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/orders/:id/comments")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/orders/:id/comments")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/orders/:id/comments');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders/:id/comments'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/orders/:id/comments';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/orders/:id/comments',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/orders/:id/comments")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/orders/:id/comments',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders/:id/comments'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/orders/:id/comments');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders/:id/comments'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/orders/:id/comments';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/orders/:id/comments"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/orders/:id/comments" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/orders/:id/comments",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/orders/:id/comments');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/orders/:id/comments');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/orders/:id/comments');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/orders/:id/comments' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/orders/:id/comments' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/orders/:id/comments")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/orders/:id/comments"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/orders/:id/comments"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/orders/:id/comments")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/orders/:id/comments') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/orders/:id/comments";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/orders/:id/comments
http GET {{baseUrl}}/V1/orders/:id/comments
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/orders/:id/comments
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/orders/:id/comments")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST orders-{id}-emails
{{baseUrl}}/V1/orders/:id/emails
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/orders/:id/emails");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/orders/:id/emails")
require "http/client"

url = "{{baseUrl}}/V1/orders/:id/emails"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/orders/:id/emails"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/orders/:id/emails");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/orders/:id/emails"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/orders/:id/emails HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/orders/:id/emails")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/orders/:id/emails"))
    .method("POST", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/orders/:id/emails")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/orders/:id/emails")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/orders/:id/emails');

xhr.send(data);
import axios from 'axios';

const options = {method: 'POST', url: '{{baseUrl}}/V1/orders/:id/emails'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/orders/:id/emails';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/orders/:id/emails',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/orders/:id/emails")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/orders/:id/emails',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'POST', url: '{{baseUrl}}/V1/orders/:id/emails'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/orders/:id/emails');

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}}/V1/orders/:id/emails'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/orders/:id/emails';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/orders/:id/emails"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/orders/:id/emails" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/orders/:id/emails",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/orders/:id/emails');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/orders/:id/emails');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/orders/:id/emails');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/orders/:id/emails' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/orders/:id/emails' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/V1/orders/:id/emails")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/orders/:id/emails"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/orders/:id/emails"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/orders/:id/emails")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/V1/orders/:id/emails') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/orders/:id/emails";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/orders/:id/emails
http POST {{baseUrl}}/V1/orders/:id/emails
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/V1/orders/:id/emails
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/orders/:id/emails")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST orders-{id}-hold
{{baseUrl}}/V1/orders/:id/hold
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/orders/:id/hold");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/orders/:id/hold")
require "http/client"

url = "{{baseUrl}}/V1/orders/:id/hold"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/orders/:id/hold"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/orders/:id/hold");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/orders/:id/hold"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/orders/:id/hold HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/orders/:id/hold")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/orders/:id/hold"))
    .method("POST", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/orders/:id/hold")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/orders/:id/hold")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/orders/:id/hold');

xhr.send(data);
import axios from 'axios';

const options = {method: 'POST', url: '{{baseUrl}}/V1/orders/:id/hold'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/orders/:id/hold';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/orders/:id/hold',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/orders/:id/hold")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/orders/:id/hold',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'POST', url: '{{baseUrl}}/V1/orders/:id/hold'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/orders/:id/hold');

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}}/V1/orders/:id/hold'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/orders/:id/hold';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/orders/:id/hold"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/orders/:id/hold" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/orders/:id/hold",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/orders/:id/hold');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/orders/:id/hold');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/orders/:id/hold');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/orders/:id/hold' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/orders/:id/hold' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/V1/orders/:id/hold")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/orders/:id/hold"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/orders/:id/hold"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/orders/:id/hold")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/V1/orders/:id/hold') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/orders/:id/hold";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/orders/:id/hold
http POST {{baseUrl}}/V1/orders/:id/hold
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/V1/orders/:id/hold
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/orders/:id/hold")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET orders-{id}-statuses
{{baseUrl}}/V1/orders/:id/statuses
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/orders/:id/statuses");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/orders/:id/statuses")
require "http/client"

url = "{{baseUrl}}/V1/orders/:id/statuses"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/orders/:id/statuses"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/orders/:id/statuses");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/orders/:id/statuses"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/orders/:id/statuses HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/orders/:id/statuses")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/orders/:id/statuses"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/orders/:id/statuses")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/orders/:id/statuses")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/orders/:id/statuses');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders/:id/statuses'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/orders/:id/statuses';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/orders/:id/statuses',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/orders/:id/statuses")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/orders/:id/statuses',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders/:id/statuses'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/orders/:id/statuses');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders/:id/statuses'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/orders/:id/statuses';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/orders/:id/statuses"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/orders/:id/statuses" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/orders/:id/statuses",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/orders/:id/statuses');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/orders/:id/statuses');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/orders/:id/statuses');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/orders/:id/statuses' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/orders/:id/statuses' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/orders/:id/statuses")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/orders/:id/statuses"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/orders/:id/statuses"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/orders/:id/statuses")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/orders/:id/statuses') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/orders/:id/statuses";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/orders/:id/statuses
http GET {{baseUrl}}/V1/orders/:id/statuses
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/orders/:id/statuses
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/orders/:id/statuses")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST orders-{id}-unhold
{{baseUrl}}/V1/orders/:id/unhold
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/orders/:id/unhold");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/orders/:id/unhold")
require "http/client"

url = "{{baseUrl}}/V1/orders/:id/unhold"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/orders/:id/unhold"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/orders/:id/unhold");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/orders/:id/unhold"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/orders/:id/unhold HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/orders/:id/unhold")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/orders/:id/unhold"))
    .method("POST", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/orders/:id/unhold")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/orders/:id/unhold")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/orders/:id/unhold');

xhr.send(data);
import axios from 'axios';

const options = {method: 'POST', url: '{{baseUrl}}/V1/orders/:id/unhold'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/orders/:id/unhold';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/orders/:id/unhold',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/orders/:id/unhold")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/orders/:id/unhold',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'POST', url: '{{baseUrl}}/V1/orders/:id/unhold'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/orders/:id/unhold');

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}}/V1/orders/:id/unhold'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/orders/:id/unhold';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/orders/:id/unhold"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/orders/:id/unhold" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/orders/:id/unhold",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/orders/:id/unhold');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/orders/:id/unhold');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/orders/:id/unhold');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/orders/:id/unhold' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/orders/:id/unhold' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/V1/orders/:id/unhold")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/orders/:id/unhold"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/orders/:id/unhold"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/orders/:id/unhold")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/V1/orders/:id/unhold') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/orders/:id/unhold";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/orders/:id/unhold
http POST {{baseUrl}}/V1/orders/:id/unhold
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/V1/orders/:id/unhold
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/orders/:id/unhold")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT orders-{parent_id}
{{baseUrl}}/V1/orders/:parent_id
QUERY PARAMS

parent_id
BODY json

{
  "entity": {
    "address_type": "",
    "city": "",
    "company": "",
    "country_id": "",
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "entity_id": 0,
    "extension_attributes": {
      "checkout_fields": [
        {
          "attribute_code": "",
          "value": ""
        }
      ]
    },
    "fax": "",
    "firstname": "",
    "lastname": "",
    "middlename": "",
    "parent_id": 0,
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": "",
    "vat_is_valid": 0,
    "vat_request_date": "",
    "vat_request_id": "",
    "vat_request_success": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/orders/:parent_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"entity\": {\n    \"address_type\": \"\",\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ]\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"parent_id\": 0,\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\",\n    \"vat_is_valid\": 0,\n    \"vat_request_date\": \"\",\n    \"vat_request_id\": \"\",\n    \"vat_request_success\": 0\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/orders/:parent_id" {:content-type :json
                                                                :form-params {:entity {:address_type ""
                                                                                       :city ""
                                                                                       :company ""
                                                                                       :country_id ""
                                                                                       :customer_address_id 0
                                                                                       :customer_id 0
                                                                                       :email ""
                                                                                       :entity_id 0
                                                                                       :extension_attributes {:checkout_fields [{:attribute_code ""
                                                                                                                                 :value ""}]}
                                                                                       :fax ""
                                                                                       :firstname ""
                                                                                       :lastname ""
                                                                                       :middlename ""
                                                                                       :parent_id 0
                                                                                       :postcode ""
                                                                                       :prefix ""
                                                                                       :region ""
                                                                                       :region_code ""
                                                                                       :region_id 0
                                                                                       :street []
                                                                                       :suffix ""
                                                                                       :telephone ""
                                                                                       :vat_id ""
                                                                                       :vat_is_valid 0
                                                                                       :vat_request_date ""
                                                                                       :vat_request_id ""
                                                                                       :vat_request_success 0}}})
require "http/client"

url = "{{baseUrl}}/V1/orders/:parent_id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"entity\": {\n    \"address_type\": \"\",\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ]\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"parent_id\": 0,\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\",\n    \"vat_is_valid\": 0,\n    \"vat_request_date\": \"\",\n    \"vat_request_id\": \"\",\n    \"vat_request_success\": 0\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}}/V1/orders/:parent_id"),
    Content = new StringContent("{\n  \"entity\": {\n    \"address_type\": \"\",\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ]\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"parent_id\": 0,\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\",\n    \"vat_is_valid\": 0,\n    \"vat_request_date\": \"\",\n    \"vat_request_id\": \"\",\n    \"vat_request_success\": 0\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}}/V1/orders/:parent_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"entity\": {\n    \"address_type\": \"\",\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ]\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"parent_id\": 0,\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\",\n    \"vat_is_valid\": 0,\n    \"vat_request_date\": \"\",\n    \"vat_request_id\": \"\",\n    \"vat_request_success\": 0\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/orders/:parent_id"

	payload := strings.NewReader("{\n  \"entity\": {\n    \"address_type\": \"\",\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ]\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"parent_id\": 0,\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\",\n    \"vat_is_valid\": 0,\n    \"vat_request_date\": \"\",\n    \"vat_request_id\": \"\",\n    \"vat_request_success\": 0\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/orders/:parent_id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 715

{
  "entity": {
    "address_type": "",
    "city": "",
    "company": "",
    "country_id": "",
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "entity_id": 0,
    "extension_attributes": {
      "checkout_fields": [
        {
          "attribute_code": "",
          "value": ""
        }
      ]
    },
    "fax": "",
    "firstname": "",
    "lastname": "",
    "middlename": "",
    "parent_id": 0,
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": "",
    "vat_is_valid": 0,
    "vat_request_date": "",
    "vat_request_id": "",
    "vat_request_success": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/orders/:parent_id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"entity\": {\n    \"address_type\": \"\",\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ]\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"parent_id\": 0,\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\",\n    \"vat_is_valid\": 0,\n    \"vat_request_date\": \"\",\n    \"vat_request_id\": \"\",\n    \"vat_request_success\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/orders/:parent_id"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"entity\": {\n    \"address_type\": \"\",\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ]\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"parent_id\": 0,\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\",\n    \"vat_is_valid\": 0,\n    \"vat_request_date\": \"\",\n    \"vat_request_id\": \"\",\n    \"vat_request_success\": 0\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  \"entity\": {\n    \"address_type\": \"\",\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ]\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"parent_id\": 0,\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\",\n    \"vat_is_valid\": 0,\n    \"vat_request_date\": \"\",\n    \"vat_request_id\": \"\",\n    \"vat_request_success\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/orders/:parent_id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/orders/:parent_id")
  .header("content-type", "application/json")
  .body("{\n  \"entity\": {\n    \"address_type\": \"\",\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ]\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"parent_id\": 0,\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\",\n    \"vat_is_valid\": 0,\n    \"vat_request_date\": \"\",\n    \"vat_request_id\": \"\",\n    \"vat_request_success\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  entity: {
    address_type: '',
    city: '',
    company: '',
    country_id: '',
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    entity_id: 0,
    extension_attributes: {
      checkout_fields: [
        {
          attribute_code: '',
          value: ''
        }
      ]
    },
    fax: '',
    firstname: '',
    lastname: '',
    middlename: '',
    parent_id: 0,
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: '',
    vat_is_valid: 0,
    vat_request_date: '',
    vat_request_id: '',
    vat_request_success: 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}}/V1/orders/:parent_id');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/orders/:parent_id',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      address_type: '',
      city: '',
      company: '',
      country_id: '',
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      entity_id: 0,
      extension_attributes: {checkout_fields: [{attribute_code: '', value: ''}]},
      fax: '',
      firstname: '',
      lastname: '',
      middlename: '',
      parent_id: 0,
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: '',
      vat_is_valid: 0,
      vat_request_date: '',
      vat_request_id: '',
      vat_request_success: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/orders/:parent_id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"address_type":"","city":"","company":"","country_id":"","customer_address_id":0,"customer_id":0,"email":"","entity_id":0,"extension_attributes":{"checkout_fields":[{"attribute_code":"","value":""}]},"fax":"","firstname":"","lastname":"","middlename":"","parent_id":0,"postcode":"","prefix":"","region":"","region_code":"","region_id":0,"street":[],"suffix":"","telephone":"","vat_id":"","vat_is_valid":0,"vat_request_date":"","vat_request_id":"","vat_request_success":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}}/V1/orders/:parent_id',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "entity": {\n    "address_type": "",\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "entity_id": 0,\n    "extension_attributes": {\n      "checkout_fields": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ]\n    },\n    "fax": "",\n    "firstname": "",\n    "lastname": "",\n    "middlename": "",\n    "parent_id": 0,\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": "",\n    "vat_is_valid": 0,\n    "vat_request_date": "",\n    "vat_request_id": "",\n    "vat_request_success": 0\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  \"entity\": {\n    \"address_type\": \"\",\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ]\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"parent_id\": 0,\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\",\n    \"vat_is_valid\": 0,\n    \"vat_request_date\": \"\",\n    \"vat_request_id\": \"\",\n    \"vat_request_success\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/orders/:parent_id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/orders/:parent_id',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  entity: {
    address_type: '',
    city: '',
    company: '',
    country_id: '',
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    entity_id: 0,
    extension_attributes: {checkout_fields: [{attribute_code: '', value: ''}]},
    fax: '',
    firstname: '',
    lastname: '',
    middlename: '',
    parent_id: 0,
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: '',
    vat_is_valid: 0,
    vat_request_date: '',
    vat_request_id: '',
    vat_request_success: 0
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/orders/:parent_id',
  headers: {'content-type': 'application/json'},
  body: {
    entity: {
      address_type: '',
      city: '',
      company: '',
      country_id: '',
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      entity_id: 0,
      extension_attributes: {checkout_fields: [{attribute_code: '', value: ''}]},
      fax: '',
      firstname: '',
      lastname: '',
      middlename: '',
      parent_id: 0,
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: '',
      vat_is_valid: 0,
      vat_request_date: '',
      vat_request_id: '',
      vat_request_success: 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}}/V1/orders/:parent_id');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  entity: {
    address_type: '',
    city: '',
    company: '',
    country_id: '',
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    entity_id: 0,
    extension_attributes: {
      checkout_fields: [
        {
          attribute_code: '',
          value: ''
        }
      ]
    },
    fax: '',
    firstname: '',
    lastname: '',
    middlename: '',
    parent_id: 0,
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: '',
    vat_is_valid: 0,
    vat_request_date: '',
    vat_request_id: '',
    vat_request_success: 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}}/V1/orders/:parent_id',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      address_type: '',
      city: '',
      company: '',
      country_id: '',
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      entity_id: 0,
      extension_attributes: {checkout_fields: [{attribute_code: '', value: ''}]},
      fax: '',
      firstname: '',
      lastname: '',
      middlename: '',
      parent_id: 0,
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: '',
      vat_is_valid: 0,
      vat_request_date: '',
      vat_request_id: '',
      vat_request_success: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/orders/:parent_id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"address_type":"","city":"","company":"","country_id":"","customer_address_id":0,"customer_id":0,"email":"","entity_id":0,"extension_attributes":{"checkout_fields":[{"attribute_code":"","value":""}]},"fax":"","firstname":"","lastname":"","middlename":"","parent_id":0,"postcode":"","prefix":"","region":"","region_code":"","region_id":0,"street":[],"suffix":"","telephone":"","vat_id":"","vat_is_valid":0,"vat_request_date":"","vat_request_id":"","vat_request_success":0}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"entity": @{ @"address_type": @"", @"city": @"", @"company": @"", @"country_id": @"", @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"entity_id": @0, @"extension_attributes": @{ @"checkout_fields": @[ @{ @"attribute_code": @"", @"value": @"" } ] }, @"fax": @"", @"firstname": @"", @"lastname": @"", @"middlename": @"", @"parent_id": @0, @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"", @"vat_is_valid": @0, @"vat_request_date": @"", @"vat_request_id": @"", @"vat_request_success": @0 } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/orders/:parent_id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/orders/:parent_id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"entity\": {\n    \"address_type\": \"\",\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ]\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"parent_id\": 0,\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\",\n    \"vat_is_valid\": 0,\n    \"vat_request_date\": \"\",\n    \"vat_request_id\": \"\",\n    \"vat_request_success\": 0\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/orders/:parent_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'entity' => [
        'address_type' => '',
        'city' => '',
        'company' => '',
        'country_id' => '',
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'entity_id' => 0,
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ]
        ],
        'fax' => '',
        'firstname' => '',
        'lastname' => '',
        'middlename' => '',
        'parent_id' => 0,
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => '',
        'vat_is_valid' => 0,
        'vat_request_date' => '',
        'vat_request_id' => '',
        'vat_request_success' => 0
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/orders/:parent_id', [
  'body' => '{
  "entity": {
    "address_type": "",
    "city": "",
    "company": "",
    "country_id": "",
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "entity_id": 0,
    "extension_attributes": {
      "checkout_fields": [
        {
          "attribute_code": "",
          "value": ""
        }
      ]
    },
    "fax": "",
    "firstname": "",
    "lastname": "",
    "middlename": "",
    "parent_id": 0,
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": "",
    "vat_is_valid": 0,
    "vat_request_date": "",
    "vat_request_id": "",
    "vat_request_success": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/orders/:parent_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'entity' => [
    'address_type' => '',
    'city' => '',
    'company' => '',
    'country_id' => '',
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ]
    ],
    'fax' => '',
    'firstname' => '',
    'lastname' => '',
    'middlename' => '',
    'parent_id' => 0,
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => '',
    'vat_is_valid' => 0,
    'vat_request_date' => '',
    'vat_request_id' => '',
    'vat_request_success' => 0
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'entity' => [
    'address_type' => '',
    'city' => '',
    'company' => '',
    'country_id' => '',
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ]
    ],
    'fax' => '',
    'firstname' => '',
    'lastname' => '',
    'middlename' => '',
    'parent_id' => 0,
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => '',
    'vat_is_valid' => 0,
    'vat_request_date' => '',
    'vat_request_id' => '',
    'vat_request_success' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/orders/:parent_id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/orders/:parent_id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "address_type": "",
    "city": "",
    "company": "",
    "country_id": "",
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "entity_id": 0,
    "extension_attributes": {
      "checkout_fields": [
        {
          "attribute_code": "",
          "value": ""
        }
      ]
    },
    "fax": "",
    "firstname": "",
    "lastname": "",
    "middlename": "",
    "parent_id": 0,
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": "",
    "vat_is_valid": 0,
    "vat_request_date": "",
    "vat_request_id": "",
    "vat_request_success": 0
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/orders/:parent_id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "address_type": "",
    "city": "",
    "company": "",
    "country_id": "",
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "entity_id": 0,
    "extension_attributes": {
      "checkout_fields": [
        {
          "attribute_code": "",
          "value": ""
        }
      ]
    },
    "fax": "",
    "firstname": "",
    "lastname": "",
    "middlename": "",
    "parent_id": 0,
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": "",
    "vat_is_valid": 0,
    "vat_request_date": "",
    "vat_request_id": "",
    "vat_request_success": 0
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"entity\": {\n    \"address_type\": \"\",\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ]\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"parent_id\": 0,\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\",\n    \"vat_is_valid\": 0,\n    \"vat_request_date\": \"\",\n    \"vat_request_id\": \"\",\n    \"vat_request_success\": 0\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/orders/:parent_id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/orders/:parent_id"

payload = { "entity": {
        "address_type": "",
        "city": "",
        "company": "",
        "country_id": "",
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "entity_id": 0,
        "extension_attributes": { "checkout_fields": [
                {
                    "attribute_code": "",
                    "value": ""
                }
            ] },
        "fax": "",
        "firstname": "",
        "lastname": "",
        "middlename": "",
        "parent_id": 0,
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": "",
        "vat_is_valid": 0,
        "vat_request_date": "",
        "vat_request_id": "",
        "vat_request_success": 0
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/orders/:parent_id"

payload <- "{\n  \"entity\": {\n    \"address_type\": \"\",\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ]\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"parent_id\": 0,\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\",\n    \"vat_is_valid\": 0,\n    \"vat_request_date\": \"\",\n    \"vat_request_id\": \"\",\n    \"vat_request_success\": 0\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/orders/:parent_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"entity\": {\n    \"address_type\": \"\",\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ]\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"parent_id\": 0,\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\",\n    \"vat_is_valid\": 0,\n    \"vat_request_date\": \"\",\n    \"vat_request_id\": \"\",\n    \"vat_request_success\": 0\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/V1/orders/:parent_id') do |req|
  req.body = "{\n  \"entity\": {\n    \"address_type\": \"\",\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ]\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"parent_id\": 0,\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\",\n    \"vat_is_valid\": 0,\n    \"vat_request_date\": \"\",\n    \"vat_request_id\": \"\",\n    \"vat_request_success\": 0\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}}/V1/orders/:parent_id";

    let payload = json!({"entity": json!({
            "address_type": "",
            "city": "",
            "company": "",
            "country_id": "",
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "entity_id": 0,
            "extension_attributes": json!({"checkout_fields": (
                    json!({
                        "attribute_code": "",
                        "value": ""
                    })
                )}),
            "fax": "",
            "firstname": "",
            "lastname": "",
            "middlename": "",
            "parent_id": 0,
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "street": (),
            "suffix": "",
            "telephone": "",
            "vat_id": "",
            "vat_is_valid": 0,
            "vat_request_date": "",
            "vat_request_id": "",
            "vat_request_success": 0
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/orders/:parent_id \
  --header 'content-type: application/json' \
  --data '{
  "entity": {
    "address_type": "",
    "city": "",
    "company": "",
    "country_id": "",
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "entity_id": 0,
    "extension_attributes": {
      "checkout_fields": [
        {
          "attribute_code": "",
          "value": ""
        }
      ]
    },
    "fax": "",
    "firstname": "",
    "lastname": "",
    "middlename": "",
    "parent_id": 0,
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": "",
    "vat_is_valid": 0,
    "vat_request_date": "",
    "vat_request_id": "",
    "vat_request_success": 0
  }
}'
echo '{
  "entity": {
    "address_type": "",
    "city": "",
    "company": "",
    "country_id": "",
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "entity_id": 0,
    "extension_attributes": {
      "checkout_fields": [
        {
          "attribute_code": "",
          "value": ""
        }
      ]
    },
    "fax": "",
    "firstname": "",
    "lastname": "",
    "middlename": "",
    "parent_id": 0,
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": "",
    "vat_is_valid": 0,
    "vat_request_date": "",
    "vat_request_id": "",
    "vat_request_success": 0
  }
}' |  \
  http PUT {{baseUrl}}/V1/orders/:parent_id \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "entity": {\n    "address_type": "",\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "entity_id": 0,\n    "extension_attributes": {\n      "checkout_fields": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ]\n    },\n    "fax": "",\n    "firstname": "",\n    "lastname": "",\n    "middlename": "",\n    "parent_id": 0,\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": "",\n    "vat_is_valid": 0,\n    "vat_request_date": "",\n    "vat_request_id": "",\n    "vat_request_success": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/orders/:parent_id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["entity": [
    "address_type": "",
    "city": "",
    "company": "",
    "country_id": "",
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "entity_id": 0,
    "extension_attributes": ["checkout_fields": [
        [
          "attribute_code": "",
          "value": ""
        ]
      ]],
    "fax": "",
    "firstname": "",
    "lastname": "",
    "middlename": "",
    "parent_id": 0,
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": "",
    "vat_is_valid": 0,
    "vat_request_date": "",
    "vat_request_id": "",
    "vat_request_success": 0
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/orders/:parent_id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT orders-create
{{baseUrl}}/V1/orders/create
BODY json

{
  "entity": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "applied_rule_ids": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_canceled": "",
    "base_discount_invoiced": "",
    "base_discount_refunded": "",
    "base_discount_tax_compensation_amount": "",
    "base_discount_tax_compensation_invoiced": "",
    "base_discount_tax_compensation_refunded": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_canceled": "",
    "base_shipping_discount_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_invoiced": "",
    "base_shipping_refunded": "",
    "base_shipping_tax_amount": "",
    "base_shipping_tax_refunded": "",
    "base_subtotal": "",
    "base_subtotal_canceled": "",
    "base_subtotal_incl_tax": "",
    "base_subtotal_invoiced": "",
    "base_subtotal_refunded": "",
    "base_tax_amount": "",
    "base_tax_canceled": "",
    "base_tax_invoiced": "",
    "base_tax_refunded": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_canceled": "",
    "base_total_due": "",
    "base_total_invoiced": "",
    "base_total_invoiced_cost": "",
    "base_total_offline_refunded": "",
    "base_total_online_refunded": "",
    "base_total_paid": "",
    "base_total_qty_ordered": "",
    "base_total_refunded": "",
    "billing_address": {
      "address_type": "",
      "city": "",
      "company": "",
      "country_id": "",
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "entity_id": 0,
      "extension_attributes": {
        "checkout_fields": [
          {
            "attribute_code": "",
            "value": ""
          }
        ]
      },
      "fax": "",
      "firstname": "",
      "lastname": "",
      "middlename": "",
      "parent_id": 0,
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": "",
      "vat_is_valid": 0,
      "vat_request_date": "",
      "vat_request_id": "",
      "vat_request_success": 0
    },
    "billing_address_id": 0,
    "can_ship_partially": 0,
    "can_ship_partially_item": 0,
    "coupon_code": "",
    "created_at": "",
    "customer_dob": "",
    "customer_email": "",
    "customer_firstname": "",
    "customer_gender": 0,
    "customer_group_id": 0,
    "customer_id": 0,
    "customer_is_guest": 0,
    "customer_lastname": "",
    "customer_middlename": "",
    "customer_note": "",
    "customer_note_notify": 0,
    "customer_prefix": "",
    "customer_suffix": "",
    "customer_taxvat": "",
    "discount_amount": "",
    "discount_canceled": "",
    "discount_description": "",
    "discount_invoiced": "",
    "discount_refunded": "",
    "discount_tax_compensation_amount": "",
    "discount_tax_compensation_invoiced": "",
    "discount_tax_compensation_refunded": "",
    "edit_increment": 0,
    "email_sent": 0,
    "entity_id": 0,
    "ext_customer_id": "",
    "ext_order_id": "",
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "applied_taxes": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "extension_attributes": {
            "rates": [
              {
                "code": "",
                "extension_attributes": {},
                "percent": "",
                "title": ""
              }
            ]
          },
          "percent": "",
          "title": ""
        }
      ],
      "base_customer_balance_amount": "",
      "base_customer_balance_invoiced": "",
      "base_customer_balance_refunded": "",
      "base_customer_balance_total_refunded": "",
      "base_gift_cards_amount": "",
      "base_gift_cards_invoiced": "",
      "base_gift_cards_refunded": "",
      "base_reward_currency_amount": "",
      "company_order_attributes": {
        "company_id": 0,
        "company_name": "",
        "extension_attributes": {},
        "order_id": 0
      },
      "converting_from_quote": false,
      "customer_balance_amount": "",
      "customer_balance_invoiced": "",
      "customer_balance_refunded": "",
      "customer_balance_total_refunded": "",
      "gift_cards": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "id": 0
        }
      ],
      "gift_cards_amount": "",
      "gift_cards_invoiced": "",
      "gift_cards_refunded": "",
      "gift_message": {
        "customer_id": 0,
        "extension_attributes": {
          "entity_id": "",
          "entity_type": "",
          "wrapping_add_printed_card": false,
          "wrapping_allow_gift_receipt": false,
          "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
      },
      "gw_add_card": "",
      "gw_allow_gift_receipt": "",
      "gw_base_price": "",
      "gw_base_price_incl_tax": "",
      "gw_base_price_invoiced": "",
      "gw_base_price_refunded": "",
      "gw_base_tax_amount": "",
      "gw_base_tax_amount_invoiced": "",
      "gw_base_tax_amount_refunded": "",
      "gw_card_base_price": "",
      "gw_card_base_price_incl_tax": "",
      "gw_card_base_price_invoiced": "",
      "gw_card_base_price_refunded": "",
      "gw_card_base_tax_amount": "",
      "gw_card_base_tax_invoiced": "",
      "gw_card_base_tax_refunded": "",
      "gw_card_price": "",
      "gw_card_price_incl_tax": "",
      "gw_card_price_invoiced": "",
      "gw_card_price_refunded": "",
      "gw_card_tax_amount": "",
      "gw_card_tax_invoiced": "",
      "gw_card_tax_refunded": "",
      "gw_id": "",
      "gw_items_base_price": "",
      "gw_items_base_price_incl_tax": "",
      "gw_items_base_price_invoiced": "",
      "gw_items_base_price_refunded": "",
      "gw_items_base_tax_amount": "",
      "gw_items_base_tax_invoiced": "",
      "gw_items_base_tax_refunded": "",
      "gw_items_price": "",
      "gw_items_price_incl_tax": "",
      "gw_items_price_invoiced": "",
      "gw_items_price_refunded": "",
      "gw_items_tax_amount": "",
      "gw_items_tax_invoiced": "",
      "gw_items_tax_refunded": "",
      "gw_price": "",
      "gw_price_incl_tax": "",
      "gw_price_invoiced": "",
      "gw_price_refunded": "",
      "gw_tax_amount": "",
      "gw_tax_amount_invoiced": "",
      "gw_tax_amount_refunded": "",
      "item_applied_taxes": [
        {
          "applied_taxes": [
            {}
          ],
          "associated_item_id": 0,
          "extension_attributes": {},
          "item_id": 0,
          "type": ""
        }
      ],
      "payment_additional_info": [
        {
          "key": "",
          "value": ""
        }
      ],
      "reward_currency_amount": "",
      "reward_points_balance": 0,
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "additional_data": "",
              "amount_refunded": "",
              "applied_rule_ids": "",
              "base_amount_refunded": "",
              "base_cost": "",
              "base_discount_amount": "",
              "base_discount_invoiced": "",
              "base_discount_refunded": "",
              "base_discount_tax_compensation_amount": "",
              "base_discount_tax_compensation_invoiced": "",
              "base_discount_tax_compensation_refunded": "",
              "base_original_price": "",
              "base_price": "",
              "base_price_incl_tax": "",
              "base_row_invoiced": "",
              "base_row_total": "",
              "base_row_total_incl_tax": "",
              "base_tax_amount": "",
              "base_tax_before_discount": "",
              "base_tax_invoiced": "",
              "base_tax_refunded": "",
              "base_weee_tax_applied_amount": "",
              "base_weee_tax_applied_row_amnt": "",
              "base_weee_tax_disposition": "",
              "base_weee_tax_row_disposition": "",
              "created_at": "",
              "description": "",
              "discount_amount": "",
              "discount_invoiced": "",
              "discount_percent": "",
              "discount_refunded": "",
              "discount_tax_compensation_amount": "",
              "discount_tax_compensation_canceled": "",
              "discount_tax_compensation_invoiced": "",
              "discount_tax_compensation_refunded": "",
              "event_id": 0,
              "ext_order_item_id": "",
              "extension_attributes": {
                "gift_message": {},
                "gw_base_price": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_id": "",
                "gw_price": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "invoice_text_codes": [],
                "tax_codes": [],
                "vertex_tax_codes": []
              },
              "free_shipping": 0,
              "gw_base_price": "",
              "gw_base_price_invoiced": "",
              "gw_base_price_refunded": "",
              "gw_base_tax_amount": "",
              "gw_base_tax_amount_invoiced": "",
              "gw_base_tax_amount_refunded": "",
              "gw_id": 0,
              "gw_price": "",
              "gw_price_invoiced": "",
              "gw_price_refunded": "",
              "gw_tax_amount": "",
              "gw_tax_amount_invoiced": "",
              "gw_tax_amount_refunded": "",
              "is_qty_decimal": 0,
              "is_virtual": 0,
              "item_id": 0,
              "locked_do_invoice": 0,
              "locked_do_ship": 0,
              "name": "",
              "no_discount": 0,
              "order_id": 0,
              "original_price": "",
              "parent_item": "",
              "parent_item_id": 0,
              "price": "",
              "price_incl_tax": "",
              "product_id": 0,
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty_backordered": "",
              "qty_canceled": "",
              "qty_invoiced": "",
              "qty_ordered": "",
              "qty_refunded": "",
              "qty_returned": "",
              "qty_shipped": "",
              "quote_item_id": 0,
              "row_invoiced": "",
              "row_total": "",
              "row_total_incl_tax": "",
              "row_weight": "",
              "sku": "",
              "store_id": 0,
              "tax_amount": "",
              "tax_before_discount": "",
              "tax_canceled": "",
              "tax_invoiced": "",
              "tax_percent": "",
              "tax_refunded": "",
              "updated_at": "",
              "weee_tax_applied": "",
              "weee_tax_applied_amount": "",
              "weee_tax_applied_row_amount": "",
              "weee_tax_disposition": "",
              "weee_tax_row_disposition": "",
              "weight": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {
              "collection_point": {
                "city": "",
                "collection_point_id": "",
                "country": "",
                "name": "",
                "postcode": "",
                "recipient_address_id": 0,
                "region": "",
                "street": []
              },
              "ext_order_id": "",
              "shipping_experience": {
                "code": "",
                "cost": "",
                "label": ""
              }
            },
            "method": "",
            "total": {
              "base_shipping_amount": "",
              "base_shipping_canceled": "",
              "base_shipping_discount_amount": "",
              "base_shipping_discount_tax_compensation_amnt": "",
              "base_shipping_incl_tax": "",
              "base_shipping_invoiced": "",
              "base_shipping_refunded": "",
              "base_shipping_tax_amount": "",
              "base_shipping_tax_refunded": "",
              "extension_attributes": {},
              "shipping_amount": "",
              "shipping_canceled": "",
              "shipping_discount_amount": "",
              "shipping_discount_tax_compensation_amount": "",
              "shipping_incl_tax": "",
              "shipping_invoiced": "",
              "shipping_refunded": "",
              "shipping_tax_amount": "",
              "shipping_tax_refunded": ""
            }
          },
          "stock_id": 0
        }
      ]
    },
    "forced_shipment_with_invoice": 0,
    "global_currency_code": "",
    "grand_total": "",
    "hold_before_state": "",
    "hold_before_status": "",
    "increment_id": "",
    "is_virtual": 0,
    "items": [
      {}
    ],
    "order_currency_code": "",
    "original_increment_id": "",
    "payment": {
      "account_status": "",
      "additional_data": "",
      "additional_information": [],
      "address_status": "",
      "amount_authorized": "",
      "amount_canceled": "",
      "amount_ordered": "",
      "amount_paid": "",
      "amount_refunded": "",
      "anet_trans_method": "",
      "base_amount_authorized": "",
      "base_amount_canceled": "",
      "base_amount_ordered": "",
      "base_amount_paid": "",
      "base_amount_paid_online": "",
      "base_amount_refunded": "",
      "base_amount_refunded_online": "",
      "base_shipping_amount": "",
      "base_shipping_captured": "",
      "base_shipping_refunded": "",
      "cc_approval": "",
      "cc_avs_status": "",
      "cc_cid_status": "",
      "cc_debug_request_body": "",
      "cc_debug_response_body": "",
      "cc_debug_response_serialized": "",
      "cc_exp_month": "",
      "cc_exp_year": "",
      "cc_last4": "",
      "cc_number_enc": "",
      "cc_owner": "",
      "cc_secure_verify": "",
      "cc_ss_issue": "",
      "cc_ss_start_month": "",
      "cc_ss_start_year": "",
      "cc_status": "",
      "cc_status_description": "",
      "cc_trans_id": "",
      "cc_type": "",
      "echeck_account_name": "",
      "echeck_account_type": "",
      "echeck_bank_name": "",
      "echeck_routing_number": "",
      "echeck_type": "",
      "entity_id": 0,
      "extension_attributes": {
        "vault_payment_token": {
          "created_at": "",
          "customer_id": 0,
          "entity_id": 0,
          "expires_at": "",
          "gateway_token": "",
          "is_active": false,
          "is_visible": false,
          "payment_method_code": "",
          "public_hash": "",
          "token_details": "",
          "type": ""
        }
      },
      "last_trans_id": "",
      "method": "",
      "parent_id": 0,
      "po_number": "",
      "protection_eligibility": "",
      "quote_payment_id": 0,
      "shipping_amount": "",
      "shipping_captured": "",
      "shipping_refunded": ""
    },
    "payment_auth_expiration": 0,
    "payment_authorization_amount": "",
    "protect_code": "",
    "quote_address_id": 0,
    "quote_id": 0,
    "relation_child_id": "",
    "relation_child_real_id": "",
    "relation_parent_id": "",
    "relation_parent_real_id": "",
    "remote_ip": "",
    "shipping_amount": "",
    "shipping_canceled": "",
    "shipping_description": "",
    "shipping_discount_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_invoiced": "",
    "shipping_refunded": "",
    "shipping_tax_amount": "",
    "shipping_tax_refunded": "",
    "state": "",
    "status": "",
    "status_histories": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "entity_name": "",
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0,
        "status": ""
      }
    ],
    "store_currency_code": "",
    "store_id": 0,
    "store_name": "",
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_canceled": "",
    "subtotal_incl_tax": "",
    "subtotal_invoiced": "",
    "subtotal_refunded": "",
    "tax_amount": "",
    "tax_canceled": "",
    "tax_invoiced": "",
    "tax_refunded": "",
    "total_canceled": "",
    "total_due": "",
    "total_invoiced": "",
    "total_item_count": 0,
    "total_offline_refunded": "",
    "total_online_refunded": "",
    "total_paid": "",
    "total_qty_ordered": "",
    "total_refunded": "",
    "updated_at": "",
    "weight": "",
    "x_forwarded_for": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/orders/create");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/orders/create" {:content-type :json
                                                            :form-params {:entity {:adjustment_negative ""
                                                                                   :adjustment_positive ""
                                                                                   :applied_rule_ids ""
                                                                                   :base_adjustment_negative ""
                                                                                   :base_adjustment_positive ""
                                                                                   :base_currency_code ""
                                                                                   :base_discount_amount ""
                                                                                   :base_discount_canceled ""
                                                                                   :base_discount_invoiced ""
                                                                                   :base_discount_refunded ""
                                                                                   :base_discount_tax_compensation_amount ""
                                                                                   :base_discount_tax_compensation_invoiced ""
                                                                                   :base_discount_tax_compensation_refunded ""
                                                                                   :base_grand_total ""
                                                                                   :base_shipping_amount ""
                                                                                   :base_shipping_canceled ""
                                                                                   :base_shipping_discount_amount ""
                                                                                   :base_shipping_discount_tax_compensation_amnt ""
                                                                                   :base_shipping_incl_tax ""
                                                                                   :base_shipping_invoiced ""
                                                                                   :base_shipping_refunded ""
                                                                                   :base_shipping_tax_amount ""
                                                                                   :base_shipping_tax_refunded ""
                                                                                   :base_subtotal ""
                                                                                   :base_subtotal_canceled ""
                                                                                   :base_subtotal_incl_tax ""
                                                                                   :base_subtotal_invoiced ""
                                                                                   :base_subtotal_refunded ""
                                                                                   :base_tax_amount ""
                                                                                   :base_tax_canceled ""
                                                                                   :base_tax_invoiced ""
                                                                                   :base_tax_refunded ""
                                                                                   :base_to_global_rate ""
                                                                                   :base_to_order_rate ""
                                                                                   :base_total_canceled ""
                                                                                   :base_total_due ""
                                                                                   :base_total_invoiced ""
                                                                                   :base_total_invoiced_cost ""
                                                                                   :base_total_offline_refunded ""
                                                                                   :base_total_online_refunded ""
                                                                                   :base_total_paid ""
                                                                                   :base_total_qty_ordered ""
                                                                                   :base_total_refunded ""
                                                                                   :billing_address {:address_type ""
                                                                                                     :city ""
                                                                                                     :company ""
                                                                                                     :country_id ""
                                                                                                     :customer_address_id 0
                                                                                                     :customer_id 0
                                                                                                     :email ""
                                                                                                     :entity_id 0
                                                                                                     :extension_attributes {:checkout_fields [{:attribute_code ""
                                                                                                                                               :value ""}]}
                                                                                                     :fax ""
                                                                                                     :firstname ""
                                                                                                     :lastname ""
                                                                                                     :middlename ""
                                                                                                     :parent_id 0
                                                                                                     :postcode ""
                                                                                                     :prefix ""
                                                                                                     :region ""
                                                                                                     :region_code ""
                                                                                                     :region_id 0
                                                                                                     :street []
                                                                                                     :suffix ""
                                                                                                     :telephone ""
                                                                                                     :vat_id ""
                                                                                                     :vat_is_valid 0
                                                                                                     :vat_request_date ""
                                                                                                     :vat_request_id ""
                                                                                                     :vat_request_success 0}
                                                                                   :billing_address_id 0
                                                                                   :can_ship_partially 0
                                                                                   :can_ship_partially_item 0
                                                                                   :coupon_code ""
                                                                                   :created_at ""
                                                                                   :customer_dob ""
                                                                                   :customer_email ""
                                                                                   :customer_firstname ""
                                                                                   :customer_gender 0
                                                                                   :customer_group_id 0
                                                                                   :customer_id 0
                                                                                   :customer_is_guest 0
                                                                                   :customer_lastname ""
                                                                                   :customer_middlename ""
                                                                                   :customer_note ""
                                                                                   :customer_note_notify 0
                                                                                   :customer_prefix ""
                                                                                   :customer_suffix ""
                                                                                   :customer_taxvat ""
                                                                                   :discount_amount ""
                                                                                   :discount_canceled ""
                                                                                   :discount_description ""
                                                                                   :discount_invoiced ""
                                                                                   :discount_refunded ""
                                                                                   :discount_tax_compensation_amount ""
                                                                                   :discount_tax_compensation_invoiced ""
                                                                                   :discount_tax_compensation_refunded ""
                                                                                   :edit_increment 0
                                                                                   :email_sent 0
                                                                                   :entity_id 0
                                                                                   :ext_customer_id ""
                                                                                   :ext_order_id ""
                                                                                   :extension_attributes {:amazon_order_reference_id ""
                                                                                                          :applied_taxes [{:amount ""
                                                                                                                           :base_amount ""
                                                                                                                           :code ""
                                                                                                                           :extension_attributes {:rates [{:code ""
                                                                                                                                                           :extension_attributes {}
                                                                                                                                                           :percent ""
                                                                                                                                                           :title ""}]}
                                                                                                                           :percent ""
                                                                                                                           :title ""}]
                                                                                                          :base_customer_balance_amount ""
                                                                                                          :base_customer_balance_invoiced ""
                                                                                                          :base_customer_balance_refunded ""
                                                                                                          :base_customer_balance_total_refunded ""
                                                                                                          :base_gift_cards_amount ""
                                                                                                          :base_gift_cards_invoiced ""
                                                                                                          :base_gift_cards_refunded ""
                                                                                                          :base_reward_currency_amount ""
                                                                                                          :company_order_attributes {:company_id 0
                                                                                                                                     :company_name ""
                                                                                                                                     :extension_attributes {}
                                                                                                                                     :order_id 0}
                                                                                                          :converting_from_quote false
                                                                                                          :customer_balance_amount ""
                                                                                                          :customer_balance_invoiced ""
                                                                                                          :customer_balance_refunded ""
                                                                                                          :customer_balance_total_refunded ""
                                                                                                          :gift_cards [{:amount ""
                                                                                                                        :base_amount ""
                                                                                                                        :code ""
                                                                                                                        :id 0}]
                                                                                                          :gift_cards_amount ""
                                                                                                          :gift_cards_invoiced ""
                                                                                                          :gift_cards_refunded ""
                                                                                                          :gift_message {:customer_id 0
                                                                                                                         :extension_attributes {:entity_id ""
                                                                                                                                                :entity_type ""
                                                                                                                                                :wrapping_add_printed_card false
                                                                                                                                                :wrapping_allow_gift_receipt false
                                                                                                                                                :wrapping_id 0}
                                                                                                                         :gift_message_id 0
                                                                                                                         :message ""
                                                                                                                         :recipient ""
                                                                                                                         :sender ""}
                                                                                                          :gw_add_card ""
                                                                                                          :gw_allow_gift_receipt ""
                                                                                                          :gw_base_price ""
                                                                                                          :gw_base_price_incl_tax ""
                                                                                                          :gw_base_price_invoiced ""
                                                                                                          :gw_base_price_refunded ""
                                                                                                          :gw_base_tax_amount ""
                                                                                                          :gw_base_tax_amount_invoiced ""
                                                                                                          :gw_base_tax_amount_refunded ""
                                                                                                          :gw_card_base_price ""
                                                                                                          :gw_card_base_price_incl_tax ""
                                                                                                          :gw_card_base_price_invoiced ""
                                                                                                          :gw_card_base_price_refunded ""
                                                                                                          :gw_card_base_tax_amount ""
                                                                                                          :gw_card_base_tax_invoiced ""
                                                                                                          :gw_card_base_tax_refunded ""
                                                                                                          :gw_card_price ""
                                                                                                          :gw_card_price_incl_tax ""
                                                                                                          :gw_card_price_invoiced ""
                                                                                                          :gw_card_price_refunded ""
                                                                                                          :gw_card_tax_amount ""
                                                                                                          :gw_card_tax_invoiced ""
                                                                                                          :gw_card_tax_refunded ""
                                                                                                          :gw_id ""
                                                                                                          :gw_items_base_price ""
                                                                                                          :gw_items_base_price_incl_tax ""
                                                                                                          :gw_items_base_price_invoiced ""
                                                                                                          :gw_items_base_price_refunded ""
                                                                                                          :gw_items_base_tax_amount ""
                                                                                                          :gw_items_base_tax_invoiced ""
                                                                                                          :gw_items_base_tax_refunded ""
                                                                                                          :gw_items_price ""
                                                                                                          :gw_items_price_incl_tax ""
                                                                                                          :gw_items_price_invoiced ""
                                                                                                          :gw_items_price_refunded ""
                                                                                                          :gw_items_tax_amount ""
                                                                                                          :gw_items_tax_invoiced ""
                                                                                                          :gw_items_tax_refunded ""
                                                                                                          :gw_price ""
                                                                                                          :gw_price_incl_tax ""
                                                                                                          :gw_price_invoiced ""
                                                                                                          :gw_price_refunded ""
                                                                                                          :gw_tax_amount ""
                                                                                                          :gw_tax_amount_invoiced ""
                                                                                                          :gw_tax_amount_refunded ""
                                                                                                          :item_applied_taxes [{:applied_taxes [{}]
                                                                                                                                :associated_item_id 0
                                                                                                                                :extension_attributes {}
                                                                                                                                :item_id 0
                                                                                                                                :type ""}]
                                                                                                          :payment_additional_info [{:key ""
                                                                                                                                     :value ""}]
                                                                                                          :reward_currency_amount ""
                                                                                                          :reward_points_balance 0
                                                                                                          :shipping_assignments [{:extension_attributes {}
                                                                                                                                  :items [{:additional_data ""
                                                                                                                                           :amount_refunded ""
                                                                                                                                           :applied_rule_ids ""
                                                                                                                                           :base_amount_refunded ""
                                                                                                                                           :base_cost ""
                                                                                                                                           :base_discount_amount ""
                                                                                                                                           :base_discount_invoiced ""
                                                                                                                                           :base_discount_refunded ""
                                                                                                                                           :base_discount_tax_compensation_amount ""
                                                                                                                                           :base_discount_tax_compensation_invoiced ""
                                                                                                                                           :base_discount_tax_compensation_refunded ""
                                                                                                                                           :base_original_price ""
                                                                                                                                           :base_price ""
                                                                                                                                           :base_price_incl_tax ""
                                                                                                                                           :base_row_invoiced ""
                                                                                                                                           :base_row_total ""
                                                                                                                                           :base_row_total_incl_tax ""
                                                                                                                                           :base_tax_amount ""
                                                                                                                                           :base_tax_before_discount ""
                                                                                                                                           :base_tax_invoiced ""
                                                                                                                                           :base_tax_refunded ""
                                                                                                                                           :base_weee_tax_applied_amount ""
                                                                                                                                           :base_weee_tax_applied_row_amnt ""
                                                                                                                                           :base_weee_tax_disposition ""
                                                                                                                                           :base_weee_tax_row_disposition ""
                                                                                                                                           :created_at ""
                                                                                                                                           :description ""
                                                                                                                                           :discount_amount ""
                                                                                                                                           :discount_invoiced ""
                                                                                                                                           :discount_percent ""
                                                                                                                                           :discount_refunded ""
                                                                                                                                           :discount_tax_compensation_amount ""
                                                                                                                                           :discount_tax_compensation_canceled ""
                                                                                                                                           :discount_tax_compensation_invoiced ""
                                                                                                                                           :discount_tax_compensation_refunded ""
                                                                                                                                           :event_id 0
                                                                                                                                           :ext_order_item_id ""
                                                                                                                                           :extension_attributes {:gift_message {}
                                                                                                                                                                  :gw_base_price ""
                                                                                                                                                                  :gw_base_price_invoiced ""
                                                                                                                                                                  :gw_base_price_refunded ""
                                                                                                                                                                  :gw_base_tax_amount ""
                                                                                                                                                                  :gw_base_tax_amount_invoiced ""
                                                                                                                                                                  :gw_base_tax_amount_refunded ""
                                                                                                                                                                  :gw_id ""
                                                                                                                                                                  :gw_price ""
                                                                                                                                                                  :gw_price_invoiced ""
                                                                                                                                                                  :gw_price_refunded ""
                                                                                                                                                                  :gw_tax_amount ""
                                                                                                                                                                  :gw_tax_amount_invoiced ""
                                                                                                                                                                  :gw_tax_amount_refunded ""
                                                                                                                                                                  :invoice_text_codes []
                                                                                                                                                                  :tax_codes []
                                                                                                                                                                  :vertex_tax_codes []}
                                                                                                                                           :free_shipping 0
                                                                                                                                           :gw_base_price ""
                                                                                                                                           :gw_base_price_invoiced ""
                                                                                                                                           :gw_base_price_refunded ""
                                                                                                                                           :gw_base_tax_amount ""
                                                                                                                                           :gw_base_tax_amount_invoiced ""
                                                                                                                                           :gw_base_tax_amount_refunded ""
                                                                                                                                           :gw_id 0
                                                                                                                                           :gw_price ""
                                                                                                                                           :gw_price_invoiced ""
                                                                                                                                           :gw_price_refunded ""
                                                                                                                                           :gw_tax_amount ""
                                                                                                                                           :gw_tax_amount_invoiced ""
                                                                                                                                           :gw_tax_amount_refunded ""
                                                                                                                                           :is_qty_decimal 0
                                                                                                                                           :is_virtual 0
                                                                                                                                           :item_id 0
                                                                                                                                           :locked_do_invoice 0
                                                                                                                                           :locked_do_ship 0
                                                                                                                                           :name ""
                                                                                                                                           :no_discount 0
                                                                                                                                           :order_id 0
                                                                                                                                           :original_price ""
                                                                                                                                           :parent_item ""
                                                                                                                                           :parent_item_id 0
                                                                                                                                           :price ""
                                                                                                                                           :price_incl_tax ""
                                                                                                                                           :product_id 0
                                                                                                                                           :product_option {:extension_attributes {:bundle_options [{:extension_attributes {}
                                                                                                                                                                                                     :option_id 0
                                                                                                                                                                                                     :option_qty 0
                                                                                                                                                                                                     :option_selections []}]
                                                                                                                                                                                   :configurable_item_options [{:extension_attributes {}
                                                                                                                                                                                                                :option_id ""
                                                                                                                                                                                                                :option_value 0}]
                                                                                                                                                                                   :custom_options [{:extension_attributes {:file_info {:base64_encoded_data ""
                                                                                                                                                                                                                                        :name ""
                                                                                                                                                                                                                                        :type ""}}
                                                                                                                                                                                                     :option_id ""
                                                                                                                                                                                                     :option_value ""}]
                                                                                                                                                                                   :downloadable_option {:downloadable_links []}
                                                                                                                                                                                   :giftcard_item_option {:custom_giftcard_amount ""
                                                                                                                                                                                                          :extension_attributes {}
                                                                                                                                                                                                          :giftcard_amount ""
                                                                                                                                                                                                          :giftcard_message ""
                                                                                                                                                                                                          :giftcard_recipient_email ""
                                                                                                                                                                                                          :giftcard_recipient_name ""
                                                                                                                                                                                                          :giftcard_sender_email ""
                                                                                                                                                                                                          :giftcard_sender_name ""}}}
                                                                                                                                           :product_type ""
                                                                                                                                           :qty_backordered ""
                                                                                                                                           :qty_canceled ""
                                                                                                                                           :qty_invoiced ""
                                                                                                                                           :qty_ordered ""
                                                                                                                                           :qty_refunded ""
                                                                                                                                           :qty_returned ""
                                                                                                                                           :qty_shipped ""
                                                                                                                                           :quote_item_id 0
                                                                                                                                           :row_invoiced ""
                                                                                                                                           :row_total ""
                                                                                                                                           :row_total_incl_tax ""
                                                                                                                                           :row_weight ""
                                                                                                                                           :sku ""
                                                                                                                                           :store_id 0
                                                                                                                                           :tax_amount ""
                                                                                                                                           :tax_before_discount ""
                                                                                                                                           :tax_canceled ""
                                                                                                                                           :tax_invoiced ""
                                                                                                                                           :tax_percent ""
                                                                                                                                           :tax_refunded ""
                                                                                                                                           :updated_at ""
                                                                                                                                           :weee_tax_applied ""
                                                                                                                                           :weee_tax_applied_amount ""
                                                                                                                                           :weee_tax_applied_row_amount ""
                                                                                                                                           :weee_tax_disposition ""
                                                                                                                                           :weee_tax_row_disposition ""
                                                                                                                                           :weight ""}]
                                                                                                                                  :shipping {:address {}
                                                                                                                                             :extension_attributes {:collection_point {:city ""
                                                                                                                                                                                       :collection_point_id ""
                                                                                                                                                                                       :country ""
                                                                                                                                                                                       :name ""
                                                                                                                                                                                       :postcode ""
                                                                                                                                                                                       :recipient_address_id 0
                                                                                                                                                                                       :region ""
                                                                                                                                                                                       :street []}
                                                                                                                                                                    :ext_order_id ""
                                                                                                                                                                    :shipping_experience {:code ""
                                                                                                                                                                                          :cost ""
                                                                                                                                                                                          :label ""}}
                                                                                                                                             :method ""
                                                                                                                                             :total {:base_shipping_amount ""
                                                                                                                                                     :base_shipping_canceled ""
                                                                                                                                                     :base_shipping_discount_amount ""
                                                                                                                                                     :base_shipping_discount_tax_compensation_amnt ""
                                                                                                                                                     :base_shipping_incl_tax ""
                                                                                                                                                     :base_shipping_invoiced ""
                                                                                                                                                     :base_shipping_refunded ""
                                                                                                                                                     :base_shipping_tax_amount ""
                                                                                                                                                     :base_shipping_tax_refunded ""
                                                                                                                                                     :extension_attributes {}
                                                                                                                                                     :shipping_amount ""
                                                                                                                                                     :shipping_canceled ""
                                                                                                                                                     :shipping_discount_amount ""
                                                                                                                                                     :shipping_discount_tax_compensation_amount ""
                                                                                                                                                     :shipping_incl_tax ""
                                                                                                                                                     :shipping_invoiced ""
                                                                                                                                                     :shipping_refunded ""
                                                                                                                                                     :shipping_tax_amount ""
                                                                                                                                                     :shipping_tax_refunded ""}}
                                                                                                                                  :stock_id 0}]}
                                                                                   :forced_shipment_with_invoice 0
                                                                                   :global_currency_code ""
                                                                                   :grand_total ""
                                                                                   :hold_before_state ""
                                                                                   :hold_before_status ""
                                                                                   :increment_id ""
                                                                                   :is_virtual 0
                                                                                   :items [{}]
                                                                                   :order_currency_code ""
                                                                                   :original_increment_id ""
                                                                                   :payment {:account_status ""
                                                                                             :additional_data ""
                                                                                             :additional_information []
                                                                                             :address_status ""
                                                                                             :amount_authorized ""
                                                                                             :amount_canceled ""
                                                                                             :amount_ordered ""
                                                                                             :amount_paid ""
                                                                                             :amount_refunded ""
                                                                                             :anet_trans_method ""
                                                                                             :base_amount_authorized ""
                                                                                             :base_amount_canceled ""
                                                                                             :base_amount_ordered ""
                                                                                             :base_amount_paid ""
                                                                                             :base_amount_paid_online ""
                                                                                             :base_amount_refunded ""
                                                                                             :base_amount_refunded_online ""
                                                                                             :base_shipping_amount ""
                                                                                             :base_shipping_captured ""
                                                                                             :base_shipping_refunded ""
                                                                                             :cc_approval ""
                                                                                             :cc_avs_status ""
                                                                                             :cc_cid_status ""
                                                                                             :cc_debug_request_body ""
                                                                                             :cc_debug_response_body ""
                                                                                             :cc_debug_response_serialized ""
                                                                                             :cc_exp_month ""
                                                                                             :cc_exp_year ""
                                                                                             :cc_last4 ""
                                                                                             :cc_number_enc ""
                                                                                             :cc_owner ""
                                                                                             :cc_secure_verify ""
                                                                                             :cc_ss_issue ""
                                                                                             :cc_ss_start_month ""
                                                                                             :cc_ss_start_year ""
                                                                                             :cc_status ""
                                                                                             :cc_status_description ""
                                                                                             :cc_trans_id ""
                                                                                             :cc_type ""
                                                                                             :echeck_account_name ""
                                                                                             :echeck_account_type ""
                                                                                             :echeck_bank_name ""
                                                                                             :echeck_routing_number ""
                                                                                             :echeck_type ""
                                                                                             :entity_id 0
                                                                                             :extension_attributes {:vault_payment_token {:created_at ""
                                                                                                                                          :customer_id 0
                                                                                                                                          :entity_id 0
                                                                                                                                          :expires_at ""
                                                                                                                                          :gateway_token ""
                                                                                                                                          :is_active false
                                                                                                                                          :is_visible false
                                                                                                                                          :payment_method_code ""
                                                                                                                                          :public_hash ""
                                                                                                                                          :token_details ""
                                                                                                                                          :type ""}}
                                                                                             :last_trans_id ""
                                                                                             :method ""
                                                                                             :parent_id 0
                                                                                             :po_number ""
                                                                                             :protection_eligibility ""
                                                                                             :quote_payment_id 0
                                                                                             :shipping_amount ""
                                                                                             :shipping_captured ""
                                                                                             :shipping_refunded ""}
                                                                                   :payment_auth_expiration 0
                                                                                   :payment_authorization_amount ""
                                                                                   :protect_code ""
                                                                                   :quote_address_id 0
                                                                                   :quote_id 0
                                                                                   :relation_child_id ""
                                                                                   :relation_child_real_id ""
                                                                                   :relation_parent_id ""
                                                                                   :relation_parent_real_id ""
                                                                                   :remote_ip ""
                                                                                   :shipping_amount ""
                                                                                   :shipping_canceled ""
                                                                                   :shipping_description ""
                                                                                   :shipping_discount_amount ""
                                                                                   :shipping_discount_tax_compensation_amount ""
                                                                                   :shipping_incl_tax ""
                                                                                   :shipping_invoiced ""
                                                                                   :shipping_refunded ""
                                                                                   :shipping_tax_amount ""
                                                                                   :shipping_tax_refunded ""
                                                                                   :state ""
                                                                                   :status ""
                                                                                   :status_histories [{:comment ""
                                                                                                       :created_at ""
                                                                                                       :entity_id 0
                                                                                                       :entity_name ""
                                                                                                       :extension_attributes {}
                                                                                                       :is_customer_notified 0
                                                                                                       :is_visible_on_front 0
                                                                                                       :parent_id 0
                                                                                                       :status ""}]
                                                                                   :store_currency_code ""
                                                                                   :store_id 0
                                                                                   :store_name ""
                                                                                   :store_to_base_rate ""
                                                                                   :store_to_order_rate ""
                                                                                   :subtotal ""
                                                                                   :subtotal_canceled ""
                                                                                   :subtotal_incl_tax ""
                                                                                   :subtotal_invoiced ""
                                                                                   :subtotal_refunded ""
                                                                                   :tax_amount ""
                                                                                   :tax_canceled ""
                                                                                   :tax_invoiced ""
                                                                                   :tax_refunded ""
                                                                                   :total_canceled ""
                                                                                   :total_due ""
                                                                                   :total_invoiced ""
                                                                                   :total_item_count 0
                                                                                   :total_offline_refunded ""
                                                                                   :total_online_refunded ""
                                                                                   :total_paid ""
                                                                                   :total_qty_ordered ""
                                                                                   :total_refunded ""
                                                                                   :updated_at ""
                                                                                   :weight ""
                                                                                   :x_forwarded_for ""}}})
require "http/client"

url = "{{baseUrl}}/V1/orders/create"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\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}}/V1/orders/create"),
    Content = new StringContent("{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\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}}/V1/orders/create");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/orders/create"

	payload := strings.NewReader("{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/orders/create HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 18630

{
  "entity": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "applied_rule_ids": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_canceled": "",
    "base_discount_invoiced": "",
    "base_discount_refunded": "",
    "base_discount_tax_compensation_amount": "",
    "base_discount_tax_compensation_invoiced": "",
    "base_discount_tax_compensation_refunded": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_canceled": "",
    "base_shipping_discount_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_invoiced": "",
    "base_shipping_refunded": "",
    "base_shipping_tax_amount": "",
    "base_shipping_tax_refunded": "",
    "base_subtotal": "",
    "base_subtotal_canceled": "",
    "base_subtotal_incl_tax": "",
    "base_subtotal_invoiced": "",
    "base_subtotal_refunded": "",
    "base_tax_amount": "",
    "base_tax_canceled": "",
    "base_tax_invoiced": "",
    "base_tax_refunded": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_canceled": "",
    "base_total_due": "",
    "base_total_invoiced": "",
    "base_total_invoiced_cost": "",
    "base_total_offline_refunded": "",
    "base_total_online_refunded": "",
    "base_total_paid": "",
    "base_total_qty_ordered": "",
    "base_total_refunded": "",
    "billing_address": {
      "address_type": "",
      "city": "",
      "company": "",
      "country_id": "",
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "entity_id": 0,
      "extension_attributes": {
        "checkout_fields": [
          {
            "attribute_code": "",
            "value": ""
          }
        ]
      },
      "fax": "",
      "firstname": "",
      "lastname": "",
      "middlename": "",
      "parent_id": 0,
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": "",
      "vat_is_valid": 0,
      "vat_request_date": "",
      "vat_request_id": "",
      "vat_request_success": 0
    },
    "billing_address_id": 0,
    "can_ship_partially": 0,
    "can_ship_partially_item": 0,
    "coupon_code": "",
    "created_at": "",
    "customer_dob": "",
    "customer_email": "",
    "customer_firstname": "",
    "customer_gender": 0,
    "customer_group_id": 0,
    "customer_id": 0,
    "customer_is_guest": 0,
    "customer_lastname": "",
    "customer_middlename": "",
    "customer_note": "",
    "customer_note_notify": 0,
    "customer_prefix": "",
    "customer_suffix": "",
    "customer_taxvat": "",
    "discount_amount": "",
    "discount_canceled": "",
    "discount_description": "",
    "discount_invoiced": "",
    "discount_refunded": "",
    "discount_tax_compensation_amount": "",
    "discount_tax_compensation_invoiced": "",
    "discount_tax_compensation_refunded": "",
    "edit_increment": 0,
    "email_sent": 0,
    "entity_id": 0,
    "ext_customer_id": "",
    "ext_order_id": "",
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "applied_taxes": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "extension_attributes": {
            "rates": [
              {
                "code": "",
                "extension_attributes": {},
                "percent": "",
                "title": ""
              }
            ]
          },
          "percent": "",
          "title": ""
        }
      ],
      "base_customer_balance_amount": "",
      "base_customer_balance_invoiced": "",
      "base_customer_balance_refunded": "",
      "base_customer_balance_total_refunded": "",
      "base_gift_cards_amount": "",
      "base_gift_cards_invoiced": "",
      "base_gift_cards_refunded": "",
      "base_reward_currency_amount": "",
      "company_order_attributes": {
        "company_id": 0,
        "company_name": "",
        "extension_attributes": {},
        "order_id": 0
      },
      "converting_from_quote": false,
      "customer_balance_amount": "",
      "customer_balance_invoiced": "",
      "customer_balance_refunded": "",
      "customer_balance_total_refunded": "",
      "gift_cards": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "id": 0
        }
      ],
      "gift_cards_amount": "",
      "gift_cards_invoiced": "",
      "gift_cards_refunded": "",
      "gift_message": {
        "customer_id": 0,
        "extension_attributes": {
          "entity_id": "",
          "entity_type": "",
          "wrapping_add_printed_card": false,
          "wrapping_allow_gift_receipt": false,
          "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
      },
      "gw_add_card": "",
      "gw_allow_gift_receipt": "",
      "gw_base_price": "",
      "gw_base_price_incl_tax": "",
      "gw_base_price_invoiced": "",
      "gw_base_price_refunded": "",
      "gw_base_tax_amount": "",
      "gw_base_tax_amount_invoiced": "",
      "gw_base_tax_amount_refunded": "",
      "gw_card_base_price": "",
      "gw_card_base_price_incl_tax": "",
      "gw_card_base_price_invoiced": "",
      "gw_card_base_price_refunded": "",
      "gw_card_base_tax_amount": "",
      "gw_card_base_tax_invoiced": "",
      "gw_card_base_tax_refunded": "",
      "gw_card_price": "",
      "gw_card_price_incl_tax": "",
      "gw_card_price_invoiced": "",
      "gw_card_price_refunded": "",
      "gw_card_tax_amount": "",
      "gw_card_tax_invoiced": "",
      "gw_card_tax_refunded": "",
      "gw_id": "",
      "gw_items_base_price": "",
      "gw_items_base_price_incl_tax": "",
      "gw_items_base_price_invoiced": "",
      "gw_items_base_price_refunded": "",
      "gw_items_base_tax_amount": "",
      "gw_items_base_tax_invoiced": "",
      "gw_items_base_tax_refunded": "",
      "gw_items_price": "",
      "gw_items_price_incl_tax": "",
      "gw_items_price_invoiced": "",
      "gw_items_price_refunded": "",
      "gw_items_tax_amount": "",
      "gw_items_tax_invoiced": "",
      "gw_items_tax_refunded": "",
      "gw_price": "",
      "gw_price_incl_tax": "",
      "gw_price_invoiced": "",
      "gw_price_refunded": "",
      "gw_tax_amount": "",
      "gw_tax_amount_invoiced": "",
      "gw_tax_amount_refunded": "",
      "item_applied_taxes": [
        {
          "applied_taxes": [
            {}
          ],
          "associated_item_id": 0,
          "extension_attributes": {},
          "item_id": 0,
          "type": ""
        }
      ],
      "payment_additional_info": [
        {
          "key": "",
          "value": ""
        }
      ],
      "reward_currency_amount": "",
      "reward_points_balance": 0,
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "additional_data": "",
              "amount_refunded": "",
              "applied_rule_ids": "",
              "base_amount_refunded": "",
              "base_cost": "",
              "base_discount_amount": "",
              "base_discount_invoiced": "",
              "base_discount_refunded": "",
              "base_discount_tax_compensation_amount": "",
              "base_discount_tax_compensation_invoiced": "",
              "base_discount_tax_compensation_refunded": "",
              "base_original_price": "",
              "base_price": "",
              "base_price_incl_tax": "",
              "base_row_invoiced": "",
              "base_row_total": "",
              "base_row_total_incl_tax": "",
              "base_tax_amount": "",
              "base_tax_before_discount": "",
              "base_tax_invoiced": "",
              "base_tax_refunded": "",
              "base_weee_tax_applied_amount": "",
              "base_weee_tax_applied_row_amnt": "",
              "base_weee_tax_disposition": "",
              "base_weee_tax_row_disposition": "",
              "created_at": "",
              "description": "",
              "discount_amount": "",
              "discount_invoiced": "",
              "discount_percent": "",
              "discount_refunded": "",
              "discount_tax_compensation_amount": "",
              "discount_tax_compensation_canceled": "",
              "discount_tax_compensation_invoiced": "",
              "discount_tax_compensation_refunded": "",
              "event_id": 0,
              "ext_order_item_id": "",
              "extension_attributes": {
                "gift_message": {},
                "gw_base_price": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_id": "",
                "gw_price": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "invoice_text_codes": [],
                "tax_codes": [],
                "vertex_tax_codes": []
              },
              "free_shipping": 0,
              "gw_base_price": "",
              "gw_base_price_invoiced": "",
              "gw_base_price_refunded": "",
              "gw_base_tax_amount": "",
              "gw_base_tax_amount_invoiced": "",
              "gw_base_tax_amount_refunded": "",
              "gw_id": 0,
              "gw_price": "",
              "gw_price_invoiced": "",
              "gw_price_refunded": "",
              "gw_tax_amount": "",
              "gw_tax_amount_invoiced": "",
              "gw_tax_amount_refunded": "",
              "is_qty_decimal": 0,
              "is_virtual": 0,
              "item_id": 0,
              "locked_do_invoice": 0,
              "locked_do_ship": 0,
              "name": "",
              "no_discount": 0,
              "order_id": 0,
              "original_price": "",
              "parent_item": "",
              "parent_item_id": 0,
              "price": "",
              "price_incl_tax": "",
              "product_id": 0,
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty_backordered": "",
              "qty_canceled": "",
              "qty_invoiced": "",
              "qty_ordered": "",
              "qty_refunded": "",
              "qty_returned": "",
              "qty_shipped": "",
              "quote_item_id": 0,
              "row_invoiced": "",
              "row_total": "",
              "row_total_incl_tax": "",
              "row_weight": "",
              "sku": "",
              "store_id": 0,
              "tax_amount": "",
              "tax_before_discount": "",
              "tax_canceled": "",
              "tax_invoiced": "",
              "tax_percent": "",
              "tax_refunded": "",
              "updated_at": "",
              "weee_tax_applied": "",
              "weee_tax_applied_amount": "",
              "weee_tax_applied_row_amount": "",
              "weee_tax_disposition": "",
              "weee_tax_row_disposition": "",
              "weight": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {
              "collection_point": {
                "city": "",
                "collection_point_id": "",
                "country": "",
                "name": "",
                "postcode": "",
                "recipient_address_id": 0,
                "region": "",
                "street": []
              },
              "ext_order_id": "",
              "shipping_experience": {
                "code": "",
                "cost": "",
                "label": ""
              }
            },
            "method": "",
            "total": {
              "base_shipping_amount": "",
              "base_shipping_canceled": "",
              "base_shipping_discount_amount": "",
              "base_shipping_discount_tax_compensation_amnt": "",
              "base_shipping_incl_tax": "",
              "base_shipping_invoiced": "",
              "base_shipping_refunded": "",
              "base_shipping_tax_amount": "",
              "base_shipping_tax_refunded": "",
              "extension_attributes": {},
              "shipping_amount": "",
              "shipping_canceled": "",
              "shipping_discount_amount": "",
              "shipping_discount_tax_compensation_amount": "",
              "shipping_incl_tax": "",
              "shipping_invoiced": "",
              "shipping_refunded": "",
              "shipping_tax_amount": "",
              "shipping_tax_refunded": ""
            }
          },
          "stock_id": 0
        }
      ]
    },
    "forced_shipment_with_invoice": 0,
    "global_currency_code": "",
    "grand_total": "",
    "hold_before_state": "",
    "hold_before_status": "",
    "increment_id": "",
    "is_virtual": 0,
    "items": [
      {}
    ],
    "order_currency_code": "",
    "original_increment_id": "",
    "payment": {
      "account_status": "",
      "additional_data": "",
      "additional_information": [],
      "address_status": "",
      "amount_authorized": "",
      "amount_canceled": "",
      "amount_ordered": "",
      "amount_paid": "",
      "amount_refunded": "",
      "anet_trans_method": "",
      "base_amount_authorized": "",
      "base_amount_canceled": "",
      "base_amount_ordered": "",
      "base_amount_paid": "",
      "base_amount_paid_online": "",
      "base_amount_refunded": "",
      "base_amount_refunded_online": "",
      "base_shipping_amount": "",
      "base_shipping_captured": "",
      "base_shipping_refunded": "",
      "cc_approval": "",
      "cc_avs_status": "",
      "cc_cid_status": "",
      "cc_debug_request_body": "",
      "cc_debug_response_body": "",
      "cc_debug_response_serialized": "",
      "cc_exp_month": "",
      "cc_exp_year": "",
      "cc_last4": "",
      "cc_number_enc": "",
      "cc_owner": "",
      "cc_secure_verify": "",
      "cc_ss_issue": "",
      "cc_ss_start_month": "",
      "cc_ss_start_year": "",
      "cc_status": "",
      "cc_status_description": "",
      "cc_trans_id": "",
      "cc_type": "",
      "echeck_account_name": "",
      "echeck_account_type": "",
      "echeck_bank_name": "",
      "echeck_routing_number": "",
      "echeck_type": "",
      "entity_id": 0,
      "extension_attributes": {
        "vault_payment_token": {
          "created_at": "",
          "customer_id": 0,
          "entity_id": 0,
          "expires_at": "",
          "gateway_token": "",
          "is_active": false,
          "is_visible": false,
          "payment_method_code": "",
          "public_hash": "",
          "token_details": "",
          "type": ""
        }
      },
      "last_trans_id": "",
      "method": "",
      "parent_id": 0,
      "po_number": "",
      "protection_eligibility": "",
      "quote_payment_id": 0,
      "shipping_amount": "",
      "shipping_captured": "",
      "shipping_refunded": ""
    },
    "payment_auth_expiration": 0,
    "payment_authorization_amount": "",
    "protect_code": "",
    "quote_address_id": 0,
    "quote_id": 0,
    "relation_child_id": "",
    "relation_child_real_id": "",
    "relation_parent_id": "",
    "relation_parent_real_id": "",
    "remote_ip": "",
    "shipping_amount": "",
    "shipping_canceled": "",
    "shipping_description": "",
    "shipping_discount_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_invoiced": "",
    "shipping_refunded": "",
    "shipping_tax_amount": "",
    "shipping_tax_refunded": "",
    "state": "",
    "status": "",
    "status_histories": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "entity_name": "",
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0,
        "status": ""
      }
    ],
    "store_currency_code": "",
    "store_id": 0,
    "store_name": "",
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_canceled": "",
    "subtotal_incl_tax": "",
    "subtotal_invoiced": "",
    "subtotal_refunded": "",
    "tax_amount": "",
    "tax_canceled": "",
    "tax_invoiced": "",
    "tax_refunded": "",
    "total_canceled": "",
    "total_due": "",
    "total_invoiced": "",
    "total_item_count": 0,
    "total_offline_refunded": "",
    "total_online_refunded": "",
    "total_paid": "",
    "total_qty_ordered": "",
    "total_refunded": "",
    "updated_at": "",
    "weight": "",
    "x_forwarded_for": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/orders/create")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/orders/create"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\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  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/orders/create")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/orders/create")
  .header("content-type", "application/json")
  .body("{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  entity: {
    adjustment_negative: '',
    adjustment_positive: '',
    applied_rule_ids: '',
    base_adjustment_negative: '',
    base_adjustment_positive: '',
    base_currency_code: '',
    base_discount_amount: '',
    base_discount_canceled: '',
    base_discount_invoiced: '',
    base_discount_refunded: '',
    base_discount_tax_compensation_amount: '',
    base_discount_tax_compensation_invoiced: '',
    base_discount_tax_compensation_refunded: '',
    base_grand_total: '',
    base_shipping_amount: '',
    base_shipping_canceled: '',
    base_shipping_discount_amount: '',
    base_shipping_discount_tax_compensation_amnt: '',
    base_shipping_incl_tax: '',
    base_shipping_invoiced: '',
    base_shipping_refunded: '',
    base_shipping_tax_amount: '',
    base_shipping_tax_refunded: '',
    base_subtotal: '',
    base_subtotal_canceled: '',
    base_subtotal_incl_tax: '',
    base_subtotal_invoiced: '',
    base_subtotal_refunded: '',
    base_tax_amount: '',
    base_tax_canceled: '',
    base_tax_invoiced: '',
    base_tax_refunded: '',
    base_to_global_rate: '',
    base_to_order_rate: '',
    base_total_canceled: '',
    base_total_due: '',
    base_total_invoiced: '',
    base_total_invoiced_cost: '',
    base_total_offline_refunded: '',
    base_total_online_refunded: '',
    base_total_paid: '',
    base_total_qty_ordered: '',
    base_total_refunded: '',
    billing_address: {
      address_type: '',
      city: '',
      company: '',
      country_id: '',
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      entity_id: 0,
      extension_attributes: {
        checkout_fields: [
          {
            attribute_code: '',
            value: ''
          }
        ]
      },
      fax: '',
      firstname: '',
      lastname: '',
      middlename: '',
      parent_id: 0,
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: '',
      vat_is_valid: 0,
      vat_request_date: '',
      vat_request_id: '',
      vat_request_success: 0
    },
    billing_address_id: 0,
    can_ship_partially: 0,
    can_ship_partially_item: 0,
    coupon_code: '',
    created_at: '',
    customer_dob: '',
    customer_email: '',
    customer_firstname: '',
    customer_gender: 0,
    customer_group_id: 0,
    customer_id: 0,
    customer_is_guest: 0,
    customer_lastname: '',
    customer_middlename: '',
    customer_note: '',
    customer_note_notify: 0,
    customer_prefix: '',
    customer_suffix: '',
    customer_taxvat: '',
    discount_amount: '',
    discount_canceled: '',
    discount_description: '',
    discount_invoiced: '',
    discount_refunded: '',
    discount_tax_compensation_amount: '',
    discount_tax_compensation_invoiced: '',
    discount_tax_compensation_refunded: '',
    edit_increment: 0,
    email_sent: 0,
    entity_id: 0,
    ext_customer_id: '',
    ext_order_id: '',
    extension_attributes: {
      amazon_order_reference_id: '',
      applied_taxes: [
        {
          amount: '',
          base_amount: '',
          code: '',
          extension_attributes: {
            rates: [
              {
                code: '',
                extension_attributes: {},
                percent: '',
                title: ''
              }
            ]
          },
          percent: '',
          title: ''
        }
      ],
      base_customer_balance_amount: '',
      base_customer_balance_invoiced: '',
      base_customer_balance_refunded: '',
      base_customer_balance_total_refunded: '',
      base_gift_cards_amount: '',
      base_gift_cards_invoiced: '',
      base_gift_cards_refunded: '',
      base_reward_currency_amount: '',
      company_order_attributes: {
        company_id: 0,
        company_name: '',
        extension_attributes: {},
        order_id: 0
      },
      converting_from_quote: false,
      customer_balance_amount: '',
      customer_balance_invoiced: '',
      customer_balance_refunded: '',
      customer_balance_total_refunded: '',
      gift_cards: [
        {
          amount: '',
          base_amount: '',
          code: '',
          id: 0
        }
      ],
      gift_cards_amount: '',
      gift_cards_invoiced: '',
      gift_cards_refunded: '',
      gift_message: {
        customer_id: 0,
        extension_attributes: {
          entity_id: '',
          entity_type: '',
          wrapping_add_printed_card: false,
          wrapping_allow_gift_receipt: false,
          wrapping_id: 0
        },
        gift_message_id: 0,
        message: '',
        recipient: '',
        sender: ''
      },
      gw_add_card: '',
      gw_allow_gift_receipt: '',
      gw_base_price: '',
      gw_base_price_incl_tax: '',
      gw_base_price_invoiced: '',
      gw_base_price_refunded: '',
      gw_base_tax_amount: '',
      gw_base_tax_amount_invoiced: '',
      gw_base_tax_amount_refunded: '',
      gw_card_base_price: '',
      gw_card_base_price_incl_tax: '',
      gw_card_base_price_invoiced: '',
      gw_card_base_price_refunded: '',
      gw_card_base_tax_amount: '',
      gw_card_base_tax_invoiced: '',
      gw_card_base_tax_refunded: '',
      gw_card_price: '',
      gw_card_price_incl_tax: '',
      gw_card_price_invoiced: '',
      gw_card_price_refunded: '',
      gw_card_tax_amount: '',
      gw_card_tax_invoiced: '',
      gw_card_tax_refunded: '',
      gw_id: '',
      gw_items_base_price: '',
      gw_items_base_price_incl_tax: '',
      gw_items_base_price_invoiced: '',
      gw_items_base_price_refunded: '',
      gw_items_base_tax_amount: '',
      gw_items_base_tax_invoiced: '',
      gw_items_base_tax_refunded: '',
      gw_items_price: '',
      gw_items_price_incl_tax: '',
      gw_items_price_invoiced: '',
      gw_items_price_refunded: '',
      gw_items_tax_amount: '',
      gw_items_tax_invoiced: '',
      gw_items_tax_refunded: '',
      gw_price: '',
      gw_price_incl_tax: '',
      gw_price_invoiced: '',
      gw_price_refunded: '',
      gw_tax_amount: '',
      gw_tax_amount_invoiced: '',
      gw_tax_amount_refunded: '',
      item_applied_taxes: [
        {
          applied_taxes: [
            {}
          ],
          associated_item_id: 0,
          extension_attributes: {},
          item_id: 0,
          type: ''
        }
      ],
      payment_additional_info: [
        {
          key: '',
          value: ''
        }
      ],
      reward_currency_amount: '',
      reward_points_balance: 0,
      shipping_assignments: [
        {
          extension_attributes: {},
          items: [
            {
              additional_data: '',
              amount_refunded: '',
              applied_rule_ids: '',
              base_amount_refunded: '',
              base_cost: '',
              base_discount_amount: '',
              base_discount_invoiced: '',
              base_discount_refunded: '',
              base_discount_tax_compensation_amount: '',
              base_discount_tax_compensation_invoiced: '',
              base_discount_tax_compensation_refunded: '',
              base_original_price: '',
              base_price: '',
              base_price_incl_tax: '',
              base_row_invoiced: '',
              base_row_total: '',
              base_row_total_incl_tax: '',
              base_tax_amount: '',
              base_tax_before_discount: '',
              base_tax_invoiced: '',
              base_tax_refunded: '',
              base_weee_tax_applied_amount: '',
              base_weee_tax_applied_row_amnt: '',
              base_weee_tax_disposition: '',
              base_weee_tax_row_disposition: '',
              created_at: '',
              description: '',
              discount_amount: '',
              discount_invoiced: '',
              discount_percent: '',
              discount_refunded: '',
              discount_tax_compensation_amount: '',
              discount_tax_compensation_canceled: '',
              discount_tax_compensation_invoiced: '',
              discount_tax_compensation_refunded: '',
              event_id: 0,
              ext_order_item_id: '',
              extension_attributes: {
                gift_message: {},
                gw_base_price: '',
                gw_base_price_invoiced: '',
                gw_base_price_refunded: '',
                gw_base_tax_amount: '',
                gw_base_tax_amount_invoiced: '',
                gw_base_tax_amount_refunded: '',
                gw_id: '',
                gw_price: '',
                gw_price_invoiced: '',
                gw_price_refunded: '',
                gw_tax_amount: '',
                gw_tax_amount_invoiced: '',
                gw_tax_amount_refunded: '',
                invoice_text_codes: [],
                tax_codes: [],
                vertex_tax_codes: []
              },
              free_shipping: 0,
              gw_base_price: '',
              gw_base_price_invoiced: '',
              gw_base_price_refunded: '',
              gw_base_tax_amount: '',
              gw_base_tax_amount_invoiced: '',
              gw_base_tax_amount_refunded: '',
              gw_id: 0,
              gw_price: '',
              gw_price_invoiced: '',
              gw_price_refunded: '',
              gw_tax_amount: '',
              gw_tax_amount_invoiced: '',
              gw_tax_amount_refunded: '',
              is_qty_decimal: 0,
              is_virtual: 0,
              item_id: 0,
              locked_do_invoice: 0,
              locked_do_ship: 0,
              name: '',
              no_discount: 0,
              order_id: 0,
              original_price: '',
              parent_item: '',
              parent_item_id: 0,
              price: '',
              price_incl_tax: '',
              product_id: 0,
              product_option: {
                extension_attributes: {
                  bundle_options: [
                    {
                      extension_attributes: {},
                      option_id: 0,
                      option_qty: 0,
                      option_selections: []
                    }
                  ],
                  configurable_item_options: [
                    {
                      extension_attributes: {},
                      option_id: '',
                      option_value: 0
                    }
                  ],
                  custom_options: [
                    {
                      extension_attributes: {
                        file_info: {
                          base64_encoded_data: '',
                          name: '',
                          type: ''
                        }
                      },
                      option_id: '',
                      option_value: ''
                    }
                  ],
                  downloadable_option: {
                    downloadable_links: []
                  },
                  giftcard_item_option: {
                    custom_giftcard_amount: '',
                    extension_attributes: {},
                    giftcard_amount: '',
                    giftcard_message: '',
                    giftcard_recipient_email: '',
                    giftcard_recipient_name: '',
                    giftcard_sender_email: '',
                    giftcard_sender_name: ''
                  }
                }
              },
              product_type: '',
              qty_backordered: '',
              qty_canceled: '',
              qty_invoiced: '',
              qty_ordered: '',
              qty_refunded: '',
              qty_returned: '',
              qty_shipped: '',
              quote_item_id: 0,
              row_invoiced: '',
              row_total: '',
              row_total_incl_tax: '',
              row_weight: '',
              sku: '',
              store_id: 0,
              tax_amount: '',
              tax_before_discount: '',
              tax_canceled: '',
              tax_invoiced: '',
              tax_percent: '',
              tax_refunded: '',
              updated_at: '',
              weee_tax_applied: '',
              weee_tax_applied_amount: '',
              weee_tax_applied_row_amount: '',
              weee_tax_disposition: '',
              weee_tax_row_disposition: '',
              weight: ''
            }
          ],
          shipping: {
            address: {},
            extension_attributes: {
              collection_point: {
                city: '',
                collection_point_id: '',
                country: '',
                name: '',
                postcode: '',
                recipient_address_id: 0,
                region: '',
                street: []
              },
              ext_order_id: '',
              shipping_experience: {
                code: '',
                cost: '',
                label: ''
              }
            },
            method: '',
            total: {
              base_shipping_amount: '',
              base_shipping_canceled: '',
              base_shipping_discount_amount: '',
              base_shipping_discount_tax_compensation_amnt: '',
              base_shipping_incl_tax: '',
              base_shipping_invoiced: '',
              base_shipping_refunded: '',
              base_shipping_tax_amount: '',
              base_shipping_tax_refunded: '',
              extension_attributes: {},
              shipping_amount: '',
              shipping_canceled: '',
              shipping_discount_amount: '',
              shipping_discount_tax_compensation_amount: '',
              shipping_incl_tax: '',
              shipping_invoiced: '',
              shipping_refunded: '',
              shipping_tax_amount: '',
              shipping_tax_refunded: ''
            }
          },
          stock_id: 0
        }
      ]
    },
    forced_shipment_with_invoice: 0,
    global_currency_code: '',
    grand_total: '',
    hold_before_state: '',
    hold_before_status: '',
    increment_id: '',
    is_virtual: 0,
    items: [
      {}
    ],
    order_currency_code: '',
    original_increment_id: '',
    payment: {
      account_status: '',
      additional_data: '',
      additional_information: [],
      address_status: '',
      amount_authorized: '',
      amount_canceled: '',
      amount_ordered: '',
      amount_paid: '',
      amount_refunded: '',
      anet_trans_method: '',
      base_amount_authorized: '',
      base_amount_canceled: '',
      base_amount_ordered: '',
      base_amount_paid: '',
      base_amount_paid_online: '',
      base_amount_refunded: '',
      base_amount_refunded_online: '',
      base_shipping_amount: '',
      base_shipping_captured: '',
      base_shipping_refunded: '',
      cc_approval: '',
      cc_avs_status: '',
      cc_cid_status: '',
      cc_debug_request_body: '',
      cc_debug_response_body: '',
      cc_debug_response_serialized: '',
      cc_exp_month: '',
      cc_exp_year: '',
      cc_last4: '',
      cc_number_enc: '',
      cc_owner: '',
      cc_secure_verify: '',
      cc_ss_issue: '',
      cc_ss_start_month: '',
      cc_ss_start_year: '',
      cc_status: '',
      cc_status_description: '',
      cc_trans_id: '',
      cc_type: '',
      echeck_account_name: '',
      echeck_account_type: '',
      echeck_bank_name: '',
      echeck_routing_number: '',
      echeck_type: '',
      entity_id: 0,
      extension_attributes: {
        vault_payment_token: {
          created_at: '',
          customer_id: 0,
          entity_id: 0,
          expires_at: '',
          gateway_token: '',
          is_active: false,
          is_visible: false,
          payment_method_code: '',
          public_hash: '',
          token_details: '',
          type: ''
        }
      },
      last_trans_id: '',
      method: '',
      parent_id: 0,
      po_number: '',
      protection_eligibility: '',
      quote_payment_id: 0,
      shipping_amount: '',
      shipping_captured: '',
      shipping_refunded: ''
    },
    payment_auth_expiration: 0,
    payment_authorization_amount: '',
    protect_code: '',
    quote_address_id: 0,
    quote_id: 0,
    relation_child_id: '',
    relation_child_real_id: '',
    relation_parent_id: '',
    relation_parent_real_id: '',
    remote_ip: '',
    shipping_amount: '',
    shipping_canceled: '',
    shipping_description: '',
    shipping_discount_amount: '',
    shipping_discount_tax_compensation_amount: '',
    shipping_incl_tax: '',
    shipping_invoiced: '',
    shipping_refunded: '',
    shipping_tax_amount: '',
    shipping_tax_refunded: '',
    state: '',
    status: '',
    status_histories: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        entity_name: '',
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0,
        status: ''
      }
    ],
    store_currency_code: '',
    store_id: 0,
    store_name: '',
    store_to_base_rate: '',
    store_to_order_rate: '',
    subtotal: '',
    subtotal_canceled: '',
    subtotal_incl_tax: '',
    subtotal_invoiced: '',
    subtotal_refunded: '',
    tax_amount: '',
    tax_canceled: '',
    tax_invoiced: '',
    tax_refunded: '',
    total_canceled: '',
    total_due: '',
    total_invoiced: '',
    total_item_count: 0,
    total_offline_refunded: '',
    total_online_refunded: '',
    total_paid: '',
    total_qty_ordered: '',
    total_refunded: '',
    updated_at: '',
    weight: '',
    x_forwarded_for: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/orders/create');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/orders/create',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      adjustment_negative: '',
      adjustment_positive: '',
      applied_rule_ids: '',
      base_adjustment_negative: '',
      base_adjustment_positive: '',
      base_currency_code: '',
      base_discount_amount: '',
      base_discount_canceled: '',
      base_discount_invoiced: '',
      base_discount_refunded: '',
      base_discount_tax_compensation_amount: '',
      base_discount_tax_compensation_invoiced: '',
      base_discount_tax_compensation_refunded: '',
      base_grand_total: '',
      base_shipping_amount: '',
      base_shipping_canceled: '',
      base_shipping_discount_amount: '',
      base_shipping_discount_tax_compensation_amnt: '',
      base_shipping_incl_tax: '',
      base_shipping_invoiced: '',
      base_shipping_refunded: '',
      base_shipping_tax_amount: '',
      base_shipping_tax_refunded: '',
      base_subtotal: '',
      base_subtotal_canceled: '',
      base_subtotal_incl_tax: '',
      base_subtotal_invoiced: '',
      base_subtotal_refunded: '',
      base_tax_amount: '',
      base_tax_canceled: '',
      base_tax_invoiced: '',
      base_tax_refunded: '',
      base_to_global_rate: '',
      base_to_order_rate: '',
      base_total_canceled: '',
      base_total_due: '',
      base_total_invoiced: '',
      base_total_invoiced_cost: '',
      base_total_offline_refunded: '',
      base_total_online_refunded: '',
      base_total_paid: '',
      base_total_qty_ordered: '',
      base_total_refunded: '',
      billing_address: {
        address_type: '',
        city: '',
        company: '',
        country_id: '',
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        entity_id: 0,
        extension_attributes: {checkout_fields: [{attribute_code: '', value: ''}]},
        fax: '',
        firstname: '',
        lastname: '',
        middlename: '',
        parent_id: 0,
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: '',
        vat_is_valid: 0,
        vat_request_date: '',
        vat_request_id: '',
        vat_request_success: 0
      },
      billing_address_id: 0,
      can_ship_partially: 0,
      can_ship_partially_item: 0,
      coupon_code: '',
      created_at: '',
      customer_dob: '',
      customer_email: '',
      customer_firstname: '',
      customer_gender: 0,
      customer_group_id: 0,
      customer_id: 0,
      customer_is_guest: 0,
      customer_lastname: '',
      customer_middlename: '',
      customer_note: '',
      customer_note_notify: 0,
      customer_prefix: '',
      customer_suffix: '',
      customer_taxvat: '',
      discount_amount: '',
      discount_canceled: '',
      discount_description: '',
      discount_invoiced: '',
      discount_refunded: '',
      discount_tax_compensation_amount: '',
      discount_tax_compensation_invoiced: '',
      discount_tax_compensation_refunded: '',
      edit_increment: 0,
      email_sent: 0,
      entity_id: 0,
      ext_customer_id: '',
      ext_order_id: '',
      extension_attributes: {
        amazon_order_reference_id: '',
        applied_taxes: [
          {
            amount: '',
            base_amount: '',
            code: '',
            extension_attributes: {rates: [{code: '', extension_attributes: {}, percent: '', title: ''}]},
            percent: '',
            title: ''
          }
        ],
        base_customer_balance_amount: '',
        base_customer_balance_invoiced: '',
        base_customer_balance_refunded: '',
        base_customer_balance_total_refunded: '',
        base_gift_cards_amount: '',
        base_gift_cards_invoiced: '',
        base_gift_cards_refunded: '',
        base_reward_currency_amount: '',
        company_order_attributes: {company_id: 0, company_name: '', extension_attributes: {}, order_id: 0},
        converting_from_quote: false,
        customer_balance_amount: '',
        customer_balance_invoiced: '',
        customer_balance_refunded: '',
        customer_balance_total_refunded: '',
        gift_cards: [{amount: '', base_amount: '', code: '', id: 0}],
        gift_cards_amount: '',
        gift_cards_invoiced: '',
        gift_cards_refunded: '',
        gift_message: {
          customer_id: 0,
          extension_attributes: {
            entity_id: '',
            entity_type: '',
            wrapping_add_printed_card: false,
            wrapping_allow_gift_receipt: false,
            wrapping_id: 0
          },
          gift_message_id: 0,
          message: '',
          recipient: '',
          sender: ''
        },
        gw_add_card: '',
        gw_allow_gift_receipt: '',
        gw_base_price: '',
        gw_base_price_incl_tax: '',
        gw_base_price_invoiced: '',
        gw_base_price_refunded: '',
        gw_base_tax_amount: '',
        gw_base_tax_amount_invoiced: '',
        gw_base_tax_amount_refunded: '',
        gw_card_base_price: '',
        gw_card_base_price_incl_tax: '',
        gw_card_base_price_invoiced: '',
        gw_card_base_price_refunded: '',
        gw_card_base_tax_amount: '',
        gw_card_base_tax_invoiced: '',
        gw_card_base_tax_refunded: '',
        gw_card_price: '',
        gw_card_price_incl_tax: '',
        gw_card_price_invoiced: '',
        gw_card_price_refunded: '',
        gw_card_tax_amount: '',
        gw_card_tax_invoiced: '',
        gw_card_tax_refunded: '',
        gw_id: '',
        gw_items_base_price: '',
        gw_items_base_price_incl_tax: '',
        gw_items_base_price_invoiced: '',
        gw_items_base_price_refunded: '',
        gw_items_base_tax_amount: '',
        gw_items_base_tax_invoiced: '',
        gw_items_base_tax_refunded: '',
        gw_items_price: '',
        gw_items_price_incl_tax: '',
        gw_items_price_invoiced: '',
        gw_items_price_refunded: '',
        gw_items_tax_amount: '',
        gw_items_tax_invoiced: '',
        gw_items_tax_refunded: '',
        gw_price: '',
        gw_price_incl_tax: '',
        gw_price_invoiced: '',
        gw_price_refunded: '',
        gw_tax_amount: '',
        gw_tax_amount_invoiced: '',
        gw_tax_amount_refunded: '',
        item_applied_taxes: [
          {
            applied_taxes: [{}],
            associated_item_id: 0,
            extension_attributes: {},
            item_id: 0,
            type: ''
          }
        ],
        payment_additional_info: [{key: '', value: ''}],
        reward_currency_amount: '',
        reward_points_balance: 0,
        shipping_assignments: [
          {
            extension_attributes: {},
            items: [
              {
                additional_data: '',
                amount_refunded: '',
                applied_rule_ids: '',
                base_amount_refunded: '',
                base_cost: '',
                base_discount_amount: '',
                base_discount_invoiced: '',
                base_discount_refunded: '',
                base_discount_tax_compensation_amount: '',
                base_discount_tax_compensation_invoiced: '',
                base_discount_tax_compensation_refunded: '',
                base_original_price: '',
                base_price: '',
                base_price_incl_tax: '',
                base_row_invoiced: '',
                base_row_total: '',
                base_row_total_incl_tax: '',
                base_tax_amount: '',
                base_tax_before_discount: '',
                base_tax_invoiced: '',
                base_tax_refunded: '',
                base_weee_tax_applied_amount: '',
                base_weee_tax_applied_row_amnt: '',
                base_weee_tax_disposition: '',
                base_weee_tax_row_disposition: '',
                created_at: '',
                description: '',
                discount_amount: '',
                discount_invoiced: '',
                discount_percent: '',
                discount_refunded: '',
                discount_tax_compensation_amount: '',
                discount_tax_compensation_canceled: '',
                discount_tax_compensation_invoiced: '',
                discount_tax_compensation_refunded: '',
                event_id: 0,
                ext_order_item_id: '',
                extension_attributes: {
                  gift_message: {},
                  gw_base_price: '',
                  gw_base_price_invoiced: '',
                  gw_base_price_refunded: '',
                  gw_base_tax_amount: '',
                  gw_base_tax_amount_invoiced: '',
                  gw_base_tax_amount_refunded: '',
                  gw_id: '',
                  gw_price: '',
                  gw_price_invoiced: '',
                  gw_price_refunded: '',
                  gw_tax_amount: '',
                  gw_tax_amount_invoiced: '',
                  gw_tax_amount_refunded: '',
                  invoice_text_codes: [],
                  tax_codes: [],
                  vertex_tax_codes: []
                },
                free_shipping: 0,
                gw_base_price: '',
                gw_base_price_invoiced: '',
                gw_base_price_refunded: '',
                gw_base_tax_amount: '',
                gw_base_tax_amount_invoiced: '',
                gw_base_tax_amount_refunded: '',
                gw_id: 0,
                gw_price: '',
                gw_price_invoiced: '',
                gw_price_refunded: '',
                gw_tax_amount: '',
                gw_tax_amount_invoiced: '',
                gw_tax_amount_refunded: '',
                is_qty_decimal: 0,
                is_virtual: 0,
                item_id: 0,
                locked_do_invoice: 0,
                locked_do_ship: 0,
                name: '',
                no_discount: 0,
                order_id: 0,
                original_price: '',
                parent_item: '',
                parent_item_id: 0,
                price: '',
                price_incl_tax: '',
                product_id: 0,
                product_option: {
                  extension_attributes: {
                    bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                    configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                    custom_options: [
                      {
                        extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                        option_id: '',
                        option_value: ''
                      }
                    ],
                    downloadable_option: {downloadable_links: []},
                    giftcard_item_option: {
                      custom_giftcard_amount: '',
                      extension_attributes: {},
                      giftcard_amount: '',
                      giftcard_message: '',
                      giftcard_recipient_email: '',
                      giftcard_recipient_name: '',
                      giftcard_sender_email: '',
                      giftcard_sender_name: ''
                    }
                  }
                },
                product_type: '',
                qty_backordered: '',
                qty_canceled: '',
                qty_invoiced: '',
                qty_ordered: '',
                qty_refunded: '',
                qty_returned: '',
                qty_shipped: '',
                quote_item_id: 0,
                row_invoiced: '',
                row_total: '',
                row_total_incl_tax: '',
                row_weight: '',
                sku: '',
                store_id: 0,
                tax_amount: '',
                tax_before_discount: '',
                tax_canceled: '',
                tax_invoiced: '',
                tax_percent: '',
                tax_refunded: '',
                updated_at: '',
                weee_tax_applied: '',
                weee_tax_applied_amount: '',
                weee_tax_applied_row_amount: '',
                weee_tax_disposition: '',
                weee_tax_row_disposition: '',
                weight: ''
              }
            ],
            shipping: {
              address: {},
              extension_attributes: {
                collection_point: {
                  city: '',
                  collection_point_id: '',
                  country: '',
                  name: '',
                  postcode: '',
                  recipient_address_id: 0,
                  region: '',
                  street: []
                },
                ext_order_id: '',
                shipping_experience: {code: '', cost: '', label: ''}
              },
              method: '',
              total: {
                base_shipping_amount: '',
                base_shipping_canceled: '',
                base_shipping_discount_amount: '',
                base_shipping_discount_tax_compensation_amnt: '',
                base_shipping_incl_tax: '',
                base_shipping_invoiced: '',
                base_shipping_refunded: '',
                base_shipping_tax_amount: '',
                base_shipping_tax_refunded: '',
                extension_attributes: {},
                shipping_amount: '',
                shipping_canceled: '',
                shipping_discount_amount: '',
                shipping_discount_tax_compensation_amount: '',
                shipping_incl_tax: '',
                shipping_invoiced: '',
                shipping_refunded: '',
                shipping_tax_amount: '',
                shipping_tax_refunded: ''
              }
            },
            stock_id: 0
          }
        ]
      },
      forced_shipment_with_invoice: 0,
      global_currency_code: '',
      grand_total: '',
      hold_before_state: '',
      hold_before_status: '',
      increment_id: '',
      is_virtual: 0,
      items: [{}],
      order_currency_code: '',
      original_increment_id: '',
      payment: {
        account_status: '',
        additional_data: '',
        additional_information: [],
        address_status: '',
        amount_authorized: '',
        amount_canceled: '',
        amount_ordered: '',
        amount_paid: '',
        amount_refunded: '',
        anet_trans_method: '',
        base_amount_authorized: '',
        base_amount_canceled: '',
        base_amount_ordered: '',
        base_amount_paid: '',
        base_amount_paid_online: '',
        base_amount_refunded: '',
        base_amount_refunded_online: '',
        base_shipping_amount: '',
        base_shipping_captured: '',
        base_shipping_refunded: '',
        cc_approval: '',
        cc_avs_status: '',
        cc_cid_status: '',
        cc_debug_request_body: '',
        cc_debug_response_body: '',
        cc_debug_response_serialized: '',
        cc_exp_month: '',
        cc_exp_year: '',
        cc_last4: '',
        cc_number_enc: '',
        cc_owner: '',
        cc_secure_verify: '',
        cc_ss_issue: '',
        cc_ss_start_month: '',
        cc_ss_start_year: '',
        cc_status: '',
        cc_status_description: '',
        cc_trans_id: '',
        cc_type: '',
        echeck_account_name: '',
        echeck_account_type: '',
        echeck_bank_name: '',
        echeck_routing_number: '',
        echeck_type: '',
        entity_id: 0,
        extension_attributes: {
          vault_payment_token: {
            created_at: '',
            customer_id: 0,
            entity_id: 0,
            expires_at: '',
            gateway_token: '',
            is_active: false,
            is_visible: false,
            payment_method_code: '',
            public_hash: '',
            token_details: '',
            type: ''
          }
        },
        last_trans_id: '',
        method: '',
        parent_id: 0,
        po_number: '',
        protection_eligibility: '',
        quote_payment_id: 0,
        shipping_amount: '',
        shipping_captured: '',
        shipping_refunded: ''
      },
      payment_auth_expiration: 0,
      payment_authorization_amount: '',
      protect_code: '',
      quote_address_id: 0,
      quote_id: 0,
      relation_child_id: '',
      relation_child_real_id: '',
      relation_parent_id: '',
      relation_parent_real_id: '',
      remote_ip: '',
      shipping_amount: '',
      shipping_canceled: '',
      shipping_description: '',
      shipping_discount_amount: '',
      shipping_discount_tax_compensation_amount: '',
      shipping_incl_tax: '',
      shipping_invoiced: '',
      shipping_refunded: '',
      shipping_tax_amount: '',
      shipping_tax_refunded: '',
      state: '',
      status: '',
      status_histories: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          entity_name: '',
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0,
          status: ''
        }
      ],
      store_currency_code: '',
      store_id: 0,
      store_name: '',
      store_to_base_rate: '',
      store_to_order_rate: '',
      subtotal: '',
      subtotal_canceled: '',
      subtotal_incl_tax: '',
      subtotal_invoiced: '',
      subtotal_refunded: '',
      tax_amount: '',
      tax_canceled: '',
      tax_invoiced: '',
      tax_refunded: '',
      total_canceled: '',
      total_due: '',
      total_invoiced: '',
      total_item_count: 0,
      total_offline_refunded: '',
      total_online_refunded: '',
      total_paid: '',
      total_qty_ordered: '',
      total_refunded: '',
      updated_at: '',
      weight: '',
      x_forwarded_for: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/orders/create';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"adjustment_negative":"","adjustment_positive":"","applied_rule_ids":"","base_adjustment_negative":"","base_adjustment_positive":"","base_currency_code":"","base_discount_amount":"","base_discount_canceled":"","base_discount_invoiced":"","base_discount_refunded":"","base_discount_tax_compensation_amount":"","base_discount_tax_compensation_invoiced":"","base_discount_tax_compensation_refunded":"","base_grand_total":"","base_shipping_amount":"","base_shipping_canceled":"","base_shipping_discount_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_invoiced":"","base_shipping_refunded":"","base_shipping_tax_amount":"","base_shipping_tax_refunded":"","base_subtotal":"","base_subtotal_canceled":"","base_subtotal_incl_tax":"","base_subtotal_invoiced":"","base_subtotal_refunded":"","base_tax_amount":"","base_tax_canceled":"","base_tax_invoiced":"","base_tax_refunded":"","base_to_global_rate":"","base_to_order_rate":"","base_total_canceled":"","base_total_due":"","base_total_invoiced":"","base_total_invoiced_cost":"","base_total_offline_refunded":"","base_total_online_refunded":"","base_total_paid":"","base_total_qty_ordered":"","base_total_refunded":"","billing_address":{"address_type":"","city":"","company":"","country_id":"","customer_address_id":0,"customer_id":0,"email":"","entity_id":0,"extension_attributes":{"checkout_fields":[{"attribute_code":"","value":""}]},"fax":"","firstname":"","lastname":"","middlename":"","parent_id":0,"postcode":"","prefix":"","region":"","region_code":"","region_id":0,"street":[],"suffix":"","telephone":"","vat_id":"","vat_is_valid":0,"vat_request_date":"","vat_request_id":"","vat_request_success":0},"billing_address_id":0,"can_ship_partially":0,"can_ship_partially_item":0,"coupon_code":"","created_at":"","customer_dob":"","customer_email":"","customer_firstname":"","customer_gender":0,"customer_group_id":0,"customer_id":0,"customer_is_guest":0,"customer_lastname":"","customer_middlename":"","customer_note":"","customer_note_notify":0,"customer_prefix":"","customer_suffix":"","customer_taxvat":"","discount_amount":"","discount_canceled":"","discount_description":"","discount_invoiced":"","discount_refunded":"","discount_tax_compensation_amount":"","discount_tax_compensation_invoiced":"","discount_tax_compensation_refunded":"","edit_increment":0,"email_sent":0,"entity_id":0,"ext_customer_id":"","ext_order_id":"","extension_attributes":{"amazon_order_reference_id":"","applied_taxes":[{"amount":"","base_amount":"","code":"","extension_attributes":{"rates":[{"code":"","extension_attributes":{},"percent":"","title":""}]},"percent":"","title":""}],"base_customer_balance_amount":"","base_customer_balance_invoiced":"","base_customer_balance_refunded":"","base_customer_balance_total_refunded":"","base_gift_cards_amount":"","base_gift_cards_invoiced":"","base_gift_cards_refunded":"","base_reward_currency_amount":"","company_order_attributes":{"company_id":0,"company_name":"","extension_attributes":{},"order_id":0},"converting_from_quote":false,"customer_balance_amount":"","customer_balance_invoiced":"","customer_balance_refunded":"","customer_balance_total_refunded":"","gift_cards":[{"amount":"","base_amount":"","code":"","id":0}],"gift_cards_amount":"","gift_cards_invoiced":"","gift_cards_refunded":"","gift_message":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""},"gw_add_card":"","gw_allow_gift_receipt":"","gw_base_price":"","gw_base_price_incl_tax":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_card_base_price":"","gw_card_base_price_incl_tax":"","gw_card_base_price_invoiced":"","gw_card_base_price_refunded":"","gw_card_base_tax_amount":"","gw_card_base_tax_invoiced":"","gw_card_base_tax_refunded":"","gw_card_price":"","gw_card_price_incl_tax":"","gw_card_price_invoiced":"","gw_card_price_refunded":"","gw_card_tax_amount":"","gw_card_tax_invoiced":"","gw_card_tax_refunded":"","gw_id":"","gw_items_base_price":"","gw_items_base_price_incl_tax":"","gw_items_base_price_invoiced":"","gw_items_base_price_refunded":"","gw_items_base_tax_amount":"","gw_items_base_tax_invoiced":"","gw_items_base_tax_refunded":"","gw_items_price":"","gw_items_price_incl_tax":"","gw_items_price_invoiced":"","gw_items_price_refunded":"","gw_items_tax_amount":"","gw_items_tax_invoiced":"","gw_items_tax_refunded":"","gw_price":"","gw_price_incl_tax":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","item_applied_taxes":[{"applied_taxes":[{}],"associated_item_id":0,"extension_attributes":{},"item_id":0,"type":""}],"payment_additional_info":[{"key":"","value":""}],"reward_currency_amount":"","reward_points_balance":0,"shipping_assignments":[{"extension_attributes":{},"items":[{"additional_data":"","amount_refunded":"","applied_rule_ids":"","base_amount_refunded":"","base_cost":"","base_discount_amount":"","base_discount_invoiced":"","base_discount_refunded":"","base_discount_tax_compensation_amount":"","base_discount_tax_compensation_invoiced":"","base_discount_tax_compensation_refunded":"","base_original_price":"","base_price":"","base_price_incl_tax":"","base_row_invoiced":"","base_row_total":"","base_row_total_incl_tax":"","base_tax_amount":"","base_tax_before_discount":"","base_tax_invoiced":"","base_tax_refunded":"","base_weee_tax_applied_amount":"","base_weee_tax_applied_row_amnt":"","base_weee_tax_disposition":"","base_weee_tax_row_disposition":"","created_at":"","description":"","discount_amount":"","discount_invoiced":"","discount_percent":"","discount_refunded":"","discount_tax_compensation_amount":"","discount_tax_compensation_canceled":"","discount_tax_compensation_invoiced":"","discount_tax_compensation_refunded":"","event_id":0,"ext_order_item_id":"","extension_attributes":{"gift_message":{},"gw_base_price":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_id":"","gw_price":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","invoice_text_codes":[],"tax_codes":[],"vertex_tax_codes":[]},"free_shipping":0,"gw_base_price":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_id":0,"gw_price":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","is_qty_decimal":0,"is_virtual":0,"item_id":0,"locked_do_invoice":0,"locked_do_ship":0,"name":"","no_discount":0,"order_id":0,"original_price":"","parent_item":"","parent_item_id":0,"price":"","price_incl_tax":"","product_id":0,"product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty_backordered":"","qty_canceled":"","qty_invoiced":"","qty_ordered":"","qty_refunded":"","qty_returned":"","qty_shipped":"","quote_item_id":0,"row_invoiced":"","row_total":"","row_total_incl_tax":"","row_weight":"","sku":"","store_id":0,"tax_amount":"","tax_before_discount":"","tax_canceled":"","tax_invoiced":"","tax_percent":"","tax_refunded":"","updated_at":"","weee_tax_applied":"","weee_tax_applied_amount":"","weee_tax_applied_row_amount":"","weee_tax_disposition":"","weee_tax_row_disposition":"","weight":""}],"shipping":{"address":{},"extension_attributes":{"collection_point":{"city":"","collection_point_id":"","country":"","name":"","postcode":"","recipient_address_id":0,"region":"","street":[]},"ext_order_id":"","shipping_experience":{"code":"","cost":"","label":""}},"method":"","total":{"base_shipping_amount":"","base_shipping_canceled":"","base_shipping_discount_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_invoiced":"","base_shipping_refunded":"","base_shipping_tax_amount":"","base_shipping_tax_refunded":"","extension_attributes":{},"shipping_amount":"","shipping_canceled":"","shipping_discount_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_invoiced":"","shipping_refunded":"","shipping_tax_amount":"","shipping_tax_refunded":""}},"stock_id":0}]},"forced_shipment_with_invoice":0,"global_currency_code":"","grand_total":"","hold_before_state":"","hold_before_status":"","increment_id":"","is_virtual":0,"items":[{}],"order_currency_code":"","original_increment_id":"","payment":{"account_status":"","additional_data":"","additional_information":[],"address_status":"","amount_authorized":"","amount_canceled":"","amount_ordered":"","amount_paid":"","amount_refunded":"","anet_trans_method":"","base_amount_authorized":"","base_amount_canceled":"","base_amount_ordered":"","base_amount_paid":"","base_amount_paid_online":"","base_amount_refunded":"","base_amount_refunded_online":"","base_shipping_amount":"","base_shipping_captured":"","base_shipping_refunded":"","cc_approval":"","cc_avs_status":"","cc_cid_status":"","cc_debug_request_body":"","cc_debug_response_body":"","cc_debug_response_serialized":"","cc_exp_month":"","cc_exp_year":"","cc_last4":"","cc_number_enc":"","cc_owner":"","cc_secure_verify":"","cc_ss_issue":"","cc_ss_start_month":"","cc_ss_start_year":"","cc_status":"","cc_status_description":"","cc_trans_id":"","cc_type":"","echeck_account_name":"","echeck_account_type":"","echeck_bank_name":"","echeck_routing_number":"","echeck_type":"","entity_id":0,"extension_attributes":{"vault_payment_token":{"created_at":"","customer_id":0,"entity_id":0,"expires_at":"","gateway_token":"","is_active":false,"is_visible":false,"payment_method_code":"","public_hash":"","token_details":"","type":""}},"last_trans_id":"","method":"","parent_id":0,"po_number":"","protection_eligibility":"","quote_payment_id":0,"shipping_amount":"","shipping_captured":"","shipping_refunded":""},"payment_auth_expiration":0,"payment_authorization_amount":"","protect_code":"","quote_address_id":0,"quote_id":0,"relation_child_id":"","relation_child_real_id":"","relation_parent_id":"","relation_parent_real_id":"","remote_ip":"","shipping_amount":"","shipping_canceled":"","shipping_description":"","shipping_discount_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_invoiced":"","shipping_refunded":"","shipping_tax_amount":"","shipping_tax_refunded":"","state":"","status":"","status_histories":[{"comment":"","created_at":"","entity_id":0,"entity_name":"","extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_id":0,"status":""}],"store_currency_code":"","store_id":0,"store_name":"","store_to_base_rate":"","store_to_order_rate":"","subtotal":"","subtotal_canceled":"","subtotal_incl_tax":"","subtotal_invoiced":"","subtotal_refunded":"","tax_amount":"","tax_canceled":"","tax_invoiced":"","tax_refunded":"","total_canceled":"","total_due":"","total_invoiced":"","total_item_count":0,"total_offline_refunded":"","total_online_refunded":"","total_paid":"","total_qty_ordered":"","total_refunded":"","updated_at":"","weight":"","x_forwarded_for":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/orders/create',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "entity": {\n    "adjustment_negative": "",\n    "adjustment_positive": "",\n    "applied_rule_ids": "",\n    "base_adjustment_negative": "",\n    "base_adjustment_positive": "",\n    "base_currency_code": "",\n    "base_discount_amount": "",\n    "base_discount_canceled": "",\n    "base_discount_invoiced": "",\n    "base_discount_refunded": "",\n    "base_discount_tax_compensation_amount": "",\n    "base_discount_tax_compensation_invoiced": "",\n    "base_discount_tax_compensation_refunded": "",\n    "base_grand_total": "",\n    "base_shipping_amount": "",\n    "base_shipping_canceled": "",\n    "base_shipping_discount_amount": "",\n    "base_shipping_discount_tax_compensation_amnt": "",\n    "base_shipping_incl_tax": "",\n    "base_shipping_invoiced": "",\n    "base_shipping_refunded": "",\n    "base_shipping_tax_amount": "",\n    "base_shipping_tax_refunded": "",\n    "base_subtotal": "",\n    "base_subtotal_canceled": "",\n    "base_subtotal_incl_tax": "",\n    "base_subtotal_invoiced": "",\n    "base_subtotal_refunded": "",\n    "base_tax_amount": "",\n    "base_tax_canceled": "",\n    "base_tax_invoiced": "",\n    "base_tax_refunded": "",\n    "base_to_global_rate": "",\n    "base_to_order_rate": "",\n    "base_total_canceled": "",\n    "base_total_due": "",\n    "base_total_invoiced": "",\n    "base_total_invoiced_cost": "",\n    "base_total_offline_refunded": "",\n    "base_total_online_refunded": "",\n    "base_total_paid": "",\n    "base_total_qty_ordered": "",\n    "base_total_refunded": "",\n    "billing_address": {\n      "address_type": "",\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "entity_id": 0,\n      "extension_attributes": {\n        "checkout_fields": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ]\n      },\n      "fax": "",\n      "firstname": "",\n      "lastname": "",\n      "middlename": "",\n      "parent_id": 0,\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": "",\n      "vat_is_valid": 0,\n      "vat_request_date": "",\n      "vat_request_id": "",\n      "vat_request_success": 0\n    },\n    "billing_address_id": 0,\n    "can_ship_partially": 0,\n    "can_ship_partially_item": 0,\n    "coupon_code": "",\n    "created_at": "",\n    "customer_dob": "",\n    "customer_email": "",\n    "customer_firstname": "",\n    "customer_gender": 0,\n    "customer_group_id": 0,\n    "customer_id": 0,\n    "customer_is_guest": 0,\n    "customer_lastname": "",\n    "customer_middlename": "",\n    "customer_note": "",\n    "customer_note_notify": 0,\n    "customer_prefix": "",\n    "customer_suffix": "",\n    "customer_taxvat": "",\n    "discount_amount": "",\n    "discount_canceled": "",\n    "discount_description": "",\n    "discount_invoiced": "",\n    "discount_refunded": "",\n    "discount_tax_compensation_amount": "",\n    "discount_tax_compensation_invoiced": "",\n    "discount_tax_compensation_refunded": "",\n    "edit_increment": 0,\n    "email_sent": 0,\n    "entity_id": 0,\n    "ext_customer_id": "",\n    "ext_order_id": "",\n    "extension_attributes": {\n      "amazon_order_reference_id": "",\n      "applied_taxes": [\n        {\n          "amount": "",\n          "base_amount": "",\n          "code": "",\n          "extension_attributes": {\n            "rates": [\n              {\n                "code": "",\n                "extension_attributes": {},\n                "percent": "",\n                "title": ""\n              }\n            ]\n          },\n          "percent": "",\n          "title": ""\n        }\n      ],\n      "base_customer_balance_amount": "",\n      "base_customer_balance_invoiced": "",\n      "base_customer_balance_refunded": "",\n      "base_customer_balance_total_refunded": "",\n      "base_gift_cards_amount": "",\n      "base_gift_cards_invoiced": "",\n      "base_gift_cards_refunded": "",\n      "base_reward_currency_amount": "",\n      "company_order_attributes": {\n        "company_id": 0,\n        "company_name": "",\n        "extension_attributes": {},\n        "order_id": 0\n      },\n      "converting_from_quote": false,\n      "customer_balance_amount": "",\n      "customer_balance_invoiced": "",\n      "customer_balance_refunded": "",\n      "customer_balance_total_refunded": "",\n      "gift_cards": [\n        {\n          "amount": "",\n          "base_amount": "",\n          "code": "",\n          "id": 0\n        }\n      ],\n      "gift_cards_amount": "",\n      "gift_cards_invoiced": "",\n      "gift_cards_refunded": "",\n      "gift_message": {\n        "customer_id": 0,\n        "extension_attributes": {\n          "entity_id": "",\n          "entity_type": "",\n          "wrapping_add_printed_card": false,\n          "wrapping_allow_gift_receipt": false,\n          "wrapping_id": 0\n        },\n        "gift_message_id": 0,\n        "message": "",\n        "recipient": "",\n        "sender": ""\n      },\n      "gw_add_card": "",\n      "gw_allow_gift_receipt": "",\n      "gw_base_price": "",\n      "gw_base_price_incl_tax": "",\n      "gw_base_price_invoiced": "",\n      "gw_base_price_refunded": "",\n      "gw_base_tax_amount": "",\n      "gw_base_tax_amount_invoiced": "",\n      "gw_base_tax_amount_refunded": "",\n      "gw_card_base_price": "",\n      "gw_card_base_price_incl_tax": "",\n      "gw_card_base_price_invoiced": "",\n      "gw_card_base_price_refunded": "",\n      "gw_card_base_tax_amount": "",\n      "gw_card_base_tax_invoiced": "",\n      "gw_card_base_tax_refunded": "",\n      "gw_card_price": "",\n      "gw_card_price_incl_tax": "",\n      "gw_card_price_invoiced": "",\n      "gw_card_price_refunded": "",\n      "gw_card_tax_amount": "",\n      "gw_card_tax_invoiced": "",\n      "gw_card_tax_refunded": "",\n      "gw_id": "",\n      "gw_items_base_price": "",\n      "gw_items_base_price_incl_tax": "",\n      "gw_items_base_price_invoiced": "",\n      "gw_items_base_price_refunded": "",\n      "gw_items_base_tax_amount": "",\n      "gw_items_base_tax_invoiced": "",\n      "gw_items_base_tax_refunded": "",\n      "gw_items_price": "",\n      "gw_items_price_incl_tax": "",\n      "gw_items_price_invoiced": "",\n      "gw_items_price_refunded": "",\n      "gw_items_tax_amount": "",\n      "gw_items_tax_invoiced": "",\n      "gw_items_tax_refunded": "",\n      "gw_price": "",\n      "gw_price_incl_tax": "",\n      "gw_price_invoiced": "",\n      "gw_price_refunded": "",\n      "gw_tax_amount": "",\n      "gw_tax_amount_invoiced": "",\n      "gw_tax_amount_refunded": "",\n      "item_applied_taxes": [\n        {\n          "applied_taxes": [\n            {}\n          ],\n          "associated_item_id": 0,\n          "extension_attributes": {},\n          "item_id": 0,\n          "type": ""\n        }\n      ],\n      "payment_additional_info": [\n        {\n          "key": "",\n          "value": ""\n        }\n      ],\n      "reward_currency_amount": "",\n      "reward_points_balance": 0,\n      "shipping_assignments": [\n        {\n          "extension_attributes": {},\n          "items": [\n            {\n              "additional_data": "",\n              "amount_refunded": "",\n              "applied_rule_ids": "",\n              "base_amount_refunded": "",\n              "base_cost": "",\n              "base_discount_amount": "",\n              "base_discount_invoiced": "",\n              "base_discount_refunded": "",\n              "base_discount_tax_compensation_amount": "",\n              "base_discount_tax_compensation_invoiced": "",\n              "base_discount_tax_compensation_refunded": "",\n              "base_original_price": "",\n              "base_price": "",\n              "base_price_incl_tax": "",\n              "base_row_invoiced": "",\n              "base_row_total": "",\n              "base_row_total_incl_tax": "",\n              "base_tax_amount": "",\n              "base_tax_before_discount": "",\n              "base_tax_invoiced": "",\n              "base_tax_refunded": "",\n              "base_weee_tax_applied_amount": "",\n              "base_weee_tax_applied_row_amnt": "",\n              "base_weee_tax_disposition": "",\n              "base_weee_tax_row_disposition": "",\n              "created_at": "",\n              "description": "",\n              "discount_amount": "",\n              "discount_invoiced": "",\n              "discount_percent": "",\n              "discount_refunded": "",\n              "discount_tax_compensation_amount": "",\n              "discount_tax_compensation_canceled": "",\n              "discount_tax_compensation_invoiced": "",\n              "discount_tax_compensation_refunded": "",\n              "event_id": 0,\n              "ext_order_item_id": "",\n              "extension_attributes": {\n                "gift_message": {},\n                "gw_base_price": "",\n                "gw_base_price_invoiced": "",\n                "gw_base_price_refunded": "",\n                "gw_base_tax_amount": "",\n                "gw_base_tax_amount_invoiced": "",\n                "gw_base_tax_amount_refunded": "",\n                "gw_id": "",\n                "gw_price": "",\n                "gw_price_invoiced": "",\n                "gw_price_refunded": "",\n                "gw_tax_amount": "",\n                "gw_tax_amount_invoiced": "",\n                "gw_tax_amount_refunded": "",\n                "invoice_text_codes": [],\n                "tax_codes": [],\n                "vertex_tax_codes": []\n              },\n              "free_shipping": 0,\n              "gw_base_price": "",\n              "gw_base_price_invoiced": "",\n              "gw_base_price_refunded": "",\n              "gw_base_tax_amount": "",\n              "gw_base_tax_amount_invoiced": "",\n              "gw_base_tax_amount_refunded": "",\n              "gw_id": 0,\n              "gw_price": "",\n              "gw_price_invoiced": "",\n              "gw_price_refunded": "",\n              "gw_tax_amount": "",\n              "gw_tax_amount_invoiced": "",\n              "gw_tax_amount_refunded": "",\n              "is_qty_decimal": 0,\n              "is_virtual": 0,\n              "item_id": 0,\n              "locked_do_invoice": 0,\n              "locked_do_ship": 0,\n              "name": "",\n              "no_discount": 0,\n              "order_id": 0,\n              "original_price": "",\n              "parent_item": "",\n              "parent_item_id": 0,\n              "price": "",\n              "price_incl_tax": "",\n              "product_id": 0,\n              "product_option": {\n                "extension_attributes": {\n                  "bundle_options": [\n                    {\n                      "extension_attributes": {},\n                      "option_id": 0,\n                      "option_qty": 0,\n                      "option_selections": []\n                    }\n                  ],\n                  "configurable_item_options": [\n                    {\n                      "extension_attributes": {},\n                      "option_id": "",\n                      "option_value": 0\n                    }\n                  ],\n                  "custom_options": [\n                    {\n                      "extension_attributes": {\n                        "file_info": {\n                          "base64_encoded_data": "",\n                          "name": "",\n                          "type": ""\n                        }\n                      },\n                      "option_id": "",\n                      "option_value": ""\n                    }\n                  ],\n                  "downloadable_option": {\n                    "downloadable_links": []\n                  },\n                  "giftcard_item_option": {\n                    "custom_giftcard_amount": "",\n                    "extension_attributes": {},\n                    "giftcard_amount": "",\n                    "giftcard_message": "",\n                    "giftcard_recipient_email": "",\n                    "giftcard_recipient_name": "",\n                    "giftcard_sender_email": "",\n                    "giftcard_sender_name": ""\n                  }\n                }\n              },\n              "product_type": "",\n              "qty_backordered": "",\n              "qty_canceled": "",\n              "qty_invoiced": "",\n              "qty_ordered": "",\n              "qty_refunded": "",\n              "qty_returned": "",\n              "qty_shipped": "",\n              "quote_item_id": 0,\n              "row_invoiced": "",\n              "row_total": "",\n              "row_total_incl_tax": "",\n              "row_weight": "",\n              "sku": "",\n              "store_id": 0,\n              "tax_amount": "",\n              "tax_before_discount": "",\n              "tax_canceled": "",\n              "tax_invoiced": "",\n              "tax_percent": "",\n              "tax_refunded": "",\n              "updated_at": "",\n              "weee_tax_applied": "",\n              "weee_tax_applied_amount": "",\n              "weee_tax_applied_row_amount": "",\n              "weee_tax_disposition": "",\n              "weee_tax_row_disposition": "",\n              "weight": ""\n            }\n          ],\n          "shipping": {\n            "address": {},\n            "extension_attributes": {\n              "collection_point": {\n                "city": "",\n                "collection_point_id": "",\n                "country": "",\n                "name": "",\n                "postcode": "",\n                "recipient_address_id": 0,\n                "region": "",\n                "street": []\n              },\n              "ext_order_id": "",\n              "shipping_experience": {\n                "code": "",\n                "cost": "",\n                "label": ""\n              }\n            },\n            "method": "",\n            "total": {\n              "base_shipping_amount": "",\n              "base_shipping_canceled": "",\n              "base_shipping_discount_amount": "",\n              "base_shipping_discount_tax_compensation_amnt": "",\n              "base_shipping_incl_tax": "",\n              "base_shipping_invoiced": "",\n              "base_shipping_refunded": "",\n              "base_shipping_tax_amount": "",\n              "base_shipping_tax_refunded": "",\n              "extension_attributes": {},\n              "shipping_amount": "",\n              "shipping_canceled": "",\n              "shipping_discount_amount": "",\n              "shipping_discount_tax_compensation_amount": "",\n              "shipping_incl_tax": "",\n              "shipping_invoiced": "",\n              "shipping_refunded": "",\n              "shipping_tax_amount": "",\n              "shipping_tax_refunded": ""\n            }\n          },\n          "stock_id": 0\n        }\n      ]\n    },\n    "forced_shipment_with_invoice": 0,\n    "global_currency_code": "",\n    "grand_total": "",\n    "hold_before_state": "",\n    "hold_before_status": "",\n    "increment_id": "",\n    "is_virtual": 0,\n    "items": [\n      {}\n    ],\n    "order_currency_code": "",\n    "original_increment_id": "",\n    "payment": {\n      "account_status": "",\n      "additional_data": "",\n      "additional_information": [],\n      "address_status": "",\n      "amount_authorized": "",\n      "amount_canceled": "",\n      "amount_ordered": "",\n      "amount_paid": "",\n      "amount_refunded": "",\n      "anet_trans_method": "",\n      "base_amount_authorized": "",\n      "base_amount_canceled": "",\n      "base_amount_ordered": "",\n      "base_amount_paid": "",\n      "base_amount_paid_online": "",\n      "base_amount_refunded": "",\n      "base_amount_refunded_online": "",\n      "base_shipping_amount": "",\n      "base_shipping_captured": "",\n      "base_shipping_refunded": "",\n      "cc_approval": "",\n      "cc_avs_status": "",\n      "cc_cid_status": "",\n      "cc_debug_request_body": "",\n      "cc_debug_response_body": "",\n      "cc_debug_response_serialized": "",\n      "cc_exp_month": "",\n      "cc_exp_year": "",\n      "cc_last4": "",\n      "cc_number_enc": "",\n      "cc_owner": "",\n      "cc_secure_verify": "",\n      "cc_ss_issue": "",\n      "cc_ss_start_month": "",\n      "cc_ss_start_year": "",\n      "cc_status": "",\n      "cc_status_description": "",\n      "cc_trans_id": "",\n      "cc_type": "",\n      "echeck_account_name": "",\n      "echeck_account_type": "",\n      "echeck_bank_name": "",\n      "echeck_routing_number": "",\n      "echeck_type": "",\n      "entity_id": 0,\n      "extension_attributes": {\n        "vault_payment_token": {\n          "created_at": "",\n          "customer_id": 0,\n          "entity_id": 0,\n          "expires_at": "",\n          "gateway_token": "",\n          "is_active": false,\n          "is_visible": false,\n          "payment_method_code": "",\n          "public_hash": "",\n          "token_details": "",\n          "type": ""\n        }\n      },\n      "last_trans_id": "",\n      "method": "",\n      "parent_id": 0,\n      "po_number": "",\n      "protection_eligibility": "",\n      "quote_payment_id": 0,\n      "shipping_amount": "",\n      "shipping_captured": "",\n      "shipping_refunded": ""\n    },\n    "payment_auth_expiration": 0,\n    "payment_authorization_amount": "",\n    "protect_code": "",\n    "quote_address_id": 0,\n    "quote_id": 0,\n    "relation_child_id": "",\n    "relation_child_real_id": "",\n    "relation_parent_id": "",\n    "relation_parent_real_id": "",\n    "remote_ip": "",\n    "shipping_amount": "",\n    "shipping_canceled": "",\n    "shipping_description": "",\n    "shipping_discount_amount": "",\n    "shipping_discount_tax_compensation_amount": "",\n    "shipping_incl_tax": "",\n    "shipping_invoiced": "",\n    "shipping_refunded": "",\n    "shipping_tax_amount": "",\n    "shipping_tax_refunded": "",\n    "state": "",\n    "status": "",\n    "status_histories": [\n      {\n        "comment": "",\n        "created_at": "",\n        "entity_id": 0,\n        "entity_name": "",\n        "extension_attributes": {},\n        "is_customer_notified": 0,\n        "is_visible_on_front": 0,\n        "parent_id": 0,\n        "status": ""\n      }\n    ],\n    "store_currency_code": "",\n    "store_id": 0,\n    "store_name": "",\n    "store_to_base_rate": "",\n    "store_to_order_rate": "",\n    "subtotal": "",\n    "subtotal_canceled": "",\n    "subtotal_incl_tax": "",\n    "subtotal_invoiced": "",\n    "subtotal_refunded": "",\n    "tax_amount": "",\n    "tax_canceled": "",\n    "tax_invoiced": "",\n    "tax_refunded": "",\n    "total_canceled": "",\n    "total_due": "",\n    "total_invoiced": "",\n    "total_item_count": 0,\n    "total_offline_refunded": "",\n    "total_online_refunded": "",\n    "total_paid": "",\n    "total_qty_ordered": "",\n    "total_refunded": "",\n    "updated_at": "",\n    "weight": "",\n    "x_forwarded_for": ""\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  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/orders/create")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/orders/create',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  entity: {
    adjustment_negative: '',
    adjustment_positive: '',
    applied_rule_ids: '',
    base_adjustment_negative: '',
    base_adjustment_positive: '',
    base_currency_code: '',
    base_discount_amount: '',
    base_discount_canceled: '',
    base_discount_invoiced: '',
    base_discount_refunded: '',
    base_discount_tax_compensation_amount: '',
    base_discount_tax_compensation_invoiced: '',
    base_discount_tax_compensation_refunded: '',
    base_grand_total: '',
    base_shipping_amount: '',
    base_shipping_canceled: '',
    base_shipping_discount_amount: '',
    base_shipping_discount_tax_compensation_amnt: '',
    base_shipping_incl_tax: '',
    base_shipping_invoiced: '',
    base_shipping_refunded: '',
    base_shipping_tax_amount: '',
    base_shipping_tax_refunded: '',
    base_subtotal: '',
    base_subtotal_canceled: '',
    base_subtotal_incl_tax: '',
    base_subtotal_invoiced: '',
    base_subtotal_refunded: '',
    base_tax_amount: '',
    base_tax_canceled: '',
    base_tax_invoiced: '',
    base_tax_refunded: '',
    base_to_global_rate: '',
    base_to_order_rate: '',
    base_total_canceled: '',
    base_total_due: '',
    base_total_invoiced: '',
    base_total_invoiced_cost: '',
    base_total_offline_refunded: '',
    base_total_online_refunded: '',
    base_total_paid: '',
    base_total_qty_ordered: '',
    base_total_refunded: '',
    billing_address: {
      address_type: '',
      city: '',
      company: '',
      country_id: '',
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      entity_id: 0,
      extension_attributes: {checkout_fields: [{attribute_code: '', value: ''}]},
      fax: '',
      firstname: '',
      lastname: '',
      middlename: '',
      parent_id: 0,
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: '',
      vat_is_valid: 0,
      vat_request_date: '',
      vat_request_id: '',
      vat_request_success: 0
    },
    billing_address_id: 0,
    can_ship_partially: 0,
    can_ship_partially_item: 0,
    coupon_code: '',
    created_at: '',
    customer_dob: '',
    customer_email: '',
    customer_firstname: '',
    customer_gender: 0,
    customer_group_id: 0,
    customer_id: 0,
    customer_is_guest: 0,
    customer_lastname: '',
    customer_middlename: '',
    customer_note: '',
    customer_note_notify: 0,
    customer_prefix: '',
    customer_suffix: '',
    customer_taxvat: '',
    discount_amount: '',
    discount_canceled: '',
    discount_description: '',
    discount_invoiced: '',
    discount_refunded: '',
    discount_tax_compensation_amount: '',
    discount_tax_compensation_invoiced: '',
    discount_tax_compensation_refunded: '',
    edit_increment: 0,
    email_sent: 0,
    entity_id: 0,
    ext_customer_id: '',
    ext_order_id: '',
    extension_attributes: {
      amazon_order_reference_id: '',
      applied_taxes: [
        {
          amount: '',
          base_amount: '',
          code: '',
          extension_attributes: {rates: [{code: '', extension_attributes: {}, percent: '', title: ''}]},
          percent: '',
          title: ''
        }
      ],
      base_customer_balance_amount: '',
      base_customer_balance_invoiced: '',
      base_customer_balance_refunded: '',
      base_customer_balance_total_refunded: '',
      base_gift_cards_amount: '',
      base_gift_cards_invoiced: '',
      base_gift_cards_refunded: '',
      base_reward_currency_amount: '',
      company_order_attributes: {company_id: 0, company_name: '', extension_attributes: {}, order_id: 0},
      converting_from_quote: false,
      customer_balance_amount: '',
      customer_balance_invoiced: '',
      customer_balance_refunded: '',
      customer_balance_total_refunded: '',
      gift_cards: [{amount: '', base_amount: '', code: '', id: 0}],
      gift_cards_amount: '',
      gift_cards_invoiced: '',
      gift_cards_refunded: '',
      gift_message: {
        customer_id: 0,
        extension_attributes: {
          entity_id: '',
          entity_type: '',
          wrapping_add_printed_card: false,
          wrapping_allow_gift_receipt: false,
          wrapping_id: 0
        },
        gift_message_id: 0,
        message: '',
        recipient: '',
        sender: ''
      },
      gw_add_card: '',
      gw_allow_gift_receipt: '',
      gw_base_price: '',
      gw_base_price_incl_tax: '',
      gw_base_price_invoiced: '',
      gw_base_price_refunded: '',
      gw_base_tax_amount: '',
      gw_base_tax_amount_invoiced: '',
      gw_base_tax_amount_refunded: '',
      gw_card_base_price: '',
      gw_card_base_price_incl_tax: '',
      gw_card_base_price_invoiced: '',
      gw_card_base_price_refunded: '',
      gw_card_base_tax_amount: '',
      gw_card_base_tax_invoiced: '',
      gw_card_base_tax_refunded: '',
      gw_card_price: '',
      gw_card_price_incl_tax: '',
      gw_card_price_invoiced: '',
      gw_card_price_refunded: '',
      gw_card_tax_amount: '',
      gw_card_tax_invoiced: '',
      gw_card_tax_refunded: '',
      gw_id: '',
      gw_items_base_price: '',
      gw_items_base_price_incl_tax: '',
      gw_items_base_price_invoiced: '',
      gw_items_base_price_refunded: '',
      gw_items_base_tax_amount: '',
      gw_items_base_tax_invoiced: '',
      gw_items_base_tax_refunded: '',
      gw_items_price: '',
      gw_items_price_incl_tax: '',
      gw_items_price_invoiced: '',
      gw_items_price_refunded: '',
      gw_items_tax_amount: '',
      gw_items_tax_invoiced: '',
      gw_items_tax_refunded: '',
      gw_price: '',
      gw_price_incl_tax: '',
      gw_price_invoiced: '',
      gw_price_refunded: '',
      gw_tax_amount: '',
      gw_tax_amount_invoiced: '',
      gw_tax_amount_refunded: '',
      item_applied_taxes: [
        {
          applied_taxes: [{}],
          associated_item_id: 0,
          extension_attributes: {},
          item_id: 0,
          type: ''
        }
      ],
      payment_additional_info: [{key: '', value: ''}],
      reward_currency_amount: '',
      reward_points_balance: 0,
      shipping_assignments: [
        {
          extension_attributes: {},
          items: [
            {
              additional_data: '',
              amount_refunded: '',
              applied_rule_ids: '',
              base_amount_refunded: '',
              base_cost: '',
              base_discount_amount: '',
              base_discount_invoiced: '',
              base_discount_refunded: '',
              base_discount_tax_compensation_amount: '',
              base_discount_tax_compensation_invoiced: '',
              base_discount_tax_compensation_refunded: '',
              base_original_price: '',
              base_price: '',
              base_price_incl_tax: '',
              base_row_invoiced: '',
              base_row_total: '',
              base_row_total_incl_tax: '',
              base_tax_amount: '',
              base_tax_before_discount: '',
              base_tax_invoiced: '',
              base_tax_refunded: '',
              base_weee_tax_applied_amount: '',
              base_weee_tax_applied_row_amnt: '',
              base_weee_tax_disposition: '',
              base_weee_tax_row_disposition: '',
              created_at: '',
              description: '',
              discount_amount: '',
              discount_invoiced: '',
              discount_percent: '',
              discount_refunded: '',
              discount_tax_compensation_amount: '',
              discount_tax_compensation_canceled: '',
              discount_tax_compensation_invoiced: '',
              discount_tax_compensation_refunded: '',
              event_id: 0,
              ext_order_item_id: '',
              extension_attributes: {
                gift_message: {},
                gw_base_price: '',
                gw_base_price_invoiced: '',
                gw_base_price_refunded: '',
                gw_base_tax_amount: '',
                gw_base_tax_amount_invoiced: '',
                gw_base_tax_amount_refunded: '',
                gw_id: '',
                gw_price: '',
                gw_price_invoiced: '',
                gw_price_refunded: '',
                gw_tax_amount: '',
                gw_tax_amount_invoiced: '',
                gw_tax_amount_refunded: '',
                invoice_text_codes: [],
                tax_codes: [],
                vertex_tax_codes: []
              },
              free_shipping: 0,
              gw_base_price: '',
              gw_base_price_invoiced: '',
              gw_base_price_refunded: '',
              gw_base_tax_amount: '',
              gw_base_tax_amount_invoiced: '',
              gw_base_tax_amount_refunded: '',
              gw_id: 0,
              gw_price: '',
              gw_price_invoiced: '',
              gw_price_refunded: '',
              gw_tax_amount: '',
              gw_tax_amount_invoiced: '',
              gw_tax_amount_refunded: '',
              is_qty_decimal: 0,
              is_virtual: 0,
              item_id: 0,
              locked_do_invoice: 0,
              locked_do_ship: 0,
              name: '',
              no_discount: 0,
              order_id: 0,
              original_price: '',
              parent_item: '',
              parent_item_id: 0,
              price: '',
              price_incl_tax: '',
              product_id: 0,
              product_option: {
                extension_attributes: {
                  bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                  configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                  custom_options: [
                    {
                      extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                      option_id: '',
                      option_value: ''
                    }
                  ],
                  downloadable_option: {downloadable_links: []},
                  giftcard_item_option: {
                    custom_giftcard_amount: '',
                    extension_attributes: {},
                    giftcard_amount: '',
                    giftcard_message: '',
                    giftcard_recipient_email: '',
                    giftcard_recipient_name: '',
                    giftcard_sender_email: '',
                    giftcard_sender_name: ''
                  }
                }
              },
              product_type: '',
              qty_backordered: '',
              qty_canceled: '',
              qty_invoiced: '',
              qty_ordered: '',
              qty_refunded: '',
              qty_returned: '',
              qty_shipped: '',
              quote_item_id: 0,
              row_invoiced: '',
              row_total: '',
              row_total_incl_tax: '',
              row_weight: '',
              sku: '',
              store_id: 0,
              tax_amount: '',
              tax_before_discount: '',
              tax_canceled: '',
              tax_invoiced: '',
              tax_percent: '',
              tax_refunded: '',
              updated_at: '',
              weee_tax_applied: '',
              weee_tax_applied_amount: '',
              weee_tax_applied_row_amount: '',
              weee_tax_disposition: '',
              weee_tax_row_disposition: '',
              weight: ''
            }
          ],
          shipping: {
            address: {},
            extension_attributes: {
              collection_point: {
                city: '',
                collection_point_id: '',
                country: '',
                name: '',
                postcode: '',
                recipient_address_id: 0,
                region: '',
                street: []
              },
              ext_order_id: '',
              shipping_experience: {code: '', cost: '', label: ''}
            },
            method: '',
            total: {
              base_shipping_amount: '',
              base_shipping_canceled: '',
              base_shipping_discount_amount: '',
              base_shipping_discount_tax_compensation_amnt: '',
              base_shipping_incl_tax: '',
              base_shipping_invoiced: '',
              base_shipping_refunded: '',
              base_shipping_tax_amount: '',
              base_shipping_tax_refunded: '',
              extension_attributes: {},
              shipping_amount: '',
              shipping_canceled: '',
              shipping_discount_amount: '',
              shipping_discount_tax_compensation_amount: '',
              shipping_incl_tax: '',
              shipping_invoiced: '',
              shipping_refunded: '',
              shipping_tax_amount: '',
              shipping_tax_refunded: ''
            }
          },
          stock_id: 0
        }
      ]
    },
    forced_shipment_with_invoice: 0,
    global_currency_code: '',
    grand_total: '',
    hold_before_state: '',
    hold_before_status: '',
    increment_id: '',
    is_virtual: 0,
    items: [{}],
    order_currency_code: '',
    original_increment_id: '',
    payment: {
      account_status: '',
      additional_data: '',
      additional_information: [],
      address_status: '',
      amount_authorized: '',
      amount_canceled: '',
      amount_ordered: '',
      amount_paid: '',
      amount_refunded: '',
      anet_trans_method: '',
      base_amount_authorized: '',
      base_amount_canceled: '',
      base_amount_ordered: '',
      base_amount_paid: '',
      base_amount_paid_online: '',
      base_amount_refunded: '',
      base_amount_refunded_online: '',
      base_shipping_amount: '',
      base_shipping_captured: '',
      base_shipping_refunded: '',
      cc_approval: '',
      cc_avs_status: '',
      cc_cid_status: '',
      cc_debug_request_body: '',
      cc_debug_response_body: '',
      cc_debug_response_serialized: '',
      cc_exp_month: '',
      cc_exp_year: '',
      cc_last4: '',
      cc_number_enc: '',
      cc_owner: '',
      cc_secure_verify: '',
      cc_ss_issue: '',
      cc_ss_start_month: '',
      cc_ss_start_year: '',
      cc_status: '',
      cc_status_description: '',
      cc_trans_id: '',
      cc_type: '',
      echeck_account_name: '',
      echeck_account_type: '',
      echeck_bank_name: '',
      echeck_routing_number: '',
      echeck_type: '',
      entity_id: 0,
      extension_attributes: {
        vault_payment_token: {
          created_at: '',
          customer_id: 0,
          entity_id: 0,
          expires_at: '',
          gateway_token: '',
          is_active: false,
          is_visible: false,
          payment_method_code: '',
          public_hash: '',
          token_details: '',
          type: ''
        }
      },
      last_trans_id: '',
      method: '',
      parent_id: 0,
      po_number: '',
      protection_eligibility: '',
      quote_payment_id: 0,
      shipping_amount: '',
      shipping_captured: '',
      shipping_refunded: ''
    },
    payment_auth_expiration: 0,
    payment_authorization_amount: '',
    protect_code: '',
    quote_address_id: 0,
    quote_id: 0,
    relation_child_id: '',
    relation_child_real_id: '',
    relation_parent_id: '',
    relation_parent_real_id: '',
    remote_ip: '',
    shipping_amount: '',
    shipping_canceled: '',
    shipping_description: '',
    shipping_discount_amount: '',
    shipping_discount_tax_compensation_amount: '',
    shipping_incl_tax: '',
    shipping_invoiced: '',
    shipping_refunded: '',
    shipping_tax_amount: '',
    shipping_tax_refunded: '',
    state: '',
    status: '',
    status_histories: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        entity_name: '',
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0,
        status: ''
      }
    ],
    store_currency_code: '',
    store_id: 0,
    store_name: '',
    store_to_base_rate: '',
    store_to_order_rate: '',
    subtotal: '',
    subtotal_canceled: '',
    subtotal_incl_tax: '',
    subtotal_invoiced: '',
    subtotal_refunded: '',
    tax_amount: '',
    tax_canceled: '',
    tax_invoiced: '',
    tax_refunded: '',
    total_canceled: '',
    total_due: '',
    total_invoiced: '',
    total_item_count: 0,
    total_offline_refunded: '',
    total_online_refunded: '',
    total_paid: '',
    total_qty_ordered: '',
    total_refunded: '',
    updated_at: '',
    weight: '',
    x_forwarded_for: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/orders/create',
  headers: {'content-type': 'application/json'},
  body: {
    entity: {
      adjustment_negative: '',
      adjustment_positive: '',
      applied_rule_ids: '',
      base_adjustment_negative: '',
      base_adjustment_positive: '',
      base_currency_code: '',
      base_discount_amount: '',
      base_discount_canceled: '',
      base_discount_invoiced: '',
      base_discount_refunded: '',
      base_discount_tax_compensation_amount: '',
      base_discount_tax_compensation_invoiced: '',
      base_discount_tax_compensation_refunded: '',
      base_grand_total: '',
      base_shipping_amount: '',
      base_shipping_canceled: '',
      base_shipping_discount_amount: '',
      base_shipping_discount_tax_compensation_amnt: '',
      base_shipping_incl_tax: '',
      base_shipping_invoiced: '',
      base_shipping_refunded: '',
      base_shipping_tax_amount: '',
      base_shipping_tax_refunded: '',
      base_subtotal: '',
      base_subtotal_canceled: '',
      base_subtotal_incl_tax: '',
      base_subtotal_invoiced: '',
      base_subtotal_refunded: '',
      base_tax_amount: '',
      base_tax_canceled: '',
      base_tax_invoiced: '',
      base_tax_refunded: '',
      base_to_global_rate: '',
      base_to_order_rate: '',
      base_total_canceled: '',
      base_total_due: '',
      base_total_invoiced: '',
      base_total_invoiced_cost: '',
      base_total_offline_refunded: '',
      base_total_online_refunded: '',
      base_total_paid: '',
      base_total_qty_ordered: '',
      base_total_refunded: '',
      billing_address: {
        address_type: '',
        city: '',
        company: '',
        country_id: '',
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        entity_id: 0,
        extension_attributes: {checkout_fields: [{attribute_code: '', value: ''}]},
        fax: '',
        firstname: '',
        lastname: '',
        middlename: '',
        parent_id: 0,
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: '',
        vat_is_valid: 0,
        vat_request_date: '',
        vat_request_id: '',
        vat_request_success: 0
      },
      billing_address_id: 0,
      can_ship_partially: 0,
      can_ship_partially_item: 0,
      coupon_code: '',
      created_at: '',
      customer_dob: '',
      customer_email: '',
      customer_firstname: '',
      customer_gender: 0,
      customer_group_id: 0,
      customer_id: 0,
      customer_is_guest: 0,
      customer_lastname: '',
      customer_middlename: '',
      customer_note: '',
      customer_note_notify: 0,
      customer_prefix: '',
      customer_suffix: '',
      customer_taxvat: '',
      discount_amount: '',
      discount_canceled: '',
      discount_description: '',
      discount_invoiced: '',
      discount_refunded: '',
      discount_tax_compensation_amount: '',
      discount_tax_compensation_invoiced: '',
      discount_tax_compensation_refunded: '',
      edit_increment: 0,
      email_sent: 0,
      entity_id: 0,
      ext_customer_id: '',
      ext_order_id: '',
      extension_attributes: {
        amazon_order_reference_id: '',
        applied_taxes: [
          {
            amount: '',
            base_amount: '',
            code: '',
            extension_attributes: {rates: [{code: '', extension_attributes: {}, percent: '', title: ''}]},
            percent: '',
            title: ''
          }
        ],
        base_customer_balance_amount: '',
        base_customer_balance_invoiced: '',
        base_customer_balance_refunded: '',
        base_customer_balance_total_refunded: '',
        base_gift_cards_amount: '',
        base_gift_cards_invoiced: '',
        base_gift_cards_refunded: '',
        base_reward_currency_amount: '',
        company_order_attributes: {company_id: 0, company_name: '', extension_attributes: {}, order_id: 0},
        converting_from_quote: false,
        customer_balance_amount: '',
        customer_balance_invoiced: '',
        customer_balance_refunded: '',
        customer_balance_total_refunded: '',
        gift_cards: [{amount: '', base_amount: '', code: '', id: 0}],
        gift_cards_amount: '',
        gift_cards_invoiced: '',
        gift_cards_refunded: '',
        gift_message: {
          customer_id: 0,
          extension_attributes: {
            entity_id: '',
            entity_type: '',
            wrapping_add_printed_card: false,
            wrapping_allow_gift_receipt: false,
            wrapping_id: 0
          },
          gift_message_id: 0,
          message: '',
          recipient: '',
          sender: ''
        },
        gw_add_card: '',
        gw_allow_gift_receipt: '',
        gw_base_price: '',
        gw_base_price_incl_tax: '',
        gw_base_price_invoiced: '',
        gw_base_price_refunded: '',
        gw_base_tax_amount: '',
        gw_base_tax_amount_invoiced: '',
        gw_base_tax_amount_refunded: '',
        gw_card_base_price: '',
        gw_card_base_price_incl_tax: '',
        gw_card_base_price_invoiced: '',
        gw_card_base_price_refunded: '',
        gw_card_base_tax_amount: '',
        gw_card_base_tax_invoiced: '',
        gw_card_base_tax_refunded: '',
        gw_card_price: '',
        gw_card_price_incl_tax: '',
        gw_card_price_invoiced: '',
        gw_card_price_refunded: '',
        gw_card_tax_amount: '',
        gw_card_tax_invoiced: '',
        gw_card_tax_refunded: '',
        gw_id: '',
        gw_items_base_price: '',
        gw_items_base_price_incl_tax: '',
        gw_items_base_price_invoiced: '',
        gw_items_base_price_refunded: '',
        gw_items_base_tax_amount: '',
        gw_items_base_tax_invoiced: '',
        gw_items_base_tax_refunded: '',
        gw_items_price: '',
        gw_items_price_incl_tax: '',
        gw_items_price_invoiced: '',
        gw_items_price_refunded: '',
        gw_items_tax_amount: '',
        gw_items_tax_invoiced: '',
        gw_items_tax_refunded: '',
        gw_price: '',
        gw_price_incl_tax: '',
        gw_price_invoiced: '',
        gw_price_refunded: '',
        gw_tax_amount: '',
        gw_tax_amount_invoiced: '',
        gw_tax_amount_refunded: '',
        item_applied_taxes: [
          {
            applied_taxes: [{}],
            associated_item_id: 0,
            extension_attributes: {},
            item_id: 0,
            type: ''
          }
        ],
        payment_additional_info: [{key: '', value: ''}],
        reward_currency_amount: '',
        reward_points_balance: 0,
        shipping_assignments: [
          {
            extension_attributes: {},
            items: [
              {
                additional_data: '',
                amount_refunded: '',
                applied_rule_ids: '',
                base_amount_refunded: '',
                base_cost: '',
                base_discount_amount: '',
                base_discount_invoiced: '',
                base_discount_refunded: '',
                base_discount_tax_compensation_amount: '',
                base_discount_tax_compensation_invoiced: '',
                base_discount_tax_compensation_refunded: '',
                base_original_price: '',
                base_price: '',
                base_price_incl_tax: '',
                base_row_invoiced: '',
                base_row_total: '',
                base_row_total_incl_tax: '',
                base_tax_amount: '',
                base_tax_before_discount: '',
                base_tax_invoiced: '',
                base_tax_refunded: '',
                base_weee_tax_applied_amount: '',
                base_weee_tax_applied_row_amnt: '',
                base_weee_tax_disposition: '',
                base_weee_tax_row_disposition: '',
                created_at: '',
                description: '',
                discount_amount: '',
                discount_invoiced: '',
                discount_percent: '',
                discount_refunded: '',
                discount_tax_compensation_amount: '',
                discount_tax_compensation_canceled: '',
                discount_tax_compensation_invoiced: '',
                discount_tax_compensation_refunded: '',
                event_id: 0,
                ext_order_item_id: '',
                extension_attributes: {
                  gift_message: {},
                  gw_base_price: '',
                  gw_base_price_invoiced: '',
                  gw_base_price_refunded: '',
                  gw_base_tax_amount: '',
                  gw_base_tax_amount_invoiced: '',
                  gw_base_tax_amount_refunded: '',
                  gw_id: '',
                  gw_price: '',
                  gw_price_invoiced: '',
                  gw_price_refunded: '',
                  gw_tax_amount: '',
                  gw_tax_amount_invoiced: '',
                  gw_tax_amount_refunded: '',
                  invoice_text_codes: [],
                  tax_codes: [],
                  vertex_tax_codes: []
                },
                free_shipping: 0,
                gw_base_price: '',
                gw_base_price_invoiced: '',
                gw_base_price_refunded: '',
                gw_base_tax_amount: '',
                gw_base_tax_amount_invoiced: '',
                gw_base_tax_amount_refunded: '',
                gw_id: 0,
                gw_price: '',
                gw_price_invoiced: '',
                gw_price_refunded: '',
                gw_tax_amount: '',
                gw_tax_amount_invoiced: '',
                gw_tax_amount_refunded: '',
                is_qty_decimal: 0,
                is_virtual: 0,
                item_id: 0,
                locked_do_invoice: 0,
                locked_do_ship: 0,
                name: '',
                no_discount: 0,
                order_id: 0,
                original_price: '',
                parent_item: '',
                parent_item_id: 0,
                price: '',
                price_incl_tax: '',
                product_id: 0,
                product_option: {
                  extension_attributes: {
                    bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                    configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                    custom_options: [
                      {
                        extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                        option_id: '',
                        option_value: ''
                      }
                    ],
                    downloadable_option: {downloadable_links: []},
                    giftcard_item_option: {
                      custom_giftcard_amount: '',
                      extension_attributes: {},
                      giftcard_amount: '',
                      giftcard_message: '',
                      giftcard_recipient_email: '',
                      giftcard_recipient_name: '',
                      giftcard_sender_email: '',
                      giftcard_sender_name: ''
                    }
                  }
                },
                product_type: '',
                qty_backordered: '',
                qty_canceled: '',
                qty_invoiced: '',
                qty_ordered: '',
                qty_refunded: '',
                qty_returned: '',
                qty_shipped: '',
                quote_item_id: 0,
                row_invoiced: '',
                row_total: '',
                row_total_incl_tax: '',
                row_weight: '',
                sku: '',
                store_id: 0,
                tax_amount: '',
                tax_before_discount: '',
                tax_canceled: '',
                tax_invoiced: '',
                tax_percent: '',
                tax_refunded: '',
                updated_at: '',
                weee_tax_applied: '',
                weee_tax_applied_amount: '',
                weee_tax_applied_row_amount: '',
                weee_tax_disposition: '',
                weee_tax_row_disposition: '',
                weight: ''
              }
            ],
            shipping: {
              address: {},
              extension_attributes: {
                collection_point: {
                  city: '',
                  collection_point_id: '',
                  country: '',
                  name: '',
                  postcode: '',
                  recipient_address_id: 0,
                  region: '',
                  street: []
                },
                ext_order_id: '',
                shipping_experience: {code: '', cost: '', label: ''}
              },
              method: '',
              total: {
                base_shipping_amount: '',
                base_shipping_canceled: '',
                base_shipping_discount_amount: '',
                base_shipping_discount_tax_compensation_amnt: '',
                base_shipping_incl_tax: '',
                base_shipping_invoiced: '',
                base_shipping_refunded: '',
                base_shipping_tax_amount: '',
                base_shipping_tax_refunded: '',
                extension_attributes: {},
                shipping_amount: '',
                shipping_canceled: '',
                shipping_discount_amount: '',
                shipping_discount_tax_compensation_amount: '',
                shipping_incl_tax: '',
                shipping_invoiced: '',
                shipping_refunded: '',
                shipping_tax_amount: '',
                shipping_tax_refunded: ''
              }
            },
            stock_id: 0
          }
        ]
      },
      forced_shipment_with_invoice: 0,
      global_currency_code: '',
      grand_total: '',
      hold_before_state: '',
      hold_before_status: '',
      increment_id: '',
      is_virtual: 0,
      items: [{}],
      order_currency_code: '',
      original_increment_id: '',
      payment: {
        account_status: '',
        additional_data: '',
        additional_information: [],
        address_status: '',
        amount_authorized: '',
        amount_canceled: '',
        amount_ordered: '',
        amount_paid: '',
        amount_refunded: '',
        anet_trans_method: '',
        base_amount_authorized: '',
        base_amount_canceled: '',
        base_amount_ordered: '',
        base_amount_paid: '',
        base_amount_paid_online: '',
        base_amount_refunded: '',
        base_amount_refunded_online: '',
        base_shipping_amount: '',
        base_shipping_captured: '',
        base_shipping_refunded: '',
        cc_approval: '',
        cc_avs_status: '',
        cc_cid_status: '',
        cc_debug_request_body: '',
        cc_debug_response_body: '',
        cc_debug_response_serialized: '',
        cc_exp_month: '',
        cc_exp_year: '',
        cc_last4: '',
        cc_number_enc: '',
        cc_owner: '',
        cc_secure_verify: '',
        cc_ss_issue: '',
        cc_ss_start_month: '',
        cc_ss_start_year: '',
        cc_status: '',
        cc_status_description: '',
        cc_trans_id: '',
        cc_type: '',
        echeck_account_name: '',
        echeck_account_type: '',
        echeck_bank_name: '',
        echeck_routing_number: '',
        echeck_type: '',
        entity_id: 0,
        extension_attributes: {
          vault_payment_token: {
            created_at: '',
            customer_id: 0,
            entity_id: 0,
            expires_at: '',
            gateway_token: '',
            is_active: false,
            is_visible: false,
            payment_method_code: '',
            public_hash: '',
            token_details: '',
            type: ''
          }
        },
        last_trans_id: '',
        method: '',
        parent_id: 0,
        po_number: '',
        protection_eligibility: '',
        quote_payment_id: 0,
        shipping_amount: '',
        shipping_captured: '',
        shipping_refunded: ''
      },
      payment_auth_expiration: 0,
      payment_authorization_amount: '',
      protect_code: '',
      quote_address_id: 0,
      quote_id: 0,
      relation_child_id: '',
      relation_child_real_id: '',
      relation_parent_id: '',
      relation_parent_real_id: '',
      remote_ip: '',
      shipping_amount: '',
      shipping_canceled: '',
      shipping_description: '',
      shipping_discount_amount: '',
      shipping_discount_tax_compensation_amount: '',
      shipping_incl_tax: '',
      shipping_invoiced: '',
      shipping_refunded: '',
      shipping_tax_amount: '',
      shipping_tax_refunded: '',
      state: '',
      status: '',
      status_histories: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          entity_name: '',
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0,
          status: ''
        }
      ],
      store_currency_code: '',
      store_id: 0,
      store_name: '',
      store_to_base_rate: '',
      store_to_order_rate: '',
      subtotal: '',
      subtotal_canceled: '',
      subtotal_incl_tax: '',
      subtotal_invoiced: '',
      subtotal_refunded: '',
      tax_amount: '',
      tax_canceled: '',
      tax_invoiced: '',
      tax_refunded: '',
      total_canceled: '',
      total_due: '',
      total_invoiced: '',
      total_item_count: 0,
      total_offline_refunded: '',
      total_online_refunded: '',
      total_paid: '',
      total_qty_ordered: '',
      total_refunded: '',
      updated_at: '',
      weight: '',
      x_forwarded_for: ''
    }
  },
  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}}/V1/orders/create');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  entity: {
    adjustment_negative: '',
    adjustment_positive: '',
    applied_rule_ids: '',
    base_adjustment_negative: '',
    base_adjustment_positive: '',
    base_currency_code: '',
    base_discount_amount: '',
    base_discount_canceled: '',
    base_discount_invoiced: '',
    base_discount_refunded: '',
    base_discount_tax_compensation_amount: '',
    base_discount_tax_compensation_invoiced: '',
    base_discount_tax_compensation_refunded: '',
    base_grand_total: '',
    base_shipping_amount: '',
    base_shipping_canceled: '',
    base_shipping_discount_amount: '',
    base_shipping_discount_tax_compensation_amnt: '',
    base_shipping_incl_tax: '',
    base_shipping_invoiced: '',
    base_shipping_refunded: '',
    base_shipping_tax_amount: '',
    base_shipping_tax_refunded: '',
    base_subtotal: '',
    base_subtotal_canceled: '',
    base_subtotal_incl_tax: '',
    base_subtotal_invoiced: '',
    base_subtotal_refunded: '',
    base_tax_amount: '',
    base_tax_canceled: '',
    base_tax_invoiced: '',
    base_tax_refunded: '',
    base_to_global_rate: '',
    base_to_order_rate: '',
    base_total_canceled: '',
    base_total_due: '',
    base_total_invoiced: '',
    base_total_invoiced_cost: '',
    base_total_offline_refunded: '',
    base_total_online_refunded: '',
    base_total_paid: '',
    base_total_qty_ordered: '',
    base_total_refunded: '',
    billing_address: {
      address_type: '',
      city: '',
      company: '',
      country_id: '',
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      entity_id: 0,
      extension_attributes: {
        checkout_fields: [
          {
            attribute_code: '',
            value: ''
          }
        ]
      },
      fax: '',
      firstname: '',
      lastname: '',
      middlename: '',
      parent_id: 0,
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: '',
      vat_is_valid: 0,
      vat_request_date: '',
      vat_request_id: '',
      vat_request_success: 0
    },
    billing_address_id: 0,
    can_ship_partially: 0,
    can_ship_partially_item: 0,
    coupon_code: '',
    created_at: '',
    customer_dob: '',
    customer_email: '',
    customer_firstname: '',
    customer_gender: 0,
    customer_group_id: 0,
    customer_id: 0,
    customer_is_guest: 0,
    customer_lastname: '',
    customer_middlename: '',
    customer_note: '',
    customer_note_notify: 0,
    customer_prefix: '',
    customer_suffix: '',
    customer_taxvat: '',
    discount_amount: '',
    discount_canceled: '',
    discount_description: '',
    discount_invoiced: '',
    discount_refunded: '',
    discount_tax_compensation_amount: '',
    discount_tax_compensation_invoiced: '',
    discount_tax_compensation_refunded: '',
    edit_increment: 0,
    email_sent: 0,
    entity_id: 0,
    ext_customer_id: '',
    ext_order_id: '',
    extension_attributes: {
      amazon_order_reference_id: '',
      applied_taxes: [
        {
          amount: '',
          base_amount: '',
          code: '',
          extension_attributes: {
            rates: [
              {
                code: '',
                extension_attributes: {},
                percent: '',
                title: ''
              }
            ]
          },
          percent: '',
          title: ''
        }
      ],
      base_customer_balance_amount: '',
      base_customer_balance_invoiced: '',
      base_customer_balance_refunded: '',
      base_customer_balance_total_refunded: '',
      base_gift_cards_amount: '',
      base_gift_cards_invoiced: '',
      base_gift_cards_refunded: '',
      base_reward_currency_amount: '',
      company_order_attributes: {
        company_id: 0,
        company_name: '',
        extension_attributes: {},
        order_id: 0
      },
      converting_from_quote: false,
      customer_balance_amount: '',
      customer_balance_invoiced: '',
      customer_balance_refunded: '',
      customer_balance_total_refunded: '',
      gift_cards: [
        {
          amount: '',
          base_amount: '',
          code: '',
          id: 0
        }
      ],
      gift_cards_amount: '',
      gift_cards_invoiced: '',
      gift_cards_refunded: '',
      gift_message: {
        customer_id: 0,
        extension_attributes: {
          entity_id: '',
          entity_type: '',
          wrapping_add_printed_card: false,
          wrapping_allow_gift_receipt: false,
          wrapping_id: 0
        },
        gift_message_id: 0,
        message: '',
        recipient: '',
        sender: ''
      },
      gw_add_card: '',
      gw_allow_gift_receipt: '',
      gw_base_price: '',
      gw_base_price_incl_tax: '',
      gw_base_price_invoiced: '',
      gw_base_price_refunded: '',
      gw_base_tax_amount: '',
      gw_base_tax_amount_invoiced: '',
      gw_base_tax_amount_refunded: '',
      gw_card_base_price: '',
      gw_card_base_price_incl_tax: '',
      gw_card_base_price_invoiced: '',
      gw_card_base_price_refunded: '',
      gw_card_base_tax_amount: '',
      gw_card_base_tax_invoiced: '',
      gw_card_base_tax_refunded: '',
      gw_card_price: '',
      gw_card_price_incl_tax: '',
      gw_card_price_invoiced: '',
      gw_card_price_refunded: '',
      gw_card_tax_amount: '',
      gw_card_tax_invoiced: '',
      gw_card_tax_refunded: '',
      gw_id: '',
      gw_items_base_price: '',
      gw_items_base_price_incl_tax: '',
      gw_items_base_price_invoiced: '',
      gw_items_base_price_refunded: '',
      gw_items_base_tax_amount: '',
      gw_items_base_tax_invoiced: '',
      gw_items_base_tax_refunded: '',
      gw_items_price: '',
      gw_items_price_incl_tax: '',
      gw_items_price_invoiced: '',
      gw_items_price_refunded: '',
      gw_items_tax_amount: '',
      gw_items_tax_invoiced: '',
      gw_items_tax_refunded: '',
      gw_price: '',
      gw_price_incl_tax: '',
      gw_price_invoiced: '',
      gw_price_refunded: '',
      gw_tax_amount: '',
      gw_tax_amount_invoiced: '',
      gw_tax_amount_refunded: '',
      item_applied_taxes: [
        {
          applied_taxes: [
            {}
          ],
          associated_item_id: 0,
          extension_attributes: {},
          item_id: 0,
          type: ''
        }
      ],
      payment_additional_info: [
        {
          key: '',
          value: ''
        }
      ],
      reward_currency_amount: '',
      reward_points_balance: 0,
      shipping_assignments: [
        {
          extension_attributes: {},
          items: [
            {
              additional_data: '',
              amount_refunded: '',
              applied_rule_ids: '',
              base_amount_refunded: '',
              base_cost: '',
              base_discount_amount: '',
              base_discount_invoiced: '',
              base_discount_refunded: '',
              base_discount_tax_compensation_amount: '',
              base_discount_tax_compensation_invoiced: '',
              base_discount_tax_compensation_refunded: '',
              base_original_price: '',
              base_price: '',
              base_price_incl_tax: '',
              base_row_invoiced: '',
              base_row_total: '',
              base_row_total_incl_tax: '',
              base_tax_amount: '',
              base_tax_before_discount: '',
              base_tax_invoiced: '',
              base_tax_refunded: '',
              base_weee_tax_applied_amount: '',
              base_weee_tax_applied_row_amnt: '',
              base_weee_tax_disposition: '',
              base_weee_tax_row_disposition: '',
              created_at: '',
              description: '',
              discount_amount: '',
              discount_invoiced: '',
              discount_percent: '',
              discount_refunded: '',
              discount_tax_compensation_amount: '',
              discount_tax_compensation_canceled: '',
              discount_tax_compensation_invoiced: '',
              discount_tax_compensation_refunded: '',
              event_id: 0,
              ext_order_item_id: '',
              extension_attributes: {
                gift_message: {},
                gw_base_price: '',
                gw_base_price_invoiced: '',
                gw_base_price_refunded: '',
                gw_base_tax_amount: '',
                gw_base_tax_amount_invoiced: '',
                gw_base_tax_amount_refunded: '',
                gw_id: '',
                gw_price: '',
                gw_price_invoiced: '',
                gw_price_refunded: '',
                gw_tax_amount: '',
                gw_tax_amount_invoiced: '',
                gw_tax_amount_refunded: '',
                invoice_text_codes: [],
                tax_codes: [],
                vertex_tax_codes: []
              },
              free_shipping: 0,
              gw_base_price: '',
              gw_base_price_invoiced: '',
              gw_base_price_refunded: '',
              gw_base_tax_amount: '',
              gw_base_tax_amount_invoiced: '',
              gw_base_tax_amount_refunded: '',
              gw_id: 0,
              gw_price: '',
              gw_price_invoiced: '',
              gw_price_refunded: '',
              gw_tax_amount: '',
              gw_tax_amount_invoiced: '',
              gw_tax_amount_refunded: '',
              is_qty_decimal: 0,
              is_virtual: 0,
              item_id: 0,
              locked_do_invoice: 0,
              locked_do_ship: 0,
              name: '',
              no_discount: 0,
              order_id: 0,
              original_price: '',
              parent_item: '',
              parent_item_id: 0,
              price: '',
              price_incl_tax: '',
              product_id: 0,
              product_option: {
                extension_attributes: {
                  bundle_options: [
                    {
                      extension_attributes: {},
                      option_id: 0,
                      option_qty: 0,
                      option_selections: []
                    }
                  ],
                  configurable_item_options: [
                    {
                      extension_attributes: {},
                      option_id: '',
                      option_value: 0
                    }
                  ],
                  custom_options: [
                    {
                      extension_attributes: {
                        file_info: {
                          base64_encoded_data: '',
                          name: '',
                          type: ''
                        }
                      },
                      option_id: '',
                      option_value: ''
                    }
                  ],
                  downloadable_option: {
                    downloadable_links: []
                  },
                  giftcard_item_option: {
                    custom_giftcard_amount: '',
                    extension_attributes: {},
                    giftcard_amount: '',
                    giftcard_message: '',
                    giftcard_recipient_email: '',
                    giftcard_recipient_name: '',
                    giftcard_sender_email: '',
                    giftcard_sender_name: ''
                  }
                }
              },
              product_type: '',
              qty_backordered: '',
              qty_canceled: '',
              qty_invoiced: '',
              qty_ordered: '',
              qty_refunded: '',
              qty_returned: '',
              qty_shipped: '',
              quote_item_id: 0,
              row_invoiced: '',
              row_total: '',
              row_total_incl_tax: '',
              row_weight: '',
              sku: '',
              store_id: 0,
              tax_amount: '',
              tax_before_discount: '',
              tax_canceled: '',
              tax_invoiced: '',
              tax_percent: '',
              tax_refunded: '',
              updated_at: '',
              weee_tax_applied: '',
              weee_tax_applied_amount: '',
              weee_tax_applied_row_amount: '',
              weee_tax_disposition: '',
              weee_tax_row_disposition: '',
              weight: ''
            }
          ],
          shipping: {
            address: {},
            extension_attributes: {
              collection_point: {
                city: '',
                collection_point_id: '',
                country: '',
                name: '',
                postcode: '',
                recipient_address_id: 0,
                region: '',
                street: []
              },
              ext_order_id: '',
              shipping_experience: {
                code: '',
                cost: '',
                label: ''
              }
            },
            method: '',
            total: {
              base_shipping_amount: '',
              base_shipping_canceled: '',
              base_shipping_discount_amount: '',
              base_shipping_discount_tax_compensation_amnt: '',
              base_shipping_incl_tax: '',
              base_shipping_invoiced: '',
              base_shipping_refunded: '',
              base_shipping_tax_amount: '',
              base_shipping_tax_refunded: '',
              extension_attributes: {},
              shipping_amount: '',
              shipping_canceled: '',
              shipping_discount_amount: '',
              shipping_discount_tax_compensation_amount: '',
              shipping_incl_tax: '',
              shipping_invoiced: '',
              shipping_refunded: '',
              shipping_tax_amount: '',
              shipping_tax_refunded: ''
            }
          },
          stock_id: 0
        }
      ]
    },
    forced_shipment_with_invoice: 0,
    global_currency_code: '',
    grand_total: '',
    hold_before_state: '',
    hold_before_status: '',
    increment_id: '',
    is_virtual: 0,
    items: [
      {}
    ],
    order_currency_code: '',
    original_increment_id: '',
    payment: {
      account_status: '',
      additional_data: '',
      additional_information: [],
      address_status: '',
      amount_authorized: '',
      amount_canceled: '',
      amount_ordered: '',
      amount_paid: '',
      amount_refunded: '',
      anet_trans_method: '',
      base_amount_authorized: '',
      base_amount_canceled: '',
      base_amount_ordered: '',
      base_amount_paid: '',
      base_amount_paid_online: '',
      base_amount_refunded: '',
      base_amount_refunded_online: '',
      base_shipping_amount: '',
      base_shipping_captured: '',
      base_shipping_refunded: '',
      cc_approval: '',
      cc_avs_status: '',
      cc_cid_status: '',
      cc_debug_request_body: '',
      cc_debug_response_body: '',
      cc_debug_response_serialized: '',
      cc_exp_month: '',
      cc_exp_year: '',
      cc_last4: '',
      cc_number_enc: '',
      cc_owner: '',
      cc_secure_verify: '',
      cc_ss_issue: '',
      cc_ss_start_month: '',
      cc_ss_start_year: '',
      cc_status: '',
      cc_status_description: '',
      cc_trans_id: '',
      cc_type: '',
      echeck_account_name: '',
      echeck_account_type: '',
      echeck_bank_name: '',
      echeck_routing_number: '',
      echeck_type: '',
      entity_id: 0,
      extension_attributes: {
        vault_payment_token: {
          created_at: '',
          customer_id: 0,
          entity_id: 0,
          expires_at: '',
          gateway_token: '',
          is_active: false,
          is_visible: false,
          payment_method_code: '',
          public_hash: '',
          token_details: '',
          type: ''
        }
      },
      last_trans_id: '',
      method: '',
      parent_id: 0,
      po_number: '',
      protection_eligibility: '',
      quote_payment_id: 0,
      shipping_amount: '',
      shipping_captured: '',
      shipping_refunded: ''
    },
    payment_auth_expiration: 0,
    payment_authorization_amount: '',
    protect_code: '',
    quote_address_id: 0,
    quote_id: 0,
    relation_child_id: '',
    relation_child_real_id: '',
    relation_parent_id: '',
    relation_parent_real_id: '',
    remote_ip: '',
    shipping_amount: '',
    shipping_canceled: '',
    shipping_description: '',
    shipping_discount_amount: '',
    shipping_discount_tax_compensation_amount: '',
    shipping_incl_tax: '',
    shipping_invoiced: '',
    shipping_refunded: '',
    shipping_tax_amount: '',
    shipping_tax_refunded: '',
    state: '',
    status: '',
    status_histories: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        entity_name: '',
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0,
        status: ''
      }
    ],
    store_currency_code: '',
    store_id: 0,
    store_name: '',
    store_to_base_rate: '',
    store_to_order_rate: '',
    subtotal: '',
    subtotal_canceled: '',
    subtotal_incl_tax: '',
    subtotal_invoiced: '',
    subtotal_refunded: '',
    tax_amount: '',
    tax_canceled: '',
    tax_invoiced: '',
    tax_refunded: '',
    total_canceled: '',
    total_due: '',
    total_invoiced: '',
    total_item_count: 0,
    total_offline_refunded: '',
    total_online_refunded: '',
    total_paid: '',
    total_qty_ordered: '',
    total_refunded: '',
    updated_at: '',
    weight: '',
    x_forwarded_for: ''
  }
});

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}}/V1/orders/create',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      adjustment_negative: '',
      adjustment_positive: '',
      applied_rule_ids: '',
      base_adjustment_negative: '',
      base_adjustment_positive: '',
      base_currency_code: '',
      base_discount_amount: '',
      base_discount_canceled: '',
      base_discount_invoiced: '',
      base_discount_refunded: '',
      base_discount_tax_compensation_amount: '',
      base_discount_tax_compensation_invoiced: '',
      base_discount_tax_compensation_refunded: '',
      base_grand_total: '',
      base_shipping_amount: '',
      base_shipping_canceled: '',
      base_shipping_discount_amount: '',
      base_shipping_discount_tax_compensation_amnt: '',
      base_shipping_incl_tax: '',
      base_shipping_invoiced: '',
      base_shipping_refunded: '',
      base_shipping_tax_amount: '',
      base_shipping_tax_refunded: '',
      base_subtotal: '',
      base_subtotal_canceled: '',
      base_subtotal_incl_tax: '',
      base_subtotal_invoiced: '',
      base_subtotal_refunded: '',
      base_tax_amount: '',
      base_tax_canceled: '',
      base_tax_invoiced: '',
      base_tax_refunded: '',
      base_to_global_rate: '',
      base_to_order_rate: '',
      base_total_canceled: '',
      base_total_due: '',
      base_total_invoiced: '',
      base_total_invoiced_cost: '',
      base_total_offline_refunded: '',
      base_total_online_refunded: '',
      base_total_paid: '',
      base_total_qty_ordered: '',
      base_total_refunded: '',
      billing_address: {
        address_type: '',
        city: '',
        company: '',
        country_id: '',
        customer_address_id: 0,
        customer_id: 0,
        email: '',
        entity_id: 0,
        extension_attributes: {checkout_fields: [{attribute_code: '', value: ''}]},
        fax: '',
        firstname: '',
        lastname: '',
        middlename: '',
        parent_id: 0,
        postcode: '',
        prefix: '',
        region: '',
        region_code: '',
        region_id: 0,
        street: [],
        suffix: '',
        telephone: '',
        vat_id: '',
        vat_is_valid: 0,
        vat_request_date: '',
        vat_request_id: '',
        vat_request_success: 0
      },
      billing_address_id: 0,
      can_ship_partially: 0,
      can_ship_partially_item: 0,
      coupon_code: '',
      created_at: '',
      customer_dob: '',
      customer_email: '',
      customer_firstname: '',
      customer_gender: 0,
      customer_group_id: 0,
      customer_id: 0,
      customer_is_guest: 0,
      customer_lastname: '',
      customer_middlename: '',
      customer_note: '',
      customer_note_notify: 0,
      customer_prefix: '',
      customer_suffix: '',
      customer_taxvat: '',
      discount_amount: '',
      discount_canceled: '',
      discount_description: '',
      discount_invoiced: '',
      discount_refunded: '',
      discount_tax_compensation_amount: '',
      discount_tax_compensation_invoiced: '',
      discount_tax_compensation_refunded: '',
      edit_increment: 0,
      email_sent: 0,
      entity_id: 0,
      ext_customer_id: '',
      ext_order_id: '',
      extension_attributes: {
        amazon_order_reference_id: '',
        applied_taxes: [
          {
            amount: '',
            base_amount: '',
            code: '',
            extension_attributes: {rates: [{code: '', extension_attributes: {}, percent: '', title: ''}]},
            percent: '',
            title: ''
          }
        ],
        base_customer_balance_amount: '',
        base_customer_balance_invoiced: '',
        base_customer_balance_refunded: '',
        base_customer_balance_total_refunded: '',
        base_gift_cards_amount: '',
        base_gift_cards_invoiced: '',
        base_gift_cards_refunded: '',
        base_reward_currency_amount: '',
        company_order_attributes: {company_id: 0, company_name: '', extension_attributes: {}, order_id: 0},
        converting_from_quote: false,
        customer_balance_amount: '',
        customer_balance_invoiced: '',
        customer_balance_refunded: '',
        customer_balance_total_refunded: '',
        gift_cards: [{amount: '', base_amount: '', code: '', id: 0}],
        gift_cards_amount: '',
        gift_cards_invoiced: '',
        gift_cards_refunded: '',
        gift_message: {
          customer_id: 0,
          extension_attributes: {
            entity_id: '',
            entity_type: '',
            wrapping_add_printed_card: false,
            wrapping_allow_gift_receipt: false,
            wrapping_id: 0
          },
          gift_message_id: 0,
          message: '',
          recipient: '',
          sender: ''
        },
        gw_add_card: '',
        gw_allow_gift_receipt: '',
        gw_base_price: '',
        gw_base_price_incl_tax: '',
        gw_base_price_invoiced: '',
        gw_base_price_refunded: '',
        gw_base_tax_amount: '',
        gw_base_tax_amount_invoiced: '',
        gw_base_tax_amount_refunded: '',
        gw_card_base_price: '',
        gw_card_base_price_incl_tax: '',
        gw_card_base_price_invoiced: '',
        gw_card_base_price_refunded: '',
        gw_card_base_tax_amount: '',
        gw_card_base_tax_invoiced: '',
        gw_card_base_tax_refunded: '',
        gw_card_price: '',
        gw_card_price_incl_tax: '',
        gw_card_price_invoiced: '',
        gw_card_price_refunded: '',
        gw_card_tax_amount: '',
        gw_card_tax_invoiced: '',
        gw_card_tax_refunded: '',
        gw_id: '',
        gw_items_base_price: '',
        gw_items_base_price_incl_tax: '',
        gw_items_base_price_invoiced: '',
        gw_items_base_price_refunded: '',
        gw_items_base_tax_amount: '',
        gw_items_base_tax_invoiced: '',
        gw_items_base_tax_refunded: '',
        gw_items_price: '',
        gw_items_price_incl_tax: '',
        gw_items_price_invoiced: '',
        gw_items_price_refunded: '',
        gw_items_tax_amount: '',
        gw_items_tax_invoiced: '',
        gw_items_tax_refunded: '',
        gw_price: '',
        gw_price_incl_tax: '',
        gw_price_invoiced: '',
        gw_price_refunded: '',
        gw_tax_amount: '',
        gw_tax_amount_invoiced: '',
        gw_tax_amount_refunded: '',
        item_applied_taxes: [
          {
            applied_taxes: [{}],
            associated_item_id: 0,
            extension_attributes: {},
            item_id: 0,
            type: ''
          }
        ],
        payment_additional_info: [{key: '', value: ''}],
        reward_currency_amount: '',
        reward_points_balance: 0,
        shipping_assignments: [
          {
            extension_attributes: {},
            items: [
              {
                additional_data: '',
                amount_refunded: '',
                applied_rule_ids: '',
                base_amount_refunded: '',
                base_cost: '',
                base_discount_amount: '',
                base_discount_invoiced: '',
                base_discount_refunded: '',
                base_discount_tax_compensation_amount: '',
                base_discount_tax_compensation_invoiced: '',
                base_discount_tax_compensation_refunded: '',
                base_original_price: '',
                base_price: '',
                base_price_incl_tax: '',
                base_row_invoiced: '',
                base_row_total: '',
                base_row_total_incl_tax: '',
                base_tax_amount: '',
                base_tax_before_discount: '',
                base_tax_invoiced: '',
                base_tax_refunded: '',
                base_weee_tax_applied_amount: '',
                base_weee_tax_applied_row_amnt: '',
                base_weee_tax_disposition: '',
                base_weee_tax_row_disposition: '',
                created_at: '',
                description: '',
                discount_amount: '',
                discount_invoiced: '',
                discount_percent: '',
                discount_refunded: '',
                discount_tax_compensation_amount: '',
                discount_tax_compensation_canceled: '',
                discount_tax_compensation_invoiced: '',
                discount_tax_compensation_refunded: '',
                event_id: 0,
                ext_order_item_id: '',
                extension_attributes: {
                  gift_message: {},
                  gw_base_price: '',
                  gw_base_price_invoiced: '',
                  gw_base_price_refunded: '',
                  gw_base_tax_amount: '',
                  gw_base_tax_amount_invoiced: '',
                  gw_base_tax_amount_refunded: '',
                  gw_id: '',
                  gw_price: '',
                  gw_price_invoiced: '',
                  gw_price_refunded: '',
                  gw_tax_amount: '',
                  gw_tax_amount_invoiced: '',
                  gw_tax_amount_refunded: '',
                  invoice_text_codes: [],
                  tax_codes: [],
                  vertex_tax_codes: []
                },
                free_shipping: 0,
                gw_base_price: '',
                gw_base_price_invoiced: '',
                gw_base_price_refunded: '',
                gw_base_tax_amount: '',
                gw_base_tax_amount_invoiced: '',
                gw_base_tax_amount_refunded: '',
                gw_id: 0,
                gw_price: '',
                gw_price_invoiced: '',
                gw_price_refunded: '',
                gw_tax_amount: '',
                gw_tax_amount_invoiced: '',
                gw_tax_amount_refunded: '',
                is_qty_decimal: 0,
                is_virtual: 0,
                item_id: 0,
                locked_do_invoice: 0,
                locked_do_ship: 0,
                name: '',
                no_discount: 0,
                order_id: 0,
                original_price: '',
                parent_item: '',
                parent_item_id: 0,
                price: '',
                price_incl_tax: '',
                product_id: 0,
                product_option: {
                  extension_attributes: {
                    bundle_options: [{extension_attributes: {}, option_id: 0, option_qty: 0, option_selections: []}],
                    configurable_item_options: [{extension_attributes: {}, option_id: '', option_value: 0}],
                    custom_options: [
                      {
                        extension_attributes: {file_info: {base64_encoded_data: '', name: '', type: ''}},
                        option_id: '',
                        option_value: ''
                      }
                    ],
                    downloadable_option: {downloadable_links: []},
                    giftcard_item_option: {
                      custom_giftcard_amount: '',
                      extension_attributes: {},
                      giftcard_amount: '',
                      giftcard_message: '',
                      giftcard_recipient_email: '',
                      giftcard_recipient_name: '',
                      giftcard_sender_email: '',
                      giftcard_sender_name: ''
                    }
                  }
                },
                product_type: '',
                qty_backordered: '',
                qty_canceled: '',
                qty_invoiced: '',
                qty_ordered: '',
                qty_refunded: '',
                qty_returned: '',
                qty_shipped: '',
                quote_item_id: 0,
                row_invoiced: '',
                row_total: '',
                row_total_incl_tax: '',
                row_weight: '',
                sku: '',
                store_id: 0,
                tax_amount: '',
                tax_before_discount: '',
                tax_canceled: '',
                tax_invoiced: '',
                tax_percent: '',
                tax_refunded: '',
                updated_at: '',
                weee_tax_applied: '',
                weee_tax_applied_amount: '',
                weee_tax_applied_row_amount: '',
                weee_tax_disposition: '',
                weee_tax_row_disposition: '',
                weight: ''
              }
            ],
            shipping: {
              address: {},
              extension_attributes: {
                collection_point: {
                  city: '',
                  collection_point_id: '',
                  country: '',
                  name: '',
                  postcode: '',
                  recipient_address_id: 0,
                  region: '',
                  street: []
                },
                ext_order_id: '',
                shipping_experience: {code: '', cost: '', label: ''}
              },
              method: '',
              total: {
                base_shipping_amount: '',
                base_shipping_canceled: '',
                base_shipping_discount_amount: '',
                base_shipping_discount_tax_compensation_amnt: '',
                base_shipping_incl_tax: '',
                base_shipping_invoiced: '',
                base_shipping_refunded: '',
                base_shipping_tax_amount: '',
                base_shipping_tax_refunded: '',
                extension_attributes: {},
                shipping_amount: '',
                shipping_canceled: '',
                shipping_discount_amount: '',
                shipping_discount_tax_compensation_amount: '',
                shipping_incl_tax: '',
                shipping_invoiced: '',
                shipping_refunded: '',
                shipping_tax_amount: '',
                shipping_tax_refunded: ''
              }
            },
            stock_id: 0
          }
        ]
      },
      forced_shipment_with_invoice: 0,
      global_currency_code: '',
      grand_total: '',
      hold_before_state: '',
      hold_before_status: '',
      increment_id: '',
      is_virtual: 0,
      items: [{}],
      order_currency_code: '',
      original_increment_id: '',
      payment: {
        account_status: '',
        additional_data: '',
        additional_information: [],
        address_status: '',
        amount_authorized: '',
        amount_canceled: '',
        amount_ordered: '',
        amount_paid: '',
        amount_refunded: '',
        anet_trans_method: '',
        base_amount_authorized: '',
        base_amount_canceled: '',
        base_amount_ordered: '',
        base_amount_paid: '',
        base_amount_paid_online: '',
        base_amount_refunded: '',
        base_amount_refunded_online: '',
        base_shipping_amount: '',
        base_shipping_captured: '',
        base_shipping_refunded: '',
        cc_approval: '',
        cc_avs_status: '',
        cc_cid_status: '',
        cc_debug_request_body: '',
        cc_debug_response_body: '',
        cc_debug_response_serialized: '',
        cc_exp_month: '',
        cc_exp_year: '',
        cc_last4: '',
        cc_number_enc: '',
        cc_owner: '',
        cc_secure_verify: '',
        cc_ss_issue: '',
        cc_ss_start_month: '',
        cc_ss_start_year: '',
        cc_status: '',
        cc_status_description: '',
        cc_trans_id: '',
        cc_type: '',
        echeck_account_name: '',
        echeck_account_type: '',
        echeck_bank_name: '',
        echeck_routing_number: '',
        echeck_type: '',
        entity_id: 0,
        extension_attributes: {
          vault_payment_token: {
            created_at: '',
            customer_id: 0,
            entity_id: 0,
            expires_at: '',
            gateway_token: '',
            is_active: false,
            is_visible: false,
            payment_method_code: '',
            public_hash: '',
            token_details: '',
            type: ''
          }
        },
        last_trans_id: '',
        method: '',
        parent_id: 0,
        po_number: '',
        protection_eligibility: '',
        quote_payment_id: 0,
        shipping_amount: '',
        shipping_captured: '',
        shipping_refunded: ''
      },
      payment_auth_expiration: 0,
      payment_authorization_amount: '',
      protect_code: '',
      quote_address_id: 0,
      quote_id: 0,
      relation_child_id: '',
      relation_child_real_id: '',
      relation_parent_id: '',
      relation_parent_real_id: '',
      remote_ip: '',
      shipping_amount: '',
      shipping_canceled: '',
      shipping_description: '',
      shipping_discount_amount: '',
      shipping_discount_tax_compensation_amount: '',
      shipping_incl_tax: '',
      shipping_invoiced: '',
      shipping_refunded: '',
      shipping_tax_amount: '',
      shipping_tax_refunded: '',
      state: '',
      status: '',
      status_histories: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          entity_name: '',
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0,
          status: ''
        }
      ],
      store_currency_code: '',
      store_id: 0,
      store_name: '',
      store_to_base_rate: '',
      store_to_order_rate: '',
      subtotal: '',
      subtotal_canceled: '',
      subtotal_incl_tax: '',
      subtotal_invoiced: '',
      subtotal_refunded: '',
      tax_amount: '',
      tax_canceled: '',
      tax_invoiced: '',
      tax_refunded: '',
      total_canceled: '',
      total_due: '',
      total_invoiced: '',
      total_item_count: 0,
      total_offline_refunded: '',
      total_online_refunded: '',
      total_paid: '',
      total_qty_ordered: '',
      total_refunded: '',
      updated_at: '',
      weight: '',
      x_forwarded_for: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/orders/create';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"adjustment_negative":"","adjustment_positive":"","applied_rule_ids":"","base_adjustment_negative":"","base_adjustment_positive":"","base_currency_code":"","base_discount_amount":"","base_discount_canceled":"","base_discount_invoiced":"","base_discount_refunded":"","base_discount_tax_compensation_amount":"","base_discount_tax_compensation_invoiced":"","base_discount_tax_compensation_refunded":"","base_grand_total":"","base_shipping_amount":"","base_shipping_canceled":"","base_shipping_discount_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_invoiced":"","base_shipping_refunded":"","base_shipping_tax_amount":"","base_shipping_tax_refunded":"","base_subtotal":"","base_subtotal_canceled":"","base_subtotal_incl_tax":"","base_subtotal_invoiced":"","base_subtotal_refunded":"","base_tax_amount":"","base_tax_canceled":"","base_tax_invoiced":"","base_tax_refunded":"","base_to_global_rate":"","base_to_order_rate":"","base_total_canceled":"","base_total_due":"","base_total_invoiced":"","base_total_invoiced_cost":"","base_total_offline_refunded":"","base_total_online_refunded":"","base_total_paid":"","base_total_qty_ordered":"","base_total_refunded":"","billing_address":{"address_type":"","city":"","company":"","country_id":"","customer_address_id":0,"customer_id":0,"email":"","entity_id":0,"extension_attributes":{"checkout_fields":[{"attribute_code":"","value":""}]},"fax":"","firstname":"","lastname":"","middlename":"","parent_id":0,"postcode":"","prefix":"","region":"","region_code":"","region_id":0,"street":[],"suffix":"","telephone":"","vat_id":"","vat_is_valid":0,"vat_request_date":"","vat_request_id":"","vat_request_success":0},"billing_address_id":0,"can_ship_partially":0,"can_ship_partially_item":0,"coupon_code":"","created_at":"","customer_dob":"","customer_email":"","customer_firstname":"","customer_gender":0,"customer_group_id":0,"customer_id":0,"customer_is_guest":0,"customer_lastname":"","customer_middlename":"","customer_note":"","customer_note_notify":0,"customer_prefix":"","customer_suffix":"","customer_taxvat":"","discount_amount":"","discount_canceled":"","discount_description":"","discount_invoiced":"","discount_refunded":"","discount_tax_compensation_amount":"","discount_tax_compensation_invoiced":"","discount_tax_compensation_refunded":"","edit_increment":0,"email_sent":0,"entity_id":0,"ext_customer_id":"","ext_order_id":"","extension_attributes":{"amazon_order_reference_id":"","applied_taxes":[{"amount":"","base_amount":"","code":"","extension_attributes":{"rates":[{"code":"","extension_attributes":{},"percent":"","title":""}]},"percent":"","title":""}],"base_customer_balance_amount":"","base_customer_balance_invoiced":"","base_customer_balance_refunded":"","base_customer_balance_total_refunded":"","base_gift_cards_amount":"","base_gift_cards_invoiced":"","base_gift_cards_refunded":"","base_reward_currency_amount":"","company_order_attributes":{"company_id":0,"company_name":"","extension_attributes":{},"order_id":0},"converting_from_quote":false,"customer_balance_amount":"","customer_balance_invoiced":"","customer_balance_refunded":"","customer_balance_total_refunded":"","gift_cards":[{"amount":"","base_amount":"","code":"","id":0}],"gift_cards_amount":"","gift_cards_invoiced":"","gift_cards_refunded":"","gift_message":{"customer_id":0,"extension_attributes":{"entity_id":"","entity_type":"","wrapping_add_printed_card":false,"wrapping_allow_gift_receipt":false,"wrapping_id":0},"gift_message_id":0,"message":"","recipient":"","sender":""},"gw_add_card":"","gw_allow_gift_receipt":"","gw_base_price":"","gw_base_price_incl_tax":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_card_base_price":"","gw_card_base_price_incl_tax":"","gw_card_base_price_invoiced":"","gw_card_base_price_refunded":"","gw_card_base_tax_amount":"","gw_card_base_tax_invoiced":"","gw_card_base_tax_refunded":"","gw_card_price":"","gw_card_price_incl_tax":"","gw_card_price_invoiced":"","gw_card_price_refunded":"","gw_card_tax_amount":"","gw_card_tax_invoiced":"","gw_card_tax_refunded":"","gw_id":"","gw_items_base_price":"","gw_items_base_price_incl_tax":"","gw_items_base_price_invoiced":"","gw_items_base_price_refunded":"","gw_items_base_tax_amount":"","gw_items_base_tax_invoiced":"","gw_items_base_tax_refunded":"","gw_items_price":"","gw_items_price_incl_tax":"","gw_items_price_invoiced":"","gw_items_price_refunded":"","gw_items_tax_amount":"","gw_items_tax_invoiced":"","gw_items_tax_refunded":"","gw_price":"","gw_price_incl_tax":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","item_applied_taxes":[{"applied_taxes":[{}],"associated_item_id":0,"extension_attributes":{},"item_id":0,"type":""}],"payment_additional_info":[{"key":"","value":""}],"reward_currency_amount":"","reward_points_balance":0,"shipping_assignments":[{"extension_attributes":{},"items":[{"additional_data":"","amount_refunded":"","applied_rule_ids":"","base_amount_refunded":"","base_cost":"","base_discount_amount":"","base_discount_invoiced":"","base_discount_refunded":"","base_discount_tax_compensation_amount":"","base_discount_tax_compensation_invoiced":"","base_discount_tax_compensation_refunded":"","base_original_price":"","base_price":"","base_price_incl_tax":"","base_row_invoiced":"","base_row_total":"","base_row_total_incl_tax":"","base_tax_amount":"","base_tax_before_discount":"","base_tax_invoiced":"","base_tax_refunded":"","base_weee_tax_applied_amount":"","base_weee_tax_applied_row_amnt":"","base_weee_tax_disposition":"","base_weee_tax_row_disposition":"","created_at":"","description":"","discount_amount":"","discount_invoiced":"","discount_percent":"","discount_refunded":"","discount_tax_compensation_amount":"","discount_tax_compensation_canceled":"","discount_tax_compensation_invoiced":"","discount_tax_compensation_refunded":"","event_id":0,"ext_order_item_id":"","extension_attributes":{"gift_message":{},"gw_base_price":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_id":"","gw_price":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","invoice_text_codes":[],"tax_codes":[],"vertex_tax_codes":[]},"free_shipping":0,"gw_base_price":"","gw_base_price_invoiced":"","gw_base_price_refunded":"","gw_base_tax_amount":"","gw_base_tax_amount_invoiced":"","gw_base_tax_amount_refunded":"","gw_id":0,"gw_price":"","gw_price_invoiced":"","gw_price_refunded":"","gw_tax_amount":"","gw_tax_amount_invoiced":"","gw_tax_amount_refunded":"","is_qty_decimal":0,"is_virtual":0,"item_id":0,"locked_do_invoice":0,"locked_do_ship":0,"name":"","no_discount":0,"order_id":0,"original_price":"","parent_item":"","parent_item_id":0,"price":"","price_incl_tax":"","product_id":0,"product_option":{"extension_attributes":{"bundle_options":[{"extension_attributes":{},"option_id":0,"option_qty":0,"option_selections":[]}],"configurable_item_options":[{"extension_attributes":{},"option_id":"","option_value":0}],"custom_options":[{"extension_attributes":{"file_info":{"base64_encoded_data":"","name":"","type":""}},"option_id":"","option_value":""}],"downloadable_option":{"downloadable_links":[]},"giftcard_item_option":{"custom_giftcard_amount":"","extension_attributes":{},"giftcard_amount":"","giftcard_message":"","giftcard_recipient_email":"","giftcard_recipient_name":"","giftcard_sender_email":"","giftcard_sender_name":""}}},"product_type":"","qty_backordered":"","qty_canceled":"","qty_invoiced":"","qty_ordered":"","qty_refunded":"","qty_returned":"","qty_shipped":"","quote_item_id":0,"row_invoiced":"","row_total":"","row_total_incl_tax":"","row_weight":"","sku":"","store_id":0,"tax_amount":"","tax_before_discount":"","tax_canceled":"","tax_invoiced":"","tax_percent":"","tax_refunded":"","updated_at":"","weee_tax_applied":"","weee_tax_applied_amount":"","weee_tax_applied_row_amount":"","weee_tax_disposition":"","weee_tax_row_disposition":"","weight":""}],"shipping":{"address":{},"extension_attributes":{"collection_point":{"city":"","collection_point_id":"","country":"","name":"","postcode":"","recipient_address_id":0,"region":"","street":[]},"ext_order_id":"","shipping_experience":{"code":"","cost":"","label":""}},"method":"","total":{"base_shipping_amount":"","base_shipping_canceled":"","base_shipping_discount_amount":"","base_shipping_discount_tax_compensation_amnt":"","base_shipping_incl_tax":"","base_shipping_invoiced":"","base_shipping_refunded":"","base_shipping_tax_amount":"","base_shipping_tax_refunded":"","extension_attributes":{},"shipping_amount":"","shipping_canceled":"","shipping_discount_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_invoiced":"","shipping_refunded":"","shipping_tax_amount":"","shipping_tax_refunded":""}},"stock_id":0}]},"forced_shipment_with_invoice":0,"global_currency_code":"","grand_total":"","hold_before_state":"","hold_before_status":"","increment_id":"","is_virtual":0,"items":[{}],"order_currency_code":"","original_increment_id":"","payment":{"account_status":"","additional_data":"","additional_information":[],"address_status":"","amount_authorized":"","amount_canceled":"","amount_ordered":"","amount_paid":"","amount_refunded":"","anet_trans_method":"","base_amount_authorized":"","base_amount_canceled":"","base_amount_ordered":"","base_amount_paid":"","base_amount_paid_online":"","base_amount_refunded":"","base_amount_refunded_online":"","base_shipping_amount":"","base_shipping_captured":"","base_shipping_refunded":"","cc_approval":"","cc_avs_status":"","cc_cid_status":"","cc_debug_request_body":"","cc_debug_response_body":"","cc_debug_response_serialized":"","cc_exp_month":"","cc_exp_year":"","cc_last4":"","cc_number_enc":"","cc_owner":"","cc_secure_verify":"","cc_ss_issue":"","cc_ss_start_month":"","cc_ss_start_year":"","cc_status":"","cc_status_description":"","cc_trans_id":"","cc_type":"","echeck_account_name":"","echeck_account_type":"","echeck_bank_name":"","echeck_routing_number":"","echeck_type":"","entity_id":0,"extension_attributes":{"vault_payment_token":{"created_at":"","customer_id":0,"entity_id":0,"expires_at":"","gateway_token":"","is_active":false,"is_visible":false,"payment_method_code":"","public_hash":"","token_details":"","type":""}},"last_trans_id":"","method":"","parent_id":0,"po_number":"","protection_eligibility":"","quote_payment_id":0,"shipping_amount":"","shipping_captured":"","shipping_refunded":""},"payment_auth_expiration":0,"payment_authorization_amount":"","protect_code":"","quote_address_id":0,"quote_id":0,"relation_child_id":"","relation_child_real_id":"","relation_parent_id":"","relation_parent_real_id":"","remote_ip":"","shipping_amount":"","shipping_canceled":"","shipping_description":"","shipping_discount_amount":"","shipping_discount_tax_compensation_amount":"","shipping_incl_tax":"","shipping_invoiced":"","shipping_refunded":"","shipping_tax_amount":"","shipping_tax_refunded":"","state":"","status":"","status_histories":[{"comment":"","created_at":"","entity_id":0,"entity_name":"","extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_id":0,"status":""}],"store_currency_code":"","store_id":0,"store_name":"","store_to_base_rate":"","store_to_order_rate":"","subtotal":"","subtotal_canceled":"","subtotal_incl_tax":"","subtotal_invoiced":"","subtotal_refunded":"","tax_amount":"","tax_canceled":"","tax_invoiced":"","tax_refunded":"","total_canceled":"","total_due":"","total_invoiced":"","total_item_count":0,"total_offline_refunded":"","total_online_refunded":"","total_paid":"","total_qty_ordered":"","total_refunded":"","updated_at":"","weight":"","x_forwarded_for":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"entity": @{ @"adjustment_negative": @"", @"adjustment_positive": @"", @"applied_rule_ids": @"", @"base_adjustment_negative": @"", @"base_adjustment_positive": @"", @"base_currency_code": @"", @"base_discount_amount": @"", @"base_discount_canceled": @"", @"base_discount_invoiced": @"", @"base_discount_refunded": @"", @"base_discount_tax_compensation_amount": @"", @"base_discount_tax_compensation_invoiced": @"", @"base_discount_tax_compensation_refunded": @"", @"base_grand_total": @"", @"base_shipping_amount": @"", @"base_shipping_canceled": @"", @"base_shipping_discount_amount": @"", @"base_shipping_discount_tax_compensation_amnt": @"", @"base_shipping_incl_tax": @"", @"base_shipping_invoiced": @"", @"base_shipping_refunded": @"", @"base_shipping_tax_amount": @"", @"base_shipping_tax_refunded": @"", @"base_subtotal": @"", @"base_subtotal_canceled": @"", @"base_subtotal_incl_tax": @"", @"base_subtotal_invoiced": @"", @"base_subtotal_refunded": @"", @"base_tax_amount": @"", @"base_tax_canceled": @"", @"base_tax_invoiced": @"", @"base_tax_refunded": @"", @"base_to_global_rate": @"", @"base_to_order_rate": @"", @"base_total_canceled": @"", @"base_total_due": @"", @"base_total_invoiced": @"", @"base_total_invoiced_cost": @"", @"base_total_offline_refunded": @"", @"base_total_online_refunded": @"", @"base_total_paid": @"", @"base_total_qty_ordered": @"", @"base_total_refunded": @"", @"billing_address": @{ @"address_type": @"", @"city": @"", @"company": @"", @"country_id": @"", @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"entity_id": @0, @"extension_attributes": @{ @"checkout_fields": @[ @{ @"attribute_code": @"", @"value": @"" } ] }, @"fax": @"", @"firstname": @"", @"lastname": @"", @"middlename": @"", @"parent_id": @0, @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"", @"vat_is_valid": @0, @"vat_request_date": @"", @"vat_request_id": @"", @"vat_request_success": @0 }, @"billing_address_id": @0, @"can_ship_partially": @0, @"can_ship_partially_item": @0, @"coupon_code": @"", @"created_at": @"", @"customer_dob": @"", @"customer_email": @"", @"customer_firstname": @"", @"customer_gender": @0, @"customer_group_id": @0, @"customer_id": @0, @"customer_is_guest": @0, @"customer_lastname": @"", @"customer_middlename": @"", @"customer_note": @"", @"customer_note_notify": @0, @"customer_prefix": @"", @"customer_suffix": @"", @"customer_taxvat": @"", @"discount_amount": @"", @"discount_canceled": @"", @"discount_description": @"", @"discount_invoiced": @"", @"discount_refunded": @"", @"discount_tax_compensation_amount": @"", @"discount_tax_compensation_invoiced": @"", @"discount_tax_compensation_refunded": @"", @"edit_increment": @0, @"email_sent": @0, @"entity_id": @0, @"ext_customer_id": @"", @"ext_order_id": @"", @"extension_attributes": @{ @"amazon_order_reference_id": @"", @"applied_taxes": @[ @{ @"amount": @"", @"base_amount": @"", @"code": @"", @"extension_attributes": @{ @"rates": @[ @{ @"code": @"", @"extension_attributes": @{  }, @"percent": @"", @"title": @"" } ] }, @"percent": @"", @"title": @"" } ], @"base_customer_balance_amount": @"", @"base_customer_balance_invoiced": @"", @"base_customer_balance_refunded": @"", @"base_customer_balance_total_refunded": @"", @"base_gift_cards_amount": @"", @"base_gift_cards_invoiced": @"", @"base_gift_cards_refunded": @"", @"base_reward_currency_amount": @"", @"company_order_attributes": @{ @"company_id": @0, @"company_name": @"", @"extension_attributes": @{  }, @"order_id": @0 }, @"converting_from_quote": @NO, @"customer_balance_amount": @"", @"customer_balance_invoiced": @"", @"customer_balance_refunded": @"", @"customer_balance_total_refunded": @"", @"gift_cards": @[ @{ @"amount": @"", @"base_amount": @"", @"code": @"", @"id": @0 } ], @"gift_cards_amount": @"", @"gift_cards_invoiced": @"", @"gift_cards_refunded": @"", @"gift_message": @{ @"customer_id": @0, @"extension_attributes": @{ @"entity_id": @"", @"entity_type": @"", @"wrapping_add_printed_card": @NO, @"wrapping_allow_gift_receipt": @NO, @"wrapping_id": @0 }, @"gift_message_id": @0, @"message": @"", @"recipient": @"", @"sender": @"" }, @"gw_add_card": @"", @"gw_allow_gift_receipt": @"", @"gw_base_price": @"", @"gw_base_price_incl_tax": @"", @"gw_base_price_invoiced": @"", @"gw_base_price_refunded": @"", @"gw_base_tax_amount": @"", @"gw_base_tax_amount_invoiced": @"", @"gw_base_tax_amount_refunded": @"", @"gw_card_base_price": @"", @"gw_card_base_price_incl_tax": @"", @"gw_card_base_price_invoiced": @"", @"gw_card_base_price_refunded": @"", @"gw_card_base_tax_amount": @"", @"gw_card_base_tax_invoiced": @"", @"gw_card_base_tax_refunded": @"", @"gw_card_price": @"", @"gw_card_price_incl_tax": @"", @"gw_card_price_invoiced": @"", @"gw_card_price_refunded": @"", @"gw_card_tax_amount": @"", @"gw_card_tax_invoiced": @"", @"gw_card_tax_refunded": @"", @"gw_id": @"", @"gw_items_base_price": @"", @"gw_items_base_price_incl_tax": @"", @"gw_items_base_price_invoiced": @"", @"gw_items_base_price_refunded": @"", @"gw_items_base_tax_amount": @"", @"gw_items_base_tax_invoiced": @"", @"gw_items_base_tax_refunded": @"", @"gw_items_price": @"", @"gw_items_price_incl_tax": @"", @"gw_items_price_invoiced": @"", @"gw_items_price_refunded": @"", @"gw_items_tax_amount": @"", @"gw_items_tax_invoiced": @"", @"gw_items_tax_refunded": @"", @"gw_price": @"", @"gw_price_incl_tax": @"", @"gw_price_invoiced": @"", @"gw_price_refunded": @"", @"gw_tax_amount": @"", @"gw_tax_amount_invoiced": @"", @"gw_tax_amount_refunded": @"", @"item_applied_taxes": @[ @{ @"applied_taxes": @[ @{  } ], @"associated_item_id": @0, @"extension_attributes": @{  }, @"item_id": @0, @"type": @"" } ], @"payment_additional_info": @[ @{ @"key": @"", @"value": @"" } ], @"reward_currency_amount": @"", @"reward_points_balance": @0, @"shipping_assignments": @[ @{ @"extension_attributes": @{  }, @"items": @[ @{ @"additional_data": @"", @"amount_refunded": @"", @"applied_rule_ids": @"", @"base_amount_refunded": @"", @"base_cost": @"", @"base_discount_amount": @"", @"base_discount_invoiced": @"", @"base_discount_refunded": @"", @"base_discount_tax_compensation_amount": @"", @"base_discount_tax_compensation_invoiced": @"", @"base_discount_tax_compensation_refunded": @"", @"base_original_price": @"", @"base_price": @"", @"base_price_incl_tax": @"", @"base_row_invoiced": @"", @"base_row_total": @"", @"base_row_total_incl_tax": @"", @"base_tax_amount": @"", @"base_tax_before_discount": @"", @"base_tax_invoiced": @"", @"base_tax_refunded": @"", @"base_weee_tax_applied_amount": @"", @"base_weee_tax_applied_row_amnt": @"", @"base_weee_tax_disposition": @"", @"base_weee_tax_row_disposition": @"", @"created_at": @"", @"description": @"", @"discount_amount": @"", @"discount_invoiced": @"", @"discount_percent": @"", @"discount_refunded": @"", @"discount_tax_compensation_amount": @"", @"discount_tax_compensation_canceled": @"", @"discount_tax_compensation_invoiced": @"", @"discount_tax_compensation_refunded": @"", @"event_id": @0, @"ext_order_item_id": @"", @"extension_attributes": @{ @"gift_message": @{  }, @"gw_base_price": @"", @"gw_base_price_invoiced": @"", @"gw_base_price_refunded": @"", @"gw_base_tax_amount": @"", @"gw_base_tax_amount_invoiced": @"", @"gw_base_tax_amount_refunded": @"", @"gw_id": @"", @"gw_price": @"", @"gw_price_invoiced": @"", @"gw_price_refunded": @"", @"gw_tax_amount": @"", @"gw_tax_amount_invoiced": @"", @"gw_tax_amount_refunded": @"", @"invoice_text_codes": @[  ], @"tax_codes": @[  ], @"vertex_tax_codes": @[  ] }, @"free_shipping": @0, @"gw_base_price": @"", @"gw_base_price_invoiced": @"", @"gw_base_price_refunded": @"", @"gw_base_tax_amount": @"", @"gw_base_tax_amount_invoiced": @"", @"gw_base_tax_amount_refunded": @"", @"gw_id": @0, @"gw_price": @"", @"gw_price_invoiced": @"", @"gw_price_refunded": @"", @"gw_tax_amount": @"", @"gw_tax_amount_invoiced": @"", @"gw_tax_amount_refunded": @"", @"is_qty_decimal": @0, @"is_virtual": @0, @"item_id": @0, @"locked_do_invoice": @0, @"locked_do_ship": @0, @"name": @"", @"no_discount": @0, @"order_id": @0, @"original_price": @"", @"parent_item": @"", @"parent_item_id": @0, @"price": @"", @"price_incl_tax": @"", @"product_id": @0, @"product_option": @{ @"extension_attributes": @{ @"bundle_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @0, @"option_qty": @0, @"option_selections": @[  ] } ], @"configurable_item_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @"", @"option_value": @0 } ], @"custom_options": @[ @{ @"extension_attributes": @{ @"file_info": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" } }, @"option_id": @"", @"option_value": @"" } ], @"downloadable_option": @{ @"downloadable_links": @[  ] }, @"giftcard_item_option": @{ @"custom_giftcard_amount": @"", @"extension_attributes": @{  }, @"giftcard_amount": @"", @"giftcard_message": @"", @"giftcard_recipient_email": @"", @"giftcard_recipient_name": @"", @"giftcard_sender_email": @"", @"giftcard_sender_name": @"" } } }, @"product_type": @"", @"qty_backordered": @"", @"qty_canceled": @"", @"qty_invoiced": @"", @"qty_ordered": @"", @"qty_refunded": @"", @"qty_returned": @"", @"qty_shipped": @"", @"quote_item_id": @0, @"row_invoiced": @"", @"row_total": @"", @"row_total_incl_tax": @"", @"row_weight": @"", @"sku": @"", @"store_id": @0, @"tax_amount": @"", @"tax_before_discount": @"", @"tax_canceled": @"", @"tax_invoiced": @"", @"tax_percent": @"", @"tax_refunded": @"", @"updated_at": @"", @"weee_tax_applied": @"", @"weee_tax_applied_amount": @"", @"weee_tax_applied_row_amount": @"", @"weee_tax_disposition": @"", @"weee_tax_row_disposition": @"", @"weight": @"" } ], @"shipping": @{ @"address": @{  }, @"extension_attributes": @{ @"collection_point": @{ @"city": @"", @"collection_point_id": @"", @"country": @"", @"name": @"", @"postcode": @"", @"recipient_address_id": @0, @"region": @"", @"street": @[  ] }, @"ext_order_id": @"", @"shipping_experience": @{ @"code": @"", @"cost": @"", @"label": @"" } }, @"method": @"", @"total": @{ @"base_shipping_amount": @"", @"base_shipping_canceled": @"", @"base_shipping_discount_amount": @"", @"base_shipping_discount_tax_compensation_amnt": @"", @"base_shipping_incl_tax": @"", @"base_shipping_invoiced": @"", @"base_shipping_refunded": @"", @"base_shipping_tax_amount": @"", @"base_shipping_tax_refunded": @"", @"extension_attributes": @{  }, @"shipping_amount": @"", @"shipping_canceled": @"", @"shipping_discount_amount": @"", @"shipping_discount_tax_compensation_amount": @"", @"shipping_incl_tax": @"", @"shipping_invoiced": @"", @"shipping_refunded": @"", @"shipping_tax_amount": @"", @"shipping_tax_refunded": @"" } }, @"stock_id": @0 } ] }, @"forced_shipment_with_invoice": @0, @"global_currency_code": @"", @"grand_total": @"", @"hold_before_state": @"", @"hold_before_status": @"", @"increment_id": @"", @"is_virtual": @0, @"items": @[ @{  } ], @"order_currency_code": @"", @"original_increment_id": @"", @"payment": @{ @"account_status": @"", @"additional_data": @"", @"additional_information": @[  ], @"address_status": @"", @"amount_authorized": @"", @"amount_canceled": @"", @"amount_ordered": @"", @"amount_paid": @"", @"amount_refunded": @"", @"anet_trans_method": @"", @"base_amount_authorized": @"", @"base_amount_canceled": @"", @"base_amount_ordered": @"", @"base_amount_paid": @"", @"base_amount_paid_online": @"", @"base_amount_refunded": @"", @"base_amount_refunded_online": @"", @"base_shipping_amount": @"", @"base_shipping_captured": @"", @"base_shipping_refunded": @"", @"cc_approval": @"", @"cc_avs_status": @"", @"cc_cid_status": @"", @"cc_debug_request_body": @"", @"cc_debug_response_body": @"", @"cc_debug_response_serialized": @"", @"cc_exp_month": @"", @"cc_exp_year": @"", @"cc_last4": @"", @"cc_number_enc": @"", @"cc_owner": @"", @"cc_secure_verify": @"", @"cc_ss_issue": @"", @"cc_ss_start_month": @"", @"cc_ss_start_year": @"", @"cc_status": @"", @"cc_status_description": @"", @"cc_trans_id": @"", @"cc_type": @"", @"echeck_account_name": @"", @"echeck_account_type": @"", @"echeck_bank_name": @"", @"echeck_routing_number": @"", @"echeck_type": @"", @"entity_id": @0, @"extension_attributes": @{ @"vault_payment_token": @{ @"created_at": @"", @"customer_id": @0, @"entity_id": @0, @"expires_at": @"", @"gateway_token": @"", @"is_active": @NO, @"is_visible": @NO, @"payment_method_code": @"", @"public_hash": @"", @"token_details": @"", @"type": @"" } }, @"last_trans_id": @"", @"method": @"", @"parent_id": @0, @"po_number": @"", @"protection_eligibility": @"", @"quote_payment_id": @0, @"shipping_amount": @"", @"shipping_captured": @"", @"shipping_refunded": @"" }, @"payment_auth_expiration": @0, @"payment_authorization_amount": @"", @"protect_code": @"", @"quote_address_id": @0, @"quote_id": @0, @"relation_child_id": @"", @"relation_child_real_id": @"", @"relation_parent_id": @"", @"relation_parent_real_id": @"", @"remote_ip": @"", @"shipping_amount": @"", @"shipping_canceled": @"", @"shipping_description": @"", @"shipping_discount_amount": @"", @"shipping_discount_tax_compensation_amount": @"", @"shipping_incl_tax": @"", @"shipping_invoiced": @"", @"shipping_refunded": @"", @"shipping_tax_amount": @"", @"shipping_tax_refunded": @"", @"state": @"", @"status": @"", @"status_histories": @[ @{ @"comment": @"", @"created_at": @"", @"entity_id": @0, @"entity_name": @"", @"extension_attributes": @{  }, @"is_customer_notified": @0, @"is_visible_on_front": @0, @"parent_id": @0, @"status": @"" } ], @"store_currency_code": @"", @"store_id": @0, @"store_name": @"", @"store_to_base_rate": @"", @"store_to_order_rate": @"", @"subtotal": @"", @"subtotal_canceled": @"", @"subtotal_incl_tax": @"", @"subtotal_invoiced": @"", @"subtotal_refunded": @"", @"tax_amount": @"", @"tax_canceled": @"", @"tax_invoiced": @"", @"tax_refunded": @"", @"total_canceled": @"", @"total_due": @"", @"total_invoiced": @"", @"total_item_count": @0, @"total_offline_refunded": @"", @"total_online_refunded": @"", @"total_paid": @"", @"total_qty_ordered": @"", @"total_refunded": @"", @"updated_at": @"", @"weight": @"", @"x_forwarded_for": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/orders/create"]
                                                       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}}/V1/orders/create" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/orders/create",
  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([
    'entity' => [
        'adjustment_negative' => '',
        'adjustment_positive' => '',
        'applied_rule_ids' => '',
        'base_adjustment_negative' => '',
        'base_adjustment_positive' => '',
        'base_currency_code' => '',
        'base_discount_amount' => '',
        'base_discount_canceled' => '',
        'base_discount_invoiced' => '',
        'base_discount_refunded' => '',
        'base_discount_tax_compensation_amount' => '',
        'base_discount_tax_compensation_invoiced' => '',
        'base_discount_tax_compensation_refunded' => '',
        'base_grand_total' => '',
        'base_shipping_amount' => '',
        'base_shipping_canceled' => '',
        'base_shipping_discount_amount' => '',
        'base_shipping_discount_tax_compensation_amnt' => '',
        'base_shipping_incl_tax' => '',
        'base_shipping_invoiced' => '',
        'base_shipping_refunded' => '',
        'base_shipping_tax_amount' => '',
        'base_shipping_tax_refunded' => '',
        'base_subtotal' => '',
        'base_subtotal_canceled' => '',
        'base_subtotal_incl_tax' => '',
        'base_subtotal_invoiced' => '',
        'base_subtotal_refunded' => '',
        'base_tax_amount' => '',
        'base_tax_canceled' => '',
        'base_tax_invoiced' => '',
        'base_tax_refunded' => '',
        'base_to_global_rate' => '',
        'base_to_order_rate' => '',
        'base_total_canceled' => '',
        'base_total_due' => '',
        'base_total_invoiced' => '',
        'base_total_invoiced_cost' => '',
        'base_total_offline_refunded' => '',
        'base_total_online_refunded' => '',
        'base_total_paid' => '',
        'base_total_qty_ordered' => '',
        'base_total_refunded' => '',
        'billing_address' => [
                'address_type' => '',
                'city' => '',
                'company' => '',
                'country_id' => '',
                'customer_address_id' => 0,
                'customer_id' => 0,
                'email' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                'checkout_fields' => [
                                                                [
                                                                                                                                'attribute_code' => '',
                                                                                                                                'value' => ''
                                                                ]
                                ]
                ],
                'fax' => '',
                'firstname' => '',
                'lastname' => '',
                'middlename' => '',
                'parent_id' => 0,
                'postcode' => '',
                'prefix' => '',
                'region' => '',
                'region_code' => '',
                'region_id' => 0,
                'street' => [
                                
                ],
                'suffix' => '',
                'telephone' => '',
                'vat_id' => '',
                'vat_is_valid' => 0,
                'vat_request_date' => '',
                'vat_request_id' => '',
                'vat_request_success' => 0
        ],
        'billing_address_id' => 0,
        'can_ship_partially' => 0,
        'can_ship_partially_item' => 0,
        'coupon_code' => '',
        'created_at' => '',
        'customer_dob' => '',
        'customer_email' => '',
        'customer_firstname' => '',
        'customer_gender' => 0,
        'customer_group_id' => 0,
        'customer_id' => 0,
        'customer_is_guest' => 0,
        'customer_lastname' => '',
        'customer_middlename' => '',
        'customer_note' => '',
        'customer_note_notify' => 0,
        'customer_prefix' => '',
        'customer_suffix' => '',
        'customer_taxvat' => '',
        'discount_amount' => '',
        'discount_canceled' => '',
        'discount_description' => '',
        'discount_invoiced' => '',
        'discount_refunded' => '',
        'discount_tax_compensation_amount' => '',
        'discount_tax_compensation_invoiced' => '',
        'discount_tax_compensation_refunded' => '',
        'edit_increment' => 0,
        'email_sent' => 0,
        'entity_id' => 0,
        'ext_customer_id' => '',
        'ext_order_id' => '',
        'extension_attributes' => [
                'amazon_order_reference_id' => '',
                'applied_taxes' => [
                                [
                                                                'amount' => '',
                                                                'base_amount' => '',
                                                                'code' => '',
                                                                'extension_attributes' => [
                                                                                                                                'rates' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'percent' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'title' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ],
                                                                'percent' => '',
                                                                'title' => ''
                                ]
                ],
                'base_customer_balance_amount' => '',
                'base_customer_balance_invoiced' => '',
                'base_customer_balance_refunded' => '',
                'base_customer_balance_total_refunded' => '',
                'base_gift_cards_amount' => '',
                'base_gift_cards_invoiced' => '',
                'base_gift_cards_refunded' => '',
                'base_reward_currency_amount' => '',
                'company_order_attributes' => [
                                'company_id' => 0,
                                'company_name' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'order_id' => 0
                ],
                'converting_from_quote' => null,
                'customer_balance_amount' => '',
                'customer_balance_invoiced' => '',
                'customer_balance_refunded' => '',
                'customer_balance_total_refunded' => '',
                'gift_cards' => [
                                [
                                                                'amount' => '',
                                                                'base_amount' => '',
                                                                'code' => '',
                                                                'id' => 0
                                ]
                ],
                'gift_cards_amount' => '',
                'gift_cards_invoiced' => '',
                'gift_cards_refunded' => '',
                'gift_message' => [
                                'customer_id' => 0,
                                'extension_attributes' => [
                                                                'entity_id' => '',
                                                                'entity_type' => '',
                                                                'wrapping_add_printed_card' => null,
                                                                'wrapping_allow_gift_receipt' => null,
                                                                'wrapping_id' => 0
                                ],
                                'gift_message_id' => 0,
                                'message' => '',
                                'recipient' => '',
                                'sender' => ''
                ],
                'gw_add_card' => '',
                'gw_allow_gift_receipt' => '',
                'gw_base_price' => '',
                'gw_base_price_incl_tax' => '',
                'gw_base_price_invoiced' => '',
                'gw_base_price_refunded' => '',
                'gw_base_tax_amount' => '',
                'gw_base_tax_amount_invoiced' => '',
                'gw_base_tax_amount_refunded' => '',
                'gw_card_base_price' => '',
                'gw_card_base_price_incl_tax' => '',
                'gw_card_base_price_invoiced' => '',
                'gw_card_base_price_refunded' => '',
                'gw_card_base_tax_amount' => '',
                'gw_card_base_tax_invoiced' => '',
                'gw_card_base_tax_refunded' => '',
                'gw_card_price' => '',
                'gw_card_price_incl_tax' => '',
                'gw_card_price_invoiced' => '',
                'gw_card_price_refunded' => '',
                'gw_card_tax_amount' => '',
                'gw_card_tax_invoiced' => '',
                'gw_card_tax_refunded' => '',
                'gw_id' => '',
                'gw_items_base_price' => '',
                'gw_items_base_price_incl_tax' => '',
                'gw_items_base_price_invoiced' => '',
                'gw_items_base_price_refunded' => '',
                'gw_items_base_tax_amount' => '',
                'gw_items_base_tax_invoiced' => '',
                'gw_items_base_tax_refunded' => '',
                'gw_items_price' => '',
                'gw_items_price_incl_tax' => '',
                'gw_items_price_invoiced' => '',
                'gw_items_price_refunded' => '',
                'gw_items_tax_amount' => '',
                'gw_items_tax_invoiced' => '',
                'gw_items_tax_refunded' => '',
                'gw_price' => '',
                'gw_price_incl_tax' => '',
                'gw_price_invoiced' => '',
                'gw_price_refunded' => '',
                'gw_tax_amount' => '',
                'gw_tax_amount_invoiced' => '',
                'gw_tax_amount_refunded' => '',
                'item_applied_taxes' => [
                                [
                                                                'applied_taxes' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'associated_item_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'item_id' => 0,
                                                                'type' => ''
                                ]
                ],
                'payment_additional_info' => [
                                [
                                                                'key' => '',
                                                                'value' => ''
                                ]
                ],
                'reward_currency_amount' => '',
                'reward_points_balance' => 0,
                'shipping_assignments' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'items' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'additional_data' => '',
                                                                                                                                                                                                                                                                'amount_refunded' => '',
                                                                                                                                                                                                                                                                'applied_rule_ids' => '',
                                                                                                                                                                                                                                                                'base_amount_refunded' => '',
                                                                                                                                                                                                                                                                'base_cost' => '',
                                                                                                                                                                                                                                                                'base_discount_amount' => '',
                                                                                                                                                                                                                                                                'base_discount_invoiced' => '',
                                                                                                                                                                                                                                                                'base_discount_refunded' => '',
                                                                                                                                                                                                                                                                'base_discount_tax_compensation_amount' => '',
                                                                                                                                                                                                                                                                'base_discount_tax_compensation_invoiced' => '',
                                                                                                                                                                                                                                                                'base_discount_tax_compensation_refunded' => '',
                                                                                                                                                                                                                                                                'base_original_price' => '',
                                                                                                                                                                                                                                                                'base_price' => '',
                                                                                                                                                                                                                                                                'base_price_incl_tax' => '',
                                                                                                                                                                                                                                                                'base_row_invoiced' => '',
                                                                                                                                                                                                                                                                'base_row_total' => '',
                                                                                                                                                                                                                                                                'base_row_total_incl_tax' => '',
                                                                                                                                                                                                                                                                'base_tax_amount' => '',
                                                                                                                                                                                                                                                                'base_tax_before_discount' => '',
                                                                                                                                                                                                                                                                'base_tax_invoiced' => '',
                                                                                                                                                                                                                                                                'base_tax_refunded' => '',
                                                                                                                                                                                                                                                                'base_weee_tax_applied_amount' => '',
                                                                                                                                                                                                                                                                'base_weee_tax_applied_row_amnt' => '',
                                                                                                                                                                                                                                                                'base_weee_tax_disposition' => '',
                                                                                                                                                                                                                                                                'base_weee_tax_row_disposition' => '',
                                                                                                                                                                                                                                                                'created_at' => '',
                                                                                                                                                                                                                                                                'description' => '',
                                                                                                                                                                                                                                                                'discount_amount' => '',
                                                                                                                                                                                                                                                                'discount_invoiced' => '',
                                                                                                                                                                                                                                                                'discount_percent' => '',
                                                                                                                                                                                                                                                                'discount_refunded' => '',
                                                                                                                                                                                                                                                                'discount_tax_compensation_amount' => '',
                                                                                                                                                                                                                                                                'discount_tax_compensation_canceled' => '',
                                                                                                                                                                                                                                                                'discount_tax_compensation_invoiced' => '',
                                                                                                                                                                                                                                                                'discount_tax_compensation_refunded' => '',
                                                                                                                                                                                                                                                                'event_id' => 0,
                                                                                                                                                                                                                                                                'ext_order_item_id' => '',
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gift_message' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'invoice_text_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'vertex_tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'free_shipping' => 0,
                                                                                                                                                                                                                                                                'gw_base_price' => '',
                                                                                                                                                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                'gw_id' => 0,
                                                                                                                                                                                                                                                                'gw_price' => '',
                                                                                                                                                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                'is_qty_decimal' => 0,
                                                                                                                                                                                                                                                                'is_virtual' => 0,
                                                                                                                                                                                                                                                                'item_id' => 0,
                                                                                                                                                                                                                                                                'locked_do_invoice' => 0,
                                                                                                                                                                                                                                                                'locked_do_ship' => 0,
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'no_discount' => 0,
                                                                                                                                                                                                                                                                'order_id' => 0,
                                                                                                                                                                                                                                                                'original_price' => '',
                                                                                                                                                                                                                                                                'parent_item' => '',
                                                                                                                                                                                                                                                                'parent_item_id' => 0,
                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                'price_incl_tax' => '',
                                                                                                                                                                                                                                                                'product_id' => 0,
                                                                                                                                                                                                                                                                'product_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'bundle_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_qty' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'configurable_item_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_links' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_item_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_message' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_name' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'product_type' => '',
                                                                                                                                                                                                                                                                'qty_backordered' => '',
                                                                                                                                                                                                                                                                'qty_canceled' => '',
                                                                                                                                                                                                                                                                'qty_invoiced' => '',
                                                                                                                                                                                                                                                                'qty_ordered' => '',
                                                                                                                                                                                                                                                                'qty_refunded' => '',
                                                                                                                                                                                                                                                                'qty_returned' => '',
                                                                                                                                                                                                                                                                'qty_shipped' => '',
                                                                                                                                                                                                                                                                'quote_item_id' => 0,
                                                                                                                                                                                                                                                                'row_invoiced' => '',
                                                                                                                                                                                                                                                                'row_total' => '',
                                                                                                                                                                                                                                                                'row_total_incl_tax' => '',
                                                                                                                                                                                                                                                                'row_weight' => '',
                                                                                                                                                                                                                                                                'sku' => '',
                                                                                                                                                                                                                                                                'store_id' => 0,
                                                                                                                                                                                                                                                                'tax_amount' => '',
                                                                                                                                                                                                                                                                'tax_before_discount' => '',
                                                                                                                                                                                                                                                                'tax_canceled' => '',
                                                                                                                                                                                                                                                                'tax_invoiced' => '',
                                                                                                                                                                                                                                                                'tax_percent' => '',
                                                                                                                                                                                                                                                                'tax_refunded' => '',
                                                                                                                                                                                                                                                                'updated_at' => '',
                                                                                                                                                                                                                                                                'weee_tax_applied' => '',
                                                                                                                                                                                                                                                                'weee_tax_applied_amount' => '',
                                                                                                                                                                                                                                                                'weee_tax_applied_row_amount' => '',
                                                                                                                                                                                                                                                                'weee_tax_disposition' => '',
                                                                                                                                                                                                                                                                'weee_tax_row_disposition' => '',
                                                                                                                                                                                                                                                                'weight' => ''
                                                                                                                                ]
                                                                ],
                                                                'shipping' => [
                                                                                                                                'address' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'collection_point' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'city' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'collection_point_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'country' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'postcode' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'recipient_address_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'region' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'street' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'ext_order_id' => '',
                                                                                                                                                                                                                                                                'shipping_experience' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'cost' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'label' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'method' => '',
                                                                                                                                'total' => [
                                                                                                                                                                                                                                                                'base_shipping_amount' => '',
                                                                                                                                                                                                                                                                'base_shipping_canceled' => '',
                                                                                                                                                                                                                                                                'base_shipping_discount_amount' => '',
                                                                                                                                                                                                                                                                'base_shipping_discount_tax_compensation_amnt' => '',
                                                                                                                                                                                                                                                                'base_shipping_incl_tax' => '',
                                                                                                                                                                                                                                                                'base_shipping_invoiced' => '',
                                                                                                                                                                                                                                                                'base_shipping_refunded' => '',
                                                                                                                                                                                                                                                                'base_shipping_tax_amount' => '',
                                                                                                                                                                                                                                                                'base_shipping_tax_refunded' => '',
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'shipping_amount' => '',
                                                                                                                                                                                                                                                                'shipping_canceled' => '',
                                                                                                                                                                                                                                                                'shipping_discount_amount' => '',
                                                                                                                                                                                                                                                                'shipping_discount_tax_compensation_amount' => '',
                                                                                                                                                                                                                                                                'shipping_incl_tax' => '',
                                                                                                                                                                                                                                                                'shipping_invoiced' => '',
                                                                                                                                                                                                                                                                'shipping_refunded' => '',
                                                                                                                                                                                                                                                                'shipping_tax_amount' => '',
                                                                                                                                                                                                                                                                'shipping_tax_refunded' => ''
                                                                                                                                ]
                                                                ],
                                                                'stock_id' => 0
                                ]
                ]
        ],
        'forced_shipment_with_invoice' => 0,
        'global_currency_code' => '',
        'grand_total' => '',
        'hold_before_state' => '',
        'hold_before_status' => '',
        'increment_id' => '',
        'is_virtual' => 0,
        'items' => [
                [
                                
                ]
        ],
        'order_currency_code' => '',
        'original_increment_id' => '',
        'payment' => [
                'account_status' => '',
                'additional_data' => '',
                'additional_information' => [
                                
                ],
                'address_status' => '',
                'amount_authorized' => '',
                'amount_canceled' => '',
                'amount_ordered' => '',
                'amount_paid' => '',
                'amount_refunded' => '',
                'anet_trans_method' => '',
                'base_amount_authorized' => '',
                'base_amount_canceled' => '',
                'base_amount_ordered' => '',
                'base_amount_paid' => '',
                'base_amount_paid_online' => '',
                'base_amount_refunded' => '',
                'base_amount_refunded_online' => '',
                'base_shipping_amount' => '',
                'base_shipping_captured' => '',
                'base_shipping_refunded' => '',
                'cc_approval' => '',
                'cc_avs_status' => '',
                'cc_cid_status' => '',
                'cc_debug_request_body' => '',
                'cc_debug_response_body' => '',
                'cc_debug_response_serialized' => '',
                'cc_exp_month' => '',
                'cc_exp_year' => '',
                'cc_last4' => '',
                'cc_number_enc' => '',
                'cc_owner' => '',
                'cc_secure_verify' => '',
                'cc_ss_issue' => '',
                'cc_ss_start_month' => '',
                'cc_ss_start_year' => '',
                'cc_status' => '',
                'cc_status_description' => '',
                'cc_trans_id' => '',
                'cc_type' => '',
                'echeck_account_name' => '',
                'echeck_account_type' => '',
                'echeck_bank_name' => '',
                'echeck_routing_number' => '',
                'echeck_type' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                'vault_payment_token' => [
                                                                'created_at' => '',
                                                                'customer_id' => 0,
                                                                'entity_id' => 0,
                                                                'expires_at' => '',
                                                                'gateway_token' => '',
                                                                'is_active' => null,
                                                                'is_visible' => null,
                                                                'payment_method_code' => '',
                                                                'public_hash' => '',
                                                                'token_details' => '',
                                                                'type' => ''
                                ]
                ],
                'last_trans_id' => '',
                'method' => '',
                'parent_id' => 0,
                'po_number' => '',
                'protection_eligibility' => '',
                'quote_payment_id' => 0,
                'shipping_amount' => '',
                'shipping_captured' => '',
                'shipping_refunded' => ''
        ],
        'payment_auth_expiration' => 0,
        'payment_authorization_amount' => '',
        'protect_code' => '',
        'quote_address_id' => 0,
        'quote_id' => 0,
        'relation_child_id' => '',
        'relation_child_real_id' => '',
        'relation_parent_id' => '',
        'relation_parent_real_id' => '',
        'remote_ip' => '',
        'shipping_amount' => '',
        'shipping_canceled' => '',
        'shipping_description' => '',
        'shipping_discount_amount' => '',
        'shipping_discount_tax_compensation_amount' => '',
        'shipping_incl_tax' => '',
        'shipping_invoiced' => '',
        'shipping_refunded' => '',
        'shipping_tax_amount' => '',
        'shipping_tax_refunded' => '',
        'state' => '',
        'status' => '',
        'status_histories' => [
                [
                                'comment' => '',
                                'created_at' => '',
                                'entity_id' => 0,
                                'entity_name' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'is_customer_notified' => 0,
                                'is_visible_on_front' => 0,
                                'parent_id' => 0,
                                'status' => ''
                ]
        ],
        'store_currency_code' => '',
        'store_id' => 0,
        'store_name' => '',
        'store_to_base_rate' => '',
        'store_to_order_rate' => '',
        'subtotal' => '',
        'subtotal_canceled' => '',
        'subtotal_incl_tax' => '',
        'subtotal_invoiced' => '',
        'subtotal_refunded' => '',
        'tax_amount' => '',
        'tax_canceled' => '',
        'tax_invoiced' => '',
        'tax_refunded' => '',
        'total_canceled' => '',
        'total_due' => '',
        'total_invoiced' => '',
        'total_item_count' => 0,
        'total_offline_refunded' => '',
        'total_online_refunded' => '',
        'total_paid' => '',
        'total_qty_ordered' => '',
        'total_refunded' => '',
        'updated_at' => '',
        'weight' => '',
        'x_forwarded_for' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/orders/create', [
  'body' => '{
  "entity": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "applied_rule_ids": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_canceled": "",
    "base_discount_invoiced": "",
    "base_discount_refunded": "",
    "base_discount_tax_compensation_amount": "",
    "base_discount_tax_compensation_invoiced": "",
    "base_discount_tax_compensation_refunded": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_canceled": "",
    "base_shipping_discount_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_invoiced": "",
    "base_shipping_refunded": "",
    "base_shipping_tax_amount": "",
    "base_shipping_tax_refunded": "",
    "base_subtotal": "",
    "base_subtotal_canceled": "",
    "base_subtotal_incl_tax": "",
    "base_subtotal_invoiced": "",
    "base_subtotal_refunded": "",
    "base_tax_amount": "",
    "base_tax_canceled": "",
    "base_tax_invoiced": "",
    "base_tax_refunded": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_canceled": "",
    "base_total_due": "",
    "base_total_invoiced": "",
    "base_total_invoiced_cost": "",
    "base_total_offline_refunded": "",
    "base_total_online_refunded": "",
    "base_total_paid": "",
    "base_total_qty_ordered": "",
    "base_total_refunded": "",
    "billing_address": {
      "address_type": "",
      "city": "",
      "company": "",
      "country_id": "",
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "entity_id": 0,
      "extension_attributes": {
        "checkout_fields": [
          {
            "attribute_code": "",
            "value": ""
          }
        ]
      },
      "fax": "",
      "firstname": "",
      "lastname": "",
      "middlename": "",
      "parent_id": 0,
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": "",
      "vat_is_valid": 0,
      "vat_request_date": "",
      "vat_request_id": "",
      "vat_request_success": 0
    },
    "billing_address_id": 0,
    "can_ship_partially": 0,
    "can_ship_partially_item": 0,
    "coupon_code": "",
    "created_at": "",
    "customer_dob": "",
    "customer_email": "",
    "customer_firstname": "",
    "customer_gender": 0,
    "customer_group_id": 0,
    "customer_id": 0,
    "customer_is_guest": 0,
    "customer_lastname": "",
    "customer_middlename": "",
    "customer_note": "",
    "customer_note_notify": 0,
    "customer_prefix": "",
    "customer_suffix": "",
    "customer_taxvat": "",
    "discount_amount": "",
    "discount_canceled": "",
    "discount_description": "",
    "discount_invoiced": "",
    "discount_refunded": "",
    "discount_tax_compensation_amount": "",
    "discount_tax_compensation_invoiced": "",
    "discount_tax_compensation_refunded": "",
    "edit_increment": 0,
    "email_sent": 0,
    "entity_id": 0,
    "ext_customer_id": "",
    "ext_order_id": "",
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "applied_taxes": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "extension_attributes": {
            "rates": [
              {
                "code": "",
                "extension_attributes": {},
                "percent": "",
                "title": ""
              }
            ]
          },
          "percent": "",
          "title": ""
        }
      ],
      "base_customer_balance_amount": "",
      "base_customer_balance_invoiced": "",
      "base_customer_balance_refunded": "",
      "base_customer_balance_total_refunded": "",
      "base_gift_cards_amount": "",
      "base_gift_cards_invoiced": "",
      "base_gift_cards_refunded": "",
      "base_reward_currency_amount": "",
      "company_order_attributes": {
        "company_id": 0,
        "company_name": "",
        "extension_attributes": {},
        "order_id": 0
      },
      "converting_from_quote": false,
      "customer_balance_amount": "",
      "customer_balance_invoiced": "",
      "customer_balance_refunded": "",
      "customer_balance_total_refunded": "",
      "gift_cards": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "id": 0
        }
      ],
      "gift_cards_amount": "",
      "gift_cards_invoiced": "",
      "gift_cards_refunded": "",
      "gift_message": {
        "customer_id": 0,
        "extension_attributes": {
          "entity_id": "",
          "entity_type": "",
          "wrapping_add_printed_card": false,
          "wrapping_allow_gift_receipt": false,
          "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
      },
      "gw_add_card": "",
      "gw_allow_gift_receipt": "",
      "gw_base_price": "",
      "gw_base_price_incl_tax": "",
      "gw_base_price_invoiced": "",
      "gw_base_price_refunded": "",
      "gw_base_tax_amount": "",
      "gw_base_tax_amount_invoiced": "",
      "gw_base_tax_amount_refunded": "",
      "gw_card_base_price": "",
      "gw_card_base_price_incl_tax": "",
      "gw_card_base_price_invoiced": "",
      "gw_card_base_price_refunded": "",
      "gw_card_base_tax_amount": "",
      "gw_card_base_tax_invoiced": "",
      "gw_card_base_tax_refunded": "",
      "gw_card_price": "",
      "gw_card_price_incl_tax": "",
      "gw_card_price_invoiced": "",
      "gw_card_price_refunded": "",
      "gw_card_tax_amount": "",
      "gw_card_tax_invoiced": "",
      "gw_card_tax_refunded": "",
      "gw_id": "",
      "gw_items_base_price": "",
      "gw_items_base_price_incl_tax": "",
      "gw_items_base_price_invoiced": "",
      "gw_items_base_price_refunded": "",
      "gw_items_base_tax_amount": "",
      "gw_items_base_tax_invoiced": "",
      "gw_items_base_tax_refunded": "",
      "gw_items_price": "",
      "gw_items_price_incl_tax": "",
      "gw_items_price_invoiced": "",
      "gw_items_price_refunded": "",
      "gw_items_tax_amount": "",
      "gw_items_tax_invoiced": "",
      "gw_items_tax_refunded": "",
      "gw_price": "",
      "gw_price_incl_tax": "",
      "gw_price_invoiced": "",
      "gw_price_refunded": "",
      "gw_tax_amount": "",
      "gw_tax_amount_invoiced": "",
      "gw_tax_amount_refunded": "",
      "item_applied_taxes": [
        {
          "applied_taxes": [
            {}
          ],
          "associated_item_id": 0,
          "extension_attributes": {},
          "item_id": 0,
          "type": ""
        }
      ],
      "payment_additional_info": [
        {
          "key": "",
          "value": ""
        }
      ],
      "reward_currency_amount": "",
      "reward_points_balance": 0,
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "additional_data": "",
              "amount_refunded": "",
              "applied_rule_ids": "",
              "base_amount_refunded": "",
              "base_cost": "",
              "base_discount_amount": "",
              "base_discount_invoiced": "",
              "base_discount_refunded": "",
              "base_discount_tax_compensation_amount": "",
              "base_discount_tax_compensation_invoiced": "",
              "base_discount_tax_compensation_refunded": "",
              "base_original_price": "",
              "base_price": "",
              "base_price_incl_tax": "",
              "base_row_invoiced": "",
              "base_row_total": "",
              "base_row_total_incl_tax": "",
              "base_tax_amount": "",
              "base_tax_before_discount": "",
              "base_tax_invoiced": "",
              "base_tax_refunded": "",
              "base_weee_tax_applied_amount": "",
              "base_weee_tax_applied_row_amnt": "",
              "base_weee_tax_disposition": "",
              "base_weee_tax_row_disposition": "",
              "created_at": "",
              "description": "",
              "discount_amount": "",
              "discount_invoiced": "",
              "discount_percent": "",
              "discount_refunded": "",
              "discount_tax_compensation_amount": "",
              "discount_tax_compensation_canceled": "",
              "discount_tax_compensation_invoiced": "",
              "discount_tax_compensation_refunded": "",
              "event_id": 0,
              "ext_order_item_id": "",
              "extension_attributes": {
                "gift_message": {},
                "gw_base_price": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_id": "",
                "gw_price": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "invoice_text_codes": [],
                "tax_codes": [],
                "vertex_tax_codes": []
              },
              "free_shipping": 0,
              "gw_base_price": "",
              "gw_base_price_invoiced": "",
              "gw_base_price_refunded": "",
              "gw_base_tax_amount": "",
              "gw_base_tax_amount_invoiced": "",
              "gw_base_tax_amount_refunded": "",
              "gw_id": 0,
              "gw_price": "",
              "gw_price_invoiced": "",
              "gw_price_refunded": "",
              "gw_tax_amount": "",
              "gw_tax_amount_invoiced": "",
              "gw_tax_amount_refunded": "",
              "is_qty_decimal": 0,
              "is_virtual": 0,
              "item_id": 0,
              "locked_do_invoice": 0,
              "locked_do_ship": 0,
              "name": "",
              "no_discount": 0,
              "order_id": 0,
              "original_price": "",
              "parent_item": "",
              "parent_item_id": 0,
              "price": "",
              "price_incl_tax": "",
              "product_id": 0,
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty_backordered": "",
              "qty_canceled": "",
              "qty_invoiced": "",
              "qty_ordered": "",
              "qty_refunded": "",
              "qty_returned": "",
              "qty_shipped": "",
              "quote_item_id": 0,
              "row_invoiced": "",
              "row_total": "",
              "row_total_incl_tax": "",
              "row_weight": "",
              "sku": "",
              "store_id": 0,
              "tax_amount": "",
              "tax_before_discount": "",
              "tax_canceled": "",
              "tax_invoiced": "",
              "tax_percent": "",
              "tax_refunded": "",
              "updated_at": "",
              "weee_tax_applied": "",
              "weee_tax_applied_amount": "",
              "weee_tax_applied_row_amount": "",
              "weee_tax_disposition": "",
              "weee_tax_row_disposition": "",
              "weight": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {
              "collection_point": {
                "city": "",
                "collection_point_id": "",
                "country": "",
                "name": "",
                "postcode": "",
                "recipient_address_id": 0,
                "region": "",
                "street": []
              },
              "ext_order_id": "",
              "shipping_experience": {
                "code": "",
                "cost": "",
                "label": ""
              }
            },
            "method": "",
            "total": {
              "base_shipping_amount": "",
              "base_shipping_canceled": "",
              "base_shipping_discount_amount": "",
              "base_shipping_discount_tax_compensation_amnt": "",
              "base_shipping_incl_tax": "",
              "base_shipping_invoiced": "",
              "base_shipping_refunded": "",
              "base_shipping_tax_amount": "",
              "base_shipping_tax_refunded": "",
              "extension_attributes": {},
              "shipping_amount": "",
              "shipping_canceled": "",
              "shipping_discount_amount": "",
              "shipping_discount_tax_compensation_amount": "",
              "shipping_incl_tax": "",
              "shipping_invoiced": "",
              "shipping_refunded": "",
              "shipping_tax_amount": "",
              "shipping_tax_refunded": ""
            }
          },
          "stock_id": 0
        }
      ]
    },
    "forced_shipment_with_invoice": 0,
    "global_currency_code": "",
    "grand_total": "",
    "hold_before_state": "",
    "hold_before_status": "",
    "increment_id": "",
    "is_virtual": 0,
    "items": [
      {}
    ],
    "order_currency_code": "",
    "original_increment_id": "",
    "payment": {
      "account_status": "",
      "additional_data": "",
      "additional_information": [],
      "address_status": "",
      "amount_authorized": "",
      "amount_canceled": "",
      "amount_ordered": "",
      "amount_paid": "",
      "amount_refunded": "",
      "anet_trans_method": "",
      "base_amount_authorized": "",
      "base_amount_canceled": "",
      "base_amount_ordered": "",
      "base_amount_paid": "",
      "base_amount_paid_online": "",
      "base_amount_refunded": "",
      "base_amount_refunded_online": "",
      "base_shipping_amount": "",
      "base_shipping_captured": "",
      "base_shipping_refunded": "",
      "cc_approval": "",
      "cc_avs_status": "",
      "cc_cid_status": "",
      "cc_debug_request_body": "",
      "cc_debug_response_body": "",
      "cc_debug_response_serialized": "",
      "cc_exp_month": "",
      "cc_exp_year": "",
      "cc_last4": "",
      "cc_number_enc": "",
      "cc_owner": "",
      "cc_secure_verify": "",
      "cc_ss_issue": "",
      "cc_ss_start_month": "",
      "cc_ss_start_year": "",
      "cc_status": "",
      "cc_status_description": "",
      "cc_trans_id": "",
      "cc_type": "",
      "echeck_account_name": "",
      "echeck_account_type": "",
      "echeck_bank_name": "",
      "echeck_routing_number": "",
      "echeck_type": "",
      "entity_id": 0,
      "extension_attributes": {
        "vault_payment_token": {
          "created_at": "",
          "customer_id": 0,
          "entity_id": 0,
          "expires_at": "",
          "gateway_token": "",
          "is_active": false,
          "is_visible": false,
          "payment_method_code": "",
          "public_hash": "",
          "token_details": "",
          "type": ""
        }
      },
      "last_trans_id": "",
      "method": "",
      "parent_id": 0,
      "po_number": "",
      "protection_eligibility": "",
      "quote_payment_id": 0,
      "shipping_amount": "",
      "shipping_captured": "",
      "shipping_refunded": ""
    },
    "payment_auth_expiration": 0,
    "payment_authorization_amount": "",
    "protect_code": "",
    "quote_address_id": 0,
    "quote_id": 0,
    "relation_child_id": "",
    "relation_child_real_id": "",
    "relation_parent_id": "",
    "relation_parent_real_id": "",
    "remote_ip": "",
    "shipping_amount": "",
    "shipping_canceled": "",
    "shipping_description": "",
    "shipping_discount_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_invoiced": "",
    "shipping_refunded": "",
    "shipping_tax_amount": "",
    "shipping_tax_refunded": "",
    "state": "",
    "status": "",
    "status_histories": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "entity_name": "",
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0,
        "status": ""
      }
    ],
    "store_currency_code": "",
    "store_id": 0,
    "store_name": "",
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_canceled": "",
    "subtotal_incl_tax": "",
    "subtotal_invoiced": "",
    "subtotal_refunded": "",
    "tax_amount": "",
    "tax_canceled": "",
    "tax_invoiced": "",
    "tax_refunded": "",
    "total_canceled": "",
    "total_due": "",
    "total_invoiced": "",
    "total_item_count": 0,
    "total_offline_refunded": "",
    "total_online_refunded": "",
    "total_paid": "",
    "total_qty_ordered": "",
    "total_refunded": "",
    "updated_at": "",
    "weight": "",
    "x_forwarded_for": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/orders/create');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'entity' => [
    'adjustment_negative' => '',
    'adjustment_positive' => '',
    'applied_rule_ids' => '',
    'base_adjustment_negative' => '',
    'base_adjustment_positive' => '',
    'base_currency_code' => '',
    'base_discount_amount' => '',
    'base_discount_canceled' => '',
    'base_discount_invoiced' => '',
    'base_discount_refunded' => '',
    'base_discount_tax_compensation_amount' => '',
    'base_discount_tax_compensation_invoiced' => '',
    'base_discount_tax_compensation_refunded' => '',
    'base_grand_total' => '',
    'base_shipping_amount' => '',
    'base_shipping_canceled' => '',
    'base_shipping_discount_amount' => '',
    'base_shipping_discount_tax_compensation_amnt' => '',
    'base_shipping_incl_tax' => '',
    'base_shipping_invoiced' => '',
    'base_shipping_refunded' => '',
    'base_shipping_tax_amount' => '',
    'base_shipping_tax_refunded' => '',
    'base_subtotal' => '',
    'base_subtotal_canceled' => '',
    'base_subtotal_incl_tax' => '',
    'base_subtotal_invoiced' => '',
    'base_subtotal_refunded' => '',
    'base_tax_amount' => '',
    'base_tax_canceled' => '',
    'base_tax_invoiced' => '',
    'base_tax_refunded' => '',
    'base_to_global_rate' => '',
    'base_to_order_rate' => '',
    'base_total_canceled' => '',
    'base_total_due' => '',
    'base_total_invoiced' => '',
    'base_total_invoiced_cost' => '',
    'base_total_offline_refunded' => '',
    'base_total_online_refunded' => '',
    'base_total_paid' => '',
    'base_total_qty_ordered' => '',
    'base_total_refunded' => '',
    'billing_address' => [
        'address_type' => '',
        'city' => '',
        'company' => '',
        'country_id' => '',
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'entity_id' => 0,
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ]
        ],
        'fax' => '',
        'firstname' => '',
        'lastname' => '',
        'middlename' => '',
        'parent_id' => 0,
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => '',
        'vat_is_valid' => 0,
        'vat_request_date' => '',
        'vat_request_id' => '',
        'vat_request_success' => 0
    ],
    'billing_address_id' => 0,
    'can_ship_partially' => 0,
    'can_ship_partially_item' => 0,
    'coupon_code' => '',
    'created_at' => '',
    'customer_dob' => '',
    'customer_email' => '',
    'customer_firstname' => '',
    'customer_gender' => 0,
    'customer_group_id' => 0,
    'customer_id' => 0,
    'customer_is_guest' => 0,
    'customer_lastname' => '',
    'customer_middlename' => '',
    'customer_note' => '',
    'customer_note_notify' => 0,
    'customer_prefix' => '',
    'customer_suffix' => '',
    'customer_taxvat' => '',
    'discount_amount' => '',
    'discount_canceled' => '',
    'discount_description' => '',
    'discount_invoiced' => '',
    'discount_refunded' => '',
    'discount_tax_compensation_amount' => '',
    'discount_tax_compensation_invoiced' => '',
    'discount_tax_compensation_refunded' => '',
    'edit_increment' => 0,
    'email_sent' => 0,
    'entity_id' => 0,
    'ext_customer_id' => '',
    'ext_order_id' => '',
    'extension_attributes' => [
        'amazon_order_reference_id' => '',
        'applied_taxes' => [
                [
                                'amount' => '',
                                'base_amount' => '',
                                'code' => '',
                                'extension_attributes' => [
                                                                'rates' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'percent' => '',
                                                                                                                                                                                                                                                                'title' => ''
                                                                                                                                ]
                                                                ]
                                ],
                                'percent' => '',
                                'title' => ''
                ]
        ],
        'base_customer_balance_amount' => '',
        'base_customer_balance_invoiced' => '',
        'base_customer_balance_refunded' => '',
        'base_customer_balance_total_refunded' => '',
        'base_gift_cards_amount' => '',
        'base_gift_cards_invoiced' => '',
        'base_gift_cards_refunded' => '',
        'base_reward_currency_amount' => '',
        'company_order_attributes' => [
                'company_id' => 0,
                'company_name' => '',
                'extension_attributes' => [
                                
                ],
                'order_id' => 0
        ],
        'converting_from_quote' => null,
        'customer_balance_amount' => '',
        'customer_balance_invoiced' => '',
        'customer_balance_refunded' => '',
        'customer_balance_total_refunded' => '',
        'gift_cards' => [
                [
                                'amount' => '',
                                'base_amount' => '',
                                'code' => '',
                                'id' => 0
                ]
        ],
        'gift_cards_amount' => '',
        'gift_cards_invoiced' => '',
        'gift_cards_refunded' => '',
        'gift_message' => [
                'customer_id' => 0,
                'extension_attributes' => [
                                'entity_id' => '',
                                'entity_type' => '',
                                'wrapping_add_printed_card' => null,
                                'wrapping_allow_gift_receipt' => null,
                                'wrapping_id' => 0
                ],
                'gift_message_id' => 0,
                'message' => '',
                'recipient' => '',
                'sender' => ''
        ],
        'gw_add_card' => '',
        'gw_allow_gift_receipt' => '',
        'gw_base_price' => '',
        'gw_base_price_incl_tax' => '',
        'gw_base_price_invoiced' => '',
        'gw_base_price_refunded' => '',
        'gw_base_tax_amount' => '',
        'gw_base_tax_amount_invoiced' => '',
        'gw_base_tax_amount_refunded' => '',
        'gw_card_base_price' => '',
        'gw_card_base_price_incl_tax' => '',
        'gw_card_base_price_invoiced' => '',
        'gw_card_base_price_refunded' => '',
        'gw_card_base_tax_amount' => '',
        'gw_card_base_tax_invoiced' => '',
        'gw_card_base_tax_refunded' => '',
        'gw_card_price' => '',
        'gw_card_price_incl_tax' => '',
        'gw_card_price_invoiced' => '',
        'gw_card_price_refunded' => '',
        'gw_card_tax_amount' => '',
        'gw_card_tax_invoiced' => '',
        'gw_card_tax_refunded' => '',
        'gw_id' => '',
        'gw_items_base_price' => '',
        'gw_items_base_price_incl_tax' => '',
        'gw_items_base_price_invoiced' => '',
        'gw_items_base_price_refunded' => '',
        'gw_items_base_tax_amount' => '',
        'gw_items_base_tax_invoiced' => '',
        'gw_items_base_tax_refunded' => '',
        'gw_items_price' => '',
        'gw_items_price_incl_tax' => '',
        'gw_items_price_invoiced' => '',
        'gw_items_price_refunded' => '',
        'gw_items_tax_amount' => '',
        'gw_items_tax_invoiced' => '',
        'gw_items_tax_refunded' => '',
        'gw_price' => '',
        'gw_price_incl_tax' => '',
        'gw_price_invoiced' => '',
        'gw_price_refunded' => '',
        'gw_tax_amount' => '',
        'gw_tax_amount_invoiced' => '',
        'gw_tax_amount_refunded' => '',
        'item_applied_taxes' => [
                [
                                'applied_taxes' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'associated_item_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'item_id' => 0,
                                'type' => ''
                ]
        ],
        'payment_additional_info' => [
                [
                                'key' => '',
                                'value' => ''
                ]
        ],
        'reward_currency_amount' => '',
        'reward_points_balance' => 0,
        'shipping_assignments' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'items' => [
                                                                [
                                                                                                                                'additional_data' => '',
                                                                                                                                'amount_refunded' => '',
                                                                                                                                'applied_rule_ids' => '',
                                                                                                                                'base_amount_refunded' => '',
                                                                                                                                'base_cost' => '',
                                                                                                                                'base_discount_amount' => '',
                                                                                                                                'base_discount_invoiced' => '',
                                                                                                                                'base_discount_refunded' => '',
                                                                                                                                'base_discount_tax_compensation_amount' => '',
                                                                                                                                'base_discount_tax_compensation_invoiced' => '',
                                                                                                                                'base_discount_tax_compensation_refunded' => '',
                                                                                                                                'base_original_price' => '',
                                                                                                                                'base_price' => '',
                                                                                                                                'base_price_incl_tax' => '',
                                                                                                                                'base_row_invoiced' => '',
                                                                                                                                'base_row_total' => '',
                                                                                                                                'base_row_total_incl_tax' => '',
                                                                                                                                'base_tax_amount' => '',
                                                                                                                                'base_tax_before_discount' => '',
                                                                                                                                'base_tax_invoiced' => '',
                                                                                                                                'base_tax_refunded' => '',
                                                                                                                                'base_weee_tax_applied_amount' => '',
                                                                                                                                'base_weee_tax_applied_row_amnt' => '',
                                                                                                                                'base_weee_tax_disposition' => '',
                                                                                                                                'base_weee_tax_row_disposition' => '',
                                                                                                                                'created_at' => '',
                                                                                                                                'description' => '',
                                                                                                                                'discount_amount' => '',
                                                                                                                                'discount_invoiced' => '',
                                                                                                                                'discount_percent' => '',
                                                                                                                                'discount_refunded' => '',
                                                                                                                                'discount_tax_compensation_amount' => '',
                                                                                                                                'discount_tax_compensation_canceled' => '',
                                                                                                                                'discount_tax_compensation_invoiced' => '',
                                                                                                                                'discount_tax_compensation_refunded' => '',
                                                                                                                                'event_id' => 0,
                                                                                                                                'ext_order_item_id' => '',
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'gift_message' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'gw_base_price' => '',
                                                                                                                                                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                'gw_id' => '',
                                                                                                                                                                                                                                                                'gw_price' => '',
                                                                                                                                                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                'invoice_text_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'vertex_tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'free_shipping' => 0,
                                                                                                                                'gw_base_price' => '',
                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                'gw_id' => 0,
                                                                                                                                'gw_price' => '',
                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                'is_qty_decimal' => 0,
                                                                                                                                'is_virtual' => 0,
                                                                                                                                'item_id' => 0,
                                                                                                                                'locked_do_invoice' => 0,
                                                                                                                                'locked_do_ship' => 0,
                                                                                                                                'name' => '',
                                                                                                                                'no_discount' => 0,
                                                                                                                                'order_id' => 0,
                                                                                                                                'original_price' => '',
                                                                                                                                'parent_item' => '',
                                                                                                                                'parent_item_id' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'price_incl_tax' => '',
                                                                                                                                'product_id' => 0,
                                                                                                                                'product_option' => [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'bundle_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_qty' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'configurable_item_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_links' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_item_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_message' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_name' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'product_type' => '',
                                                                                                                                'qty_backordered' => '',
                                                                                                                                'qty_canceled' => '',
                                                                                                                                'qty_invoiced' => '',
                                                                                                                                'qty_ordered' => '',
                                                                                                                                'qty_refunded' => '',
                                                                                                                                'qty_returned' => '',
                                                                                                                                'qty_shipped' => '',
                                                                                                                                'quote_item_id' => 0,
                                                                                                                                'row_invoiced' => '',
                                                                                                                                'row_total' => '',
                                                                                                                                'row_total_incl_tax' => '',
                                                                                                                                'row_weight' => '',
                                                                                                                                'sku' => '',
                                                                                                                                'store_id' => 0,
                                                                                                                                'tax_amount' => '',
                                                                                                                                'tax_before_discount' => '',
                                                                                                                                'tax_canceled' => '',
                                                                                                                                'tax_invoiced' => '',
                                                                                                                                'tax_percent' => '',
                                                                                                                                'tax_refunded' => '',
                                                                                                                                'updated_at' => '',
                                                                                                                                'weee_tax_applied' => '',
                                                                                                                                'weee_tax_applied_amount' => '',
                                                                                                                                'weee_tax_applied_row_amount' => '',
                                                                                                                                'weee_tax_disposition' => '',
                                                                                                                                'weee_tax_row_disposition' => '',
                                                                                                                                'weight' => ''
                                                                ]
                                ],
                                'shipping' => [
                                                                'address' => [
                                                                                                                                
                                                                ],
                                                                'extension_attributes' => [
                                                                                                                                'collection_point' => [
                                                                                                                                                                                                                                                                'city' => '',
                                                                                                                                                                                                                                                                'collection_point_id' => '',
                                                                                                                                                                                                                                                                'country' => '',
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'postcode' => '',
                                                                                                                                                                                                                                                                'recipient_address_id' => 0,
                                                                                                                                                                                                                                                                'region' => '',
                                                                                                                                                                                                                                                                'street' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'ext_order_id' => '',
                                                                                                                                'shipping_experience' => [
                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                'cost' => '',
                                                                                                                                                                                                                                                                'label' => ''
                                                                                                                                ]
                                                                ],
                                                                'method' => '',
                                                                'total' => [
                                                                                                                                'base_shipping_amount' => '',
                                                                                                                                'base_shipping_canceled' => '',
                                                                                                                                'base_shipping_discount_amount' => '',
                                                                                                                                'base_shipping_discount_tax_compensation_amnt' => '',
                                                                                                                                'base_shipping_incl_tax' => '',
                                                                                                                                'base_shipping_invoiced' => '',
                                                                                                                                'base_shipping_refunded' => '',
                                                                                                                                'base_shipping_tax_amount' => '',
                                                                                                                                'base_shipping_tax_refunded' => '',
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'shipping_amount' => '',
                                                                                                                                'shipping_canceled' => '',
                                                                                                                                'shipping_discount_amount' => '',
                                                                                                                                'shipping_discount_tax_compensation_amount' => '',
                                                                                                                                'shipping_incl_tax' => '',
                                                                                                                                'shipping_invoiced' => '',
                                                                                                                                'shipping_refunded' => '',
                                                                                                                                'shipping_tax_amount' => '',
                                                                                                                                'shipping_tax_refunded' => ''
                                                                ]
                                ],
                                'stock_id' => 0
                ]
        ]
    ],
    'forced_shipment_with_invoice' => 0,
    'global_currency_code' => '',
    'grand_total' => '',
    'hold_before_state' => '',
    'hold_before_status' => '',
    'increment_id' => '',
    'is_virtual' => 0,
    'items' => [
        [
                
        ]
    ],
    'order_currency_code' => '',
    'original_increment_id' => '',
    'payment' => [
        'account_status' => '',
        'additional_data' => '',
        'additional_information' => [
                
        ],
        'address_status' => '',
        'amount_authorized' => '',
        'amount_canceled' => '',
        'amount_ordered' => '',
        'amount_paid' => '',
        'amount_refunded' => '',
        'anet_trans_method' => '',
        'base_amount_authorized' => '',
        'base_amount_canceled' => '',
        'base_amount_ordered' => '',
        'base_amount_paid' => '',
        'base_amount_paid_online' => '',
        'base_amount_refunded' => '',
        'base_amount_refunded_online' => '',
        'base_shipping_amount' => '',
        'base_shipping_captured' => '',
        'base_shipping_refunded' => '',
        'cc_approval' => '',
        'cc_avs_status' => '',
        'cc_cid_status' => '',
        'cc_debug_request_body' => '',
        'cc_debug_response_body' => '',
        'cc_debug_response_serialized' => '',
        'cc_exp_month' => '',
        'cc_exp_year' => '',
        'cc_last4' => '',
        'cc_number_enc' => '',
        'cc_owner' => '',
        'cc_secure_verify' => '',
        'cc_ss_issue' => '',
        'cc_ss_start_month' => '',
        'cc_ss_start_year' => '',
        'cc_status' => '',
        'cc_status_description' => '',
        'cc_trans_id' => '',
        'cc_type' => '',
        'echeck_account_name' => '',
        'echeck_account_type' => '',
        'echeck_bank_name' => '',
        'echeck_routing_number' => '',
        'echeck_type' => '',
        'entity_id' => 0,
        'extension_attributes' => [
                'vault_payment_token' => [
                                'created_at' => '',
                                'customer_id' => 0,
                                'entity_id' => 0,
                                'expires_at' => '',
                                'gateway_token' => '',
                                'is_active' => null,
                                'is_visible' => null,
                                'payment_method_code' => '',
                                'public_hash' => '',
                                'token_details' => '',
                                'type' => ''
                ]
        ],
        'last_trans_id' => '',
        'method' => '',
        'parent_id' => 0,
        'po_number' => '',
        'protection_eligibility' => '',
        'quote_payment_id' => 0,
        'shipping_amount' => '',
        'shipping_captured' => '',
        'shipping_refunded' => ''
    ],
    'payment_auth_expiration' => 0,
    'payment_authorization_amount' => '',
    'protect_code' => '',
    'quote_address_id' => 0,
    'quote_id' => 0,
    'relation_child_id' => '',
    'relation_child_real_id' => '',
    'relation_parent_id' => '',
    'relation_parent_real_id' => '',
    'remote_ip' => '',
    'shipping_amount' => '',
    'shipping_canceled' => '',
    'shipping_description' => '',
    'shipping_discount_amount' => '',
    'shipping_discount_tax_compensation_amount' => '',
    'shipping_incl_tax' => '',
    'shipping_invoiced' => '',
    'shipping_refunded' => '',
    'shipping_tax_amount' => '',
    'shipping_tax_refunded' => '',
    'state' => '',
    'status' => '',
    'status_histories' => [
        [
                'comment' => '',
                'created_at' => '',
                'entity_id' => 0,
                'entity_name' => '',
                'extension_attributes' => [
                                
                ],
                'is_customer_notified' => 0,
                'is_visible_on_front' => 0,
                'parent_id' => 0,
                'status' => ''
        ]
    ],
    'store_currency_code' => '',
    'store_id' => 0,
    'store_name' => '',
    'store_to_base_rate' => '',
    'store_to_order_rate' => '',
    'subtotal' => '',
    'subtotal_canceled' => '',
    'subtotal_incl_tax' => '',
    'subtotal_invoiced' => '',
    'subtotal_refunded' => '',
    'tax_amount' => '',
    'tax_canceled' => '',
    'tax_invoiced' => '',
    'tax_refunded' => '',
    'total_canceled' => '',
    'total_due' => '',
    'total_invoiced' => '',
    'total_item_count' => 0,
    'total_offline_refunded' => '',
    'total_online_refunded' => '',
    'total_paid' => '',
    'total_qty_ordered' => '',
    'total_refunded' => '',
    'updated_at' => '',
    'weight' => '',
    'x_forwarded_for' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'entity' => [
    'adjustment_negative' => '',
    'adjustment_positive' => '',
    'applied_rule_ids' => '',
    'base_adjustment_negative' => '',
    'base_adjustment_positive' => '',
    'base_currency_code' => '',
    'base_discount_amount' => '',
    'base_discount_canceled' => '',
    'base_discount_invoiced' => '',
    'base_discount_refunded' => '',
    'base_discount_tax_compensation_amount' => '',
    'base_discount_tax_compensation_invoiced' => '',
    'base_discount_tax_compensation_refunded' => '',
    'base_grand_total' => '',
    'base_shipping_amount' => '',
    'base_shipping_canceled' => '',
    'base_shipping_discount_amount' => '',
    'base_shipping_discount_tax_compensation_amnt' => '',
    'base_shipping_incl_tax' => '',
    'base_shipping_invoiced' => '',
    'base_shipping_refunded' => '',
    'base_shipping_tax_amount' => '',
    'base_shipping_tax_refunded' => '',
    'base_subtotal' => '',
    'base_subtotal_canceled' => '',
    'base_subtotal_incl_tax' => '',
    'base_subtotal_invoiced' => '',
    'base_subtotal_refunded' => '',
    'base_tax_amount' => '',
    'base_tax_canceled' => '',
    'base_tax_invoiced' => '',
    'base_tax_refunded' => '',
    'base_to_global_rate' => '',
    'base_to_order_rate' => '',
    'base_total_canceled' => '',
    'base_total_due' => '',
    'base_total_invoiced' => '',
    'base_total_invoiced_cost' => '',
    'base_total_offline_refunded' => '',
    'base_total_online_refunded' => '',
    'base_total_paid' => '',
    'base_total_qty_ordered' => '',
    'base_total_refunded' => '',
    'billing_address' => [
        'address_type' => '',
        'city' => '',
        'company' => '',
        'country_id' => '',
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'entity_id' => 0,
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ]
        ],
        'fax' => '',
        'firstname' => '',
        'lastname' => '',
        'middlename' => '',
        'parent_id' => 0,
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => '',
        'vat_is_valid' => 0,
        'vat_request_date' => '',
        'vat_request_id' => '',
        'vat_request_success' => 0
    ],
    'billing_address_id' => 0,
    'can_ship_partially' => 0,
    'can_ship_partially_item' => 0,
    'coupon_code' => '',
    'created_at' => '',
    'customer_dob' => '',
    'customer_email' => '',
    'customer_firstname' => '',
    'customer_gender' => 0,
    'customer_group_id' => 0,
    'customer_id' => 0,
    'customer_is_guest' => 0,
    'customer_lastname' => '',
    'customer_middlename' => '',
    'customer_note' => '',
    'customer_note_notify' => 0,
    'customer_prefix' => '',
    'customer_suffix' => '',
    'customer_taxvat' => '',
    'discount_amount' => '',
    'discount_canceled' => '',
    'discount_description' => '',
    'discount_invoiced' => '',
    'discount_refunded' => '',
    'discount_tax_compensation_amount' => '',
    'discount_tax_compensation_invoiced' => '',
    'discount_tax_compensation_refunded' => '',
    'edit_increment' => 0,
    'email_sent' => 0,
    'entity_id' => 0,
    'ext_customer_id' => '',
    'ext_order_id' => '',
    'extension_attributes' => [
        'amazon_order_reference_id' => '',
        'applied_taxes' => [
                [
                                'amount' => '',
                                'base_amount' => '',
                                'code' => '',
                                'extension_attributes' => [
                                                                'rates' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'percent' => '',
                                                                                                                                                                                                                                                                'title' => ''
                                                                                                                                ]
                                                                ]
                                ],
                                'percent' => '',
                                'title' => ''
                ]
        ],
        'base_customer_balance_amount' => '',
        'base_customer_balance_invoiced' => '',
        'base_customer_balance_refunded' => '',
        'base_customer_balance_total_refunded' => '',
        'base_gift_cards_amount' => '',
        'base_gift_cards_invoiced' => '',
        'base_gift_cards_refunded' => '',
        'base_reward_currency_amount' => '',
        'company_order_attributes' => [
                'company_id' => 0,
                'company_name' => '',
                'extension_attributes' => [
                                
                ],
                'order_id' => 0
        ],
        'converting_from_quote' => null,
        'customer_balance_amount' => '',
        'customer_balance_invoiced' => '',
        'customer_balance_refunded' => '',
        'customer_balance_total_refunded' => '',
        'gift_cards' => [
                [
                                'amount' => '',
                                'base_amount' => '',
                                'code' => '',
                                'id' => 0
                ]
        ],
        'gift_cards_amount' => '',
        'gift_cards_invoiced' => '',
        'gift_cards_refunded' => '',
        'gift_message' => [
                'customer_id' => 0,
                'extension_attributes' => [
                                'entity_id' => '',
                                'entity_type' => '',
                                'wrapping_add_printed_card' => null,
                                'wrapping_allow_gift_receipt' => null,
                                'wrapping_id' => 0
                ],
                'gift_message_id' => 0,
                'message' => '',
                'recipient' => '',
                'sender' => ''
        ],
        'gw_add_card' => '',
        'gw_allow_gift_receipt' => '',
        'gw_base_price' => '',
        'gw_base_price_incl_tax' => '',
        'gw_base_price_invoiced' => '',
        'gw_base_price_refunded' => '',
        'gw_base_tax_amount' => '',
        'gw_base_tax_amount_invoiced' => '',
        'gw_base_tax_amount_refunded' => '',
        'gw_card_base_price' => '',
        'gw_card_base_price_incl_tax' => '',
        'gw_card_base_price_invoiced' => '',
        'gw_card_base_price_refunded' => '',
        'gw_card_base_tax_amount' => '',
        'gw_card_base_tax_invoiced' => '',
        'gw_card_base_tax_refunded' => '',
        'gw_card_price' => '',
        'gw_card_price_incl_tax' => '',
        'gw_card_price_invoiced' => '',
        'gw_card_price_refunded' => '',
        'gw_card_tax_amount' => '',
        'gw_card_tax_invoiced' => '',
        'gw_card_tax_refunded' => '',
        'gw_id' => '',
        'gw_items_base_price' => '',
        'gw_items_base_price_incl_tax' => '',
        'gw_items_base_price_invoiced' => '',
        'gw_items_base_price_refunded' => '',
        'gw_items_base_tax_amount' => '',
        'gw_items_base_tax_invoiced' => '',
        'gw_items_base_tax_refunded' => '',
        'gw_items_price' => '',
        'gw_items_price_incl_tax' => '',
        'gw_items_price_invoiced' => '',
        'gw_items_price_refunded' => '',
        'gw_items_tax_amount' => '',
        'gw_items_tax_invoiced' => '',
        'gw_items_tax_refunded' => '',
        'gw_price' => '',
        'gw_price_incl_tax' => '',
        'gw_price_invoiced' => '',
        'gw_price_refunded' => '',
        'gw_tax_amount' => '',
        'gw_tax_amount_invoiced' => '',
        'gw_tax_amount_refunded' => '',
        'item_applied_taxes' => [
                [
                                'applied_taxes' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'associated_item_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'item_id' => 0,
                                'type' => ''
                ]
        ],
        'payment_additional_info' => [
                [
                                'key' => '',
                                'value' => ''
                ]
        ],
        'reward_currency_amount' => '',
        'reward_points_balance' => 0,
        'shipping_assignments' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'items' => [
                                                                [
                                                                                                                                'additional_data' => '',
                                                                                                                                'amount_refunded' => '',
                                                                                                                                'applied_rule_ids' => '',
                                                                                                                                'base_amount_refunded' => '',
                                                                                                                                'base_cost' => '',
                                                                                                                                'base_discount_amount' => '',
                                                                                                                                'base_discount_invoiced' => '',
                                                                                                                                'base_discount_refunded' => '',
                                                                                                                                'base_discount_tax_compensation_amount' => '',
                                                                                                                                'base_discount_tax_compensation_invoiced' => '',
                                                                                                                                'base_discount_tax_compensation_refunded' => '',
                                                                                                                                'base_original_price' => '',
                                                                                                                                'base_price' => '',
                                                                                                                                'base_price_incl_tax' => '',
                                                                                                                                'base_row_invoiced' => '',
                                                                                                                                'base_row_total' => '',
                                                                                                                                'base_row_total_incl_tax' => '',
                                                                                                                                'base_tax_amount' => '',
                                                                                                                                'base_tax_before_discount' => '',
                                                                                                                                'base_tax_invoiced' => '',
                                                                                                                                'base_tax_refunded' => '',
                                                                                                                                'base_weee_tax_applied_amount' => '',
                                                                                                                                'base_weee_tax_applied_row_amnt' => '',
                                                                                                                                'base_weee_tax_disposition' => '',
                                                                                                                                'base_weee_tax_row_disposition' => '',
                                                                                                                                'created_at' => '',
                                                                                                                                'description' => '',
                                                                                                                                'discount_amount' => '',
                                                                                                                                'discount_invoiced' => '',
                                                                                                                                'discount_percent' => '',
                                                                                                                                'discount_refunded' => '',
                                                                                                                                'discount_tax_compensation_amount' => '',
                                                                                                                                'discount_tax_compensation_canceled' => '',
                                                                                                                                'discount_tax_compensation_invoiced' => '',
                                                                                                                                'discount_tax_compensation_refunded' => '',
                                                                                                                                'event_id' => 0,
                                                                                                                                'ext_order_item_id' => '',
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                'gift_message' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'gw_base_price' => '',
                                                                                                                                                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                'gw_id' => '',
                                                                                                                                                                                                                                                                'gw_price' => '',
                                                                                                                                                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                                                                                                                                                'invoice_text_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'vertex_tax_codes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'free_shipping' => 0,
                                                                                                                                'gw_base_price' => '',
                                                                                                                                'gw_base_price_invoiced' => '',
                                                                                                                                'gw_base_price_refunded' => '',
                                                                                                                                'gw_base_tax_amount' => '',
                                                                                                                                'gw_base_tax_amount_invoiced' => '',
                                                                                                                                'gw_base_tax_amount_refunded' => '',
                                                                                                                                'gw_id' => 0,
                                                                                                                                'gw_price' => '',
                                                                                                                                'gw_price_invoiced' => '',
                                                                                                                                'gw_price_refunded' => '',
                                                                                                                                'gw_tax_amount' => '',
                                                                                                                                'gw_tax_amount_invoiced' => '',
                                                                                                                                'gw_tax_amount_refunded' => '',
                                                                                                                                'is_qty_decimal' => 0,
                                                                                                                                'is_virtual' => 0,
                                                                                                                                'item_id' => 0,
                                                                                                                                'locked_do_invoice' => 0,
                                                                                                                                'locked_do_ship' => 0,
                                                                                                                                'name' => '',
                                                                                                                                'no_discount' => 0,
                                                                                                                                'order_id' => 0,
                                                                                                                                'original_price' => '',
                                                                                                                                'parent_item' => '',
                                                                                                                                'parent_item_id' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'price_incl_tax' => '',
                                                                                                                                'product_id' => 0,
                                                                                                                                'product_option' => [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'bundle_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_qty' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_selections' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'configurable_item_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_options' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'file_info' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_value' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'downloadable_links' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_item_option' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'custom_giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_amount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_message' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_recipient_name' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_email' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'giftcard_sender_name' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'product_type' => '',
                                                                                                                                'qty_backordered' => '',
                                                                                                                                'qty_canceled' => '',
                                                                                                                                'qty_invoiced' => '',
                                                                                                                                'qty_ordered' => '',
                                                                                                                                'qty_refunded' => '',
                                                                                                                                'qty_returned' => '',
                                                                                                                                'qty_shipped' => '',
                                                                                                                                'quote_item_id' => 0,
                                                                                                                                'row_invoiced' => '',
                                                                                                                                'row_total' => '',
                                                                                                                                'row_total_incl_tax' => '',
                                                                                                                                'row_weight' => '',
                                                                                                                                'sku' => '',
                                                                                                                                'store_id' => 0,
                                                                                                                                'tax_amount' => '',
                                                                                                                                'tax_before_discount' => '',
                                                                                                                                'tax_canceled' => '',
                                                                                                                                'tax_invoiced' => '',
                                                                                                                                'tax_percent' => '',
                                                                                                                                'tax_refunded' => '',
                                                                                                                                'updated_at' => '',
                                                                                                                                'weee_tax_applied' => '',
                                                                                                                                'weee_tax_applied_amount' => '',
                                                                                                                                'weee_tax_applied_row_amount' => '',
                                                                                                                                'weee_tax_disposition' => '',
                                                                                                                                'weee_tax_row_disposition' => '',
                                                                                                                                'weight' => ''
                                                                ]
                                ],
                                'shipping' => [
                                                                'address' => [
                                                                                                                                
                                                                ],
                                                                'extension_attributes' => [
                                                                                                                                'collection_point' => [
                                                                                                                                                                                                                                                                'city' => '',
                                                                                                                                                                                                                                                                'collection_point_id' => '',
                                                                                                                                                                                                                                                                'country' => '',
                                                                                                                                                                                                                                                                'name' => '',
                                                                                                                                                                                                                                                                'postcode' => '',
                                                                                                                                                                                                                                                                'recipient_address_id' => 0,
                                                                                                                                                                                                                                                                'region' => '',
                                                                                                                                                                                                                                                                'street' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'ext_order_id' => '',
                                                                                                                                'shipping_experience' => [
                                                                                                                                                                                                                                                                'code' => '',
                                                                                                                                                                                                                                                                'cost' => '',
                                                                                                                                                                                                                                                                'label' => ''
                                                                                                                                ]
                                                                ],
                                                                'method' => '',
                                                                'total' => [
                                                                                                                                'base_shipping_amount' => '',
                                                                                                                                'base_shipping_canceled' => '',
                                                                                                                                'base_shipping_discount_amount' => '',
                                                                                                                                'base_shipping_discount_tax_compensation_amnt' => '',
                                                                                                                                'base_shipping_incl_tax' => '',
                                                                                                                                'base_shipping_invoiced' => '',
                                                                                                                                'base_shipping_refunded' => '',
                                                                                                                                'base_shipping_tax_amount' => '',
                                                                                                                                'base_shipping_tax_refunded' => '',
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'shipping_amount' => '',
                                                                                                                                'shipping_canceled' => '',
                                                                                                                                'shipping_discount_amount' => '',
                                                                                                                                'shipping_discount_tax_compensation_amount' => '',
                                                                                                                                'shipping_incl_tax' => '',
                                                                                                                                'shipping_invoiced' => '',
                                                                                                                                'shipping_refunded' => '',
                                                                                                                                'shipping_tax_amount' => '',
                                                                                                                                'shipping_tax_refunded' => ''
                                                                ]
                                ],
                                'stock_id' => 0
                ]
        ]
    ],
    'forced_shipment_with_invoice' => 0,
    'global_currency_code' => '',
    'grand_total' => '',
    'hold_before_state' => '',
    'hold_before_status' => '',
    'increment_id' => '',
    'is_virtual' => 0,
    'items' => [
        [
                
        ]
    ],
    'order_currency_code' => '',
    'original_increment_id' => '',
    'payment' => [
        'account_status' => '',
        'additional_data' => '',
        'additional_information' => [
                
        ],
        'address_status' => '',
        'amount_authorized' => '',
        'amount_canceled' => '',
        'amount_ordered' => '',
        'amount_paid' => '',
        'amount_refunded' => '',
        'anet_trans_method' => '',
        'base_amount_authorized' => '',
        'base_amount_canceled' => '',
        'base_amount_ordered' => '',
        'base_amount_paid' => '',
        'base_amount_paid_online' => '',
        'base_amount_refunded' => '',
        'base_amount_refunded_online' => '',
        'base_shipping_amount' => '',
        'base_shipping_captured' => '',
        'base_shipping_refunded' => '',
        'cc_approval' => '',
        'cc_avs_status' => '',
        'cc_cid_status' => '',
        'cc_debug_request_body' => '',
        'cc_debug_response_body' => '',
        'cc_debug_response_serialized' => '',
        'cc_exp_month' => '',
        'cc_exp_year' => '',
        'cc_last4' => '',
        'cc_number_enc' => '',
        'cc_owner' => '',
        'cc_secure_verify' => '',
        'cc_ss_issue' => '',
        'cc_ss_start_month' => '',
        'cc_ss_start_year' => '',
        'cc_status' => '',
        'cc_status_description' => '',
        'cc_trans_id' => '',
        'cc_type' => '',
        'echeck_account_name' => '',
        'echeck_account_type' => '',
        'echeck_bank_name' => '',
        'echeck_routing_number' => '',
        'echeck_type' => '',
        'entity_id' => 0,
        'extension_attributes' => [
                'vault_payment_token' => [
                                'created_at' => '',
                                'customer_id' => 0,
                                'entity_id' => 0,
                                'expires_at' => '',
                                'gateway_token' => '',
                                'is_active' => null,
                                'is_visible' => null,
                                'payment_method_code' => '',
                                'public_hash' => '',
                                'token_details' => '',
                                'type' => ''
                ]
        ],
        'last_trans_id' => '',
        'method' => '',
        'parent_id' => 0,
        'po_number' => '',
        'protection_eligibility' => '',
        'quote_payment_id' => 0,
        'shipping_amount' => '',
        'shipping_captured' => '',
        'shipping_refunded' => ''
    ],
    'payment_auth_expiration' => 0,
    'payment_authorization_amount' => '',
    'protect_code' => '',
    'quote_address_id' => 0,
    'quote_id' => 0,
    'relation_child_id' => '',
    'relation_child_real_id' => '',
    'relation_parent_id' => '',
    'relation_parent_real_id' => '',
    'remote_ip' => '',
    'shipping_amount' => '',
    'shipping_canceled' => '',
    'shipping_description' => '',
    'shipping_discount_amount' => '',
    'shipping_discount_tax_compensation_amount' => '',
    'shipping_incl_tax' => '',
    'shipping_invoiced' => '',
    'shipping_refunded' => '',
    'shipping_tax_amount' => '',
    'shipping_tax_refunded' => '',
    'state' => '',
    'status' => '',
    'status_histories' => [
        [
                'comment' => '',
                'created_at' => '',
                'entity_id' => 0,
                'entity_name' => '',
                'extension_attributes' => [
                                
                ],
                'is_customer_notified' => 0,
                'is_visible_on_front' => 0,
                'parent_id' => 0,
                'status' => ''
        ]
    ],
    'store_currency_code' => '',
    'store_id' => 0,
    'store_name' => '',
    'store_to_base_rate' => '',
    'store_to_order_rate' => '',
    'subtotal' => '',
    'subtotal_canceled' => '',
    'subtotal_incl_tax' => '',
    'subtotal_invoiced' => '',
    'subtotal_refunded' => '',
    'tax_amount' => '',
    'tax_canceled' => '',
    'tax_invoiced' => '',
    'tax_refunded' => '',
    'total_canceled' => '',
    'total_due' => '',
    'total_invoiced' => '',
    'total_item_count' => 0,
    'total_offline_refunded' => '',
    'total_online_refunded' => '',
    'total_paid' => '',
    'total_qty_ordered' => '',
    'total_refunded' => '',
    'updated_at' => '',
    'weight' => '',
    'x_forwarded_for' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/orders/create');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/orders/create' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "applied_rule_ids": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_canceled": "",
    "base_discount_invoiced": "",
    "base_discount_refunded": "",
    "base_discount_tax_compensation_amount": "",
    "base_discount_tax_compensation_invoiced": "",
    "base_discount_tax_compensation_refunded": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_canceled": "",
    "base_shipping_discount_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_invoiced": "",
    "base_shipping_refunded": "",
    "base_shipping_tax_amount": "",
    "base_shipping_tax_refunded": "",
    "base_subtotal": "",
    "base_subtotal_canceled": "",
    "base_subtotal_incl_tax": "",
    "base_subtotal_invoiced": "",
    "base_subtotal_refunded": "",
    "base_tax_amount": "",
    "base_tax_canceled": "",
    "base_tax_invoiced": "",
    "base_tax_refunded": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_canceled": "",
    "base_total_due": "",
    "base_total_invoiced": "",
    "base_total_invoiced_cost": "",
    "base_total_offline_refunded": "",
    "base_total_online_refunded": "",
    "base_total_paid": "",
    "base_total_qty_ordered": "",
    "base_total_refunded": "",
    "billing_address": {
      "address_type": "",
      "city": "",
      "company": "",
      "country_id": "",
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "entity_id": 0,
      "extension_attributes": {
        "checkout_fields": [
          {
            "attribute_code": "",
            "value": ""
          }
        ]
      },
      "fax": "",
      "firstname": "",
      "lastname": "",
      "middlename": "",
      "parent_id": 0,
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": "",
      "vat_is_valid": 0,
      "vat_request_date": "",
      "vat_request_id": "",
      "vat_request_success": 0
    },
    "billing_address_id": 0,
    "can_ship_partially": 0,
    "can_ship_partially_item": 0,
    "coupon_code": "",
    "created_at": "",
    "customer_dob": "",
    "customer_email": "",
    "customer_firstname": "",
    "customer_gender": 0,
    "customer_group_id": 0,
    "customer_id": 0,
    "customer_is_guest": 0,
    "customer_lastname": "",
    "customer_middlename": "",
    "customer_note": "",
    "customer_note_notify": 0,
    "customer_prefix": "",
    "customer_suffix": "",
    "customer_taxvat": "",
    "discount_amount": "",
    "discount_canceled": "",
    "discount_description": "",
    "discount_invoiced": "",
    "discount_refunded": "",
    "discount_tax_compensation_amount": "",
    "discount_tax_compensation_invoiced": "",
    "discount_tax_compensation_refunded": "",
    "edit_increment": 0,
    "email_sent": 0,
    "entity_id": 0,
    "ext_customer_id": "",
    "ext_order_id": "",
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "applied_taxes": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "extension_attributes": {
            "rates": [
              {
                "code": "",
                "extension_attributes": {},
                "percent": "",
                "title": ""
              }
            ]
          },
          "percent": "",
          "title": ""
        }
      ],
      "base_customer_balance_amount": "",
      "base_customer_balance_invoiced": "",
      "base_customer_balance_refunded": "",
      "base_customer_balance_total_refunded": "",
      "base_gift_cards_amount": "",
      "base_gift_cards_invoiced": "",
      "base_gift_cards_refunded": "",
      "base_reward_currency_amount": "",
      "company_order_attributes": {
        "company_id": 0,
        "company_name": "",
        "extension_attributes": {},
        "order_id": 0
      },
      "converting_from_quote": false,
      "customer_balance_amount": "",
      "customer_balance_invoiced": "",
      "customer_balance_refunded": "",
      "customer_balance_total_refunded": "",
      "gift_cards": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "id": 0
        }
      ],
      "gift_cards_amount": "",
      "gift_cards_invoiced": "",
      "gift_cards_refunded": "",
      "gift_message": {
        "customer_id": 0,
        "extension_attributes": {
          "entity_id": "",
          "entity_type": "",
          "wrapping_add_printed_card": false,
          "wrapping_allow_gift_receipt": false,
          "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
      },
      "gw_add_card": "",
      "gw_allow_gift_receipt": "",
      "gw_base_price": "",
      "gw_base_price_incl_tax": "",
      "gw_base_price_invoiced": "",
      "gw_base_price_refunded": "",
      "gw_base_tax_amount": "",
      "gw_base_tax_amount_invoiced": "",
      "gw_base_tax_amount_refunded": "",
      "gw_card_base_price": "",
      "gw_card_base_price_incl_tax": "",
      "gw_card_base_price_invoiced": "",
      "gw_card_base_price_refunded": "",
      "gw_card_base_tax_amount": "",
      "gw_card_base_tax_invoiced": "",
      "gw_card_base_tax_refunded": "",
      "gw_card_price": "",
      "gw_card_price_incl_tax": "",
      "gw_card_price_invoiced": "",
      "gw_card_price_refunded": "",
      "gw_card_tax_amount": "",
      "gw_card_tax_invoiced": "",
      "gw_card_tax_refunded": "",
      "gw_id": "",
      "gw_items_base_price": "",
      "gw_items_base_price_incl_tax": "",
      "gw_items_base_price_invoiced": "",
      "gw_items_base_price_refunded": "",
      "gw_items_base_tax_amount": "",
      "gw_items_base_tax_invoiced": "",
      "gw_items_base_tax_refunded": "",
      "gw_items_price": "",
      "gw_items_price_incl_tax": "",
      "gw_items_price_invoiced": "",
      "gw_items_price_refunded": "",
      "gw_items_tax_amount": "",
      "gw_items_tax_invoiced": "",
      "gw_items_tax_refunded": "",
      "gw_price": "",
      "gw_price_incl_tax": "",
      "gw_price_invoiced": "",
      "gw_price_refunded": "",
      "gw_tax_amount": "",
      "gw_tax_amount_invoiced": "",
      "gw_tax_amount_refunded": "",
      "item_applied_taxes": [
        {
          "applied_taxes": [
            {}
          ],
          "associated_item_id": 0,
          "extension_attributes": {},
          "item_id": 0,
          "type": ""
        }
      ],
      "payment_additional_info": [
        {
          "key": "",
          "value": ""
        }
      ],
      "reward_currency_amount": "",
      "reward_points_balance": 0,
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "additional_data": "",
              "amount_refunded": "",
              "applied_rule_ids": "",
              "base_amount_refunded": "",
              "base_cost": "",
              "base_discount_amount": "",
              "base_discount_invoiced": "",
              "base_discount_refunded": "",
              "base_discount_tax_compensation_amount": "",
              "base_discount_tax_compensation_invoiced": "",
              "base_discount_tax_compensation_refunded": "",
              "base_original_price": "",
              "base_price": "",
              "base_price_incl_tax": "",
              "base_row_invoiced": "",
              "base_row_total": "",
              "base_row_total_incl_tax": "",
              "base_tax_amount": "",
              "base_tax_before_discount": "",
              "base_tax_invoiced": "",
              "base_tax_refunded": "",
              "base_weee_tax_applied_amount": "",
              "base_weee_tax_applied_row_amnt": "",
              "base_weee_tax_disposition": "",
              "base_weee_tax_row_disposition": "",
              "created_at": "",
              "description": "",
              "discount_amount": "",
              "discount_invoiced": "",
              "discount_percent": "",
              "discount_refunded": "",
              "discount_tax_compensation_amount": "",
              "discount_tax_compensation_canceled": "",
              "discount_tax_compensation_invoiced": "",
              "discount_tax_compensation_refunded": "",
              "event_id": 0,
              "ext_order_item_id": "",
              "extension_attributes": {
                "gift_message": {},
                "gw_base_price": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_id": "",
                "gw_price": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "invoice_text_codes": [],
                "tax_codes": [],
                "vertex_tax_codes": []
              },
              "free_shipping": 0,
              "gw_base_price": "",
              "gw_base_price_invoiced": "",
              "gw_base_price_refunded": "",
              "gw_base_tax_amount": "",
              "gw_base_tax_amount_invoiced": "",
              "gw_base_tax_amount_refunded": "",
              "gw_id": 0,
              "gw_price": "",
              "gw_price_invoiced": "",
              "gw_price_refunded": "",
              "gw_tax_amount": "",
              "gw_tax_amount_invoiced": "",
              "gw_tax_amount_refunded": "",
              "is_qty_decimal": 0,
              "is_virtual": 0,
              "item_id": 0,
              "locked_do_invoice": 0,
              "locked_do_ship": 0,
              "name": "",
              "no_discount": 0,
              "order_id": 0,
              "original_price": "",
              "parent_item": "",
              "parent_item_id": 0,
              "price": "",
              "price_incl_tax": "",
              "product_id": 0,
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty_backordered": "",
              "qty_canceled": "",
              "qty_invoiced": "",
              "qty_ordered": "",
              "qty_refunded": "",
              "qty_returned": "",
              "qty_shipped": "",
              "quote_item_id": 0,
              "row_invoiced": "",
              "row_total": "",
              "row_total_incl_tax": "",
              "row_weight": "",
              "sku": "",
              "store_id": 0,
              "tax_amount": "",
              "tax_before_discount": "",
              "tax_canceled": "",
              "tax_invoiced": "",
              "tax_percent": "",
              "tax_refunded": "",
              "updated_at": "",
              "weee_tax_applied": "",
              "weee_tax_applied_amount": "",
              "weee_tax_applied_row_amount": "",
              "weee_tax_disposition": "",
              "weee_tax_row_disposition": "",
              "weight": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {
              "collection_point": {
                "city": "",
                "collection_point_id": "",
                "country": "",
                "name": "",
                "postcode": "",
                "recipient_address_id": 0,
                "region": "",
                "street": []
              },
              "ext_order_id": "",
              "shipping_experience": {
                "code": "",
                "cost": "",
                "label": ""
              }
            },
            "method": "",
            "total": {
              "base_shipping_amount": "",
              "base_shipping_canceled": "",
              "base_shipping_discount_amount": "",
              "base_shipping_discount_tax_compensation_amnt": "",
              "base_shipping_incl_tax": "",
              "base_shipping_invoiced": "",
              "base_shipping_refunded": "",
              "base_shipping_tax_amount": "",
              "base_shipping_tax_refunded": "",
              "extension_attributes": {},
              "shipping_amount": "",
              "shipping_canceled": "",
              "shipping_discount_amount": "",
              "shipping_discount_tax_compensation_amount": "",
              "shipping_incl_tax": "",
              "shipping_invoiced": "",
              "shipping_refunded": "",
              "shipping_tax_amount": "",
              "shipping_tax_refunded": ""
            }
          },
          "stock_id": 0
        }
      ]
    },
    "forced_shipment_with_invoice": 0,
    "global_currency_code": "",
    "grand_total": "",
    "hold_before_state": "",
    "hold_before_status": "",
    "increment_id": "",
    "is_virtual": 0,
    "items": [
      {}
    ],
    "order_currency_code": "",
    "original_increment_id": "",
    "payment": {
      "account_status": "",
      "additional_data": "",
      "additional_information": [],
      "address_status": "",
      "amount_authorized": "",
      "amount_canceled": "",
      "amount_ordered": "",
      "amount_paid": "",
      "amount_refunded": "",
      "anet_trans_method": "",
      "base_amount_authorized": "",
      "base_amount_canceled": "",
      "base_amount_ordered": "",
      "base_amount_paid": "",
      "base_amount_paid_online": "",
      "base_amount_refunded": "",
      "base_amount_refunded_online": "",
      "base_shipping_amount": "",
      "base_shipping_captured": "",
      "base_shipping_refunded": "",
      "cc_approval": "",
      "cc_avs_status": "",
      "cc_cid_status": "",
      "cc_debug_request_body": "",
      "cc_debug_response_body": "",
      "cc_debug_response_serialized": "",
      "cc_exp_month": "",
      "cc_exp_year": "",
      "cc_last4": "",
      "cc_number_enc": "",
      "cc_owner": "",
      "cc_secure_verify": "",
      "cc_ss_issue": "",
      "cc_ss_start_month": "",
      "cc_ss_start_year": "",
      "cc_status": "",
      "cc_status_description": "",
      "cc_trans_id": "",
      "cc_type": "",
      "echeck_account_name": "",
      "echeck_account_type": "",
      "echeck_bank_name": "",
      "echeck_routing_number": "",
      "echeck_type": "",
      "entity_id": 0,
      "extension_attributes": {
        "vault_payment_token": {
          "created_at": "",
          "customer_id": 0,
          "entity_id": 0,
          "expires_at": "",
          "gateway_token": "",
          "is_active": false,
          "is_visible": false,
          "payment_method_code": "",
          "public_hash": "",
          "token_details": "",
          "type": ""
        }
      },
      "last_trans_id": "",
      "method": "",
      "parent_id": 0,
      "po_number": "",
      "protection_eligibility": "",
      "quote_payment_id": 0,
      "shipping_amount": "",
      "shipping_captured": "",
      "shipping_refunded": ""
    },
    "payment_auth_expiration": 0,
    "payment_authorization_amount": "",
    "protect_code": "",
    "quote_address_id": 0,
    "quote_id": 0,
    "relation_child_id": "",
    "relation_child_real_id": "",
    "relation_parent_id": "",
    "relation_parent_real_id": "",
    "remote_ip": "",
    "shipping_amount": "",
    "shipping_canceled": "",
    "shipping_description": "",
    "shipping_discount_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_invoiced": "",
    "shipping_refunded": "",
    "shipping_tax_amount": "",
    "shipping_tax_refunded": "",
    "state": "",
    "status": "",
    "status_histories": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "entity_name": "",
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0,
        "status": ""
      }
    ],
    "store_currency_code": "",
    "store_id": 0,
    "store_name": "",
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_canceled": "",
    "subtotal_incl_tax": "",
    "subtotal_invoiced": "",
    "subtotal_refunded": "",
    "tax_amount": "",
    "tax_canceled": "",
    "tax_invoiced": "",
    "tax_refunded": "",
    "total_canceled": "",
    "total_due": "",
    "total_invoiced": "",
    "total_item_count": 0,
    "total_offline_refunded": "",
    "total_online_refunded": "",
    "total_paid": "",
    "total_qty_ordered": "",
    "total_refunded": "",
    "updated_at": "",
    "weight": "",
    "x_forwarded_for": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/orders/create' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "applied_rule_ids": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_canceled": "",
    "base_discount_invoiced": "",
    "base_discount_refunded": "",
    "base_discount_tax_compensation_amount": "",
    "base_discount_tax_compensation_invoiced": "",
    "base_discount_tax_compensation_refunded": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_canceled": "",
    "base_shipping_discount_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_invoiced": "",
    "base_shipping_refunded": "",
    "base_shipping_tax_amount": "",
    "base_shipping_tax_refunded": "",
    "base_subtotal": "",
    "base_subtotal_canceled": "",
    "base_subtotal_incl_tax": "",
    "base_subtotal_invoiced": "",
    "base_subtotal_refunded": "",
    "base_tax_amount": "",
    "base_tax_canceled": "",
    "base_tax_invoiced": "",
    "base_tax_refunded": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_canceled": "",
    "base_total_due": "",
    "base_total_invoiced": "",
    "base_total_invoiced_cost": "",
    "base_total_offline_refunded": "",
    "base_total_online_refunded": "",
    "base_total_paid": "",
    "base_total_qty_ordered": "",
    "base_total_refunded": "",
    "billing_address": {
      "address_type": "",
      "city": "",
      "company": "",
      "country_id": "",
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "entity_id": 0,
      "extension_attributes": {
        "checkout_fields": [
          {
            "attribute_code": "",
            "value": ""
          }
        ]
      },
      "fax": "",
      "firstname": "",
      "lastname": "",
      "middlename": "",
      "parent_id": 0,
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": "",
      "vat_is_valid": 0,
      "vat_request_date": "",
      "vat_request_id": "",
      "vat_request_success": 0
    },
    "billing_address_id": 0,
    "can_ship_partially": 0,
    "can_ship_partially_item": 0,
    "coupon_code": "",
    "created_at": "",
    "customer_dob": "",
    "customer_email": "",
    "customer_firstname": "",
    "customer_gender": 0,
    "customer_group_id": 0,
    "customer_id": 0,
    "customer_is_guest": 0,
    "customer_lastname": "",
    "customer_middlename": "",
    "customer_note": "",
    "customer_note_notify": 0,
    "customer_prefix": "",
    "customer_suffix": "",
    "customer_taxvat": "",
    "discount_amount": "",
    "discount_canceled": "",
    "discount_description": "",
    "discount_invoiced": "",
    "discount_refunded": "",
    "discount_tax_compensation_amount": "",
    "discount_tax_compensation_invoiced": "",
    "discount_tax_compensation_refunded": "",
    "edit_increment": 0,
    "email_sent": 0,
    "entity_id": 0,
    "ext_customer_id": "",
    "ext_order_id": "",
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "applied_taxes": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "extension_attributes": {
            "rates": [
              {
                "code": "",
                "extension_attributes": {},
                "percent": "",
                "title": ""
              }
            ]
          },
          "percent": "",
          "title": ""
        }
      ],
      "base_customer_balance_amount": "",
      "base_customer_balance_invoiced": "",
      "base_customer_balance_refunded": "",
      "base_customer_balance_total_refunded": "",
      "base_gift_cards_amount": "",
      "base_gift_cards_invoiced": "",
      "base_gift_cards_refunded": "",
      "base_reward_currency_amount": "",
      "company_order_attributes": {
        "company_id": 0,
        "company_name": "",
        "extension_attributes": {},
        "order_id": 0
      },
      "converting_from_quote": false,
      "customer_balance_amount": "",
      "customer_balance_invoiced": "",
      "customer_balance_refunded": "",
      "customer_balance_total_refunded": "",
      "gift_cards": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "id": 0
        }
      ],
      "gift_cards_amount": "",
      "gift_cards_invoiced": "",
      "gift_cards_refunded": "",
      "gift_message": {
        "customer_id": 0,
        "extension_attributes": {
          "entity_id": "",
          "entity_type": "",
          "wrapping_add_printed_card": false,
          "wrapping_allow_gift_receipt": false,
          "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
      },
      "gw_add_card": "",
      "gw_allow_gift_receipt": "",
      "gw_base_price": "",
      "gw_base_price_incl_tax": "",
      "gw_base_price_invoiced": "",
      "gw_base_price_refunded": "",
      "gw_base_tax_amount": "",
      "gw_base_tax_amount_invoiced": "",
      "gw_base_tax_amount_refunded": "",
      "gw_card_base_price": "",
      "gw_card_base_price_incl_tax": "",
      "gw_card_base_price_invoiced": "",
      "gw_card_base_price_refunded": "",
      "gw_card_base_tax_amount": "",
      "gw_card_base_tax_invoiced": "",
      "gw_card_base_tax_refunded": "",
      "gw_card_price": "",
      "gw_card_price_incl_tax": "",
      "gw_card_price_invoiced": "",
      "gw_card_price_refunded": "",
      "gw_card_tax_amount": "",
      "gw_card_tax_invoiced": "",
      "gw_card_tax_refunded": "",
      "gw_id": "",
      "gw_items_base_price": "",
      "gw_items_base_price_incl_tax": "",
      "gw_items_base_price_invoiced": "",
      "gw_items_base_price_refunded": "",
      "gw_items_base_tax_amount": "",
      "gw_items_base_tax_invoiced": "",
      "gw_items_base_tax_refunded": "",
      "gw_items_price": "",
      "gw_items_price_incl_tax": "",
      "gw_items_price_invoiced": "",
      "gw_items_price_refunded": "",
      "gw_items_tax_amount": "",
      "gw_items_tax_invoiced": "",
      "gw_items_tax_refunded": "",
      "gw_price": "",
      "gw_price_incl_tax": "",
      "gw_price_invoiced": "",
      "gw_price_refunded": "",
      "gw_tax_amount": "",
      "gw_tax_amount_invoiced": "",
      "gw_tax_amount_refunded": "",
      "item_applied_taxes": [
        {
          "applied_taxes": [
            {}
          ],
          "associated_item_id": 0,
          "extension_attributes": {},
          "item_id": 0,
          "type": ""
        }
      ],
      "payment_additional_info": [
        {
          "key": "",
          "value": ""
        }
      ],
      "reward_currency_amount": "",
      "reward_points_balance": 0,
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "additional_data": "",
              "amount_refunded": "",
              "applied_rule_ids": "",
              "base_amount_refunded": "",
              "base_cost": "",
              "base_discount_amount": "",
              "base_discount_invoiced": "",
              "base_discount_refunded": "",
              "base_discount_tax_compensation_amount": "",
              "base_discount_tax_compensation_invoiced": "",
              "base_discount_tax_compensation_refunded": "",
              "base_original_price": "",
              "base_price": "",
              "base_price_incl_tax": "",
              "base_row_invoiced": "",
              "base_row_total": "",
              "base_row_total_incl_tax": "",
              "base_tax_amount": "",
              "base_tax_before_discount": "",
              "base_tax_invoiced": "",
              "base_tax_refunded": "",
              "base_weee_tax_applied_amount": "",
              "base_weee_tax_applied_row_amnt": "",
              "base_weee_tax_disposition": "",
              "base_weee_tax_row_disposition": "",
              "created_at": "",
              "description": "",
              "discount_amount": "",
              "discount_invoiced": "",
              "discount_percent": "",
              "discount_refunded": "",
              "discount_tax_compensation_amount": "",
              "discount_tax_compensation_canceled": "",
              "discount_tax_compensation_invoiced": "",
              "discount_tax_compensation_refunded": "",
              "event_id": 0,
              "ext_order_item_id": "",
              "extension_attributes": {
                "gift_message": {},
                "gw_base_price": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_id": "",
                "gw_price": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "invoice_text_codes": [],
                "tax_codes": [],
                "vertex_tax_codes": []
              },
              "free_shipping": 0,
              "gw_base_price": "",
              "gw_base_price_invoiced": "",
              "gw_base_price_refunded": "",
              "gw_base_tax_amount": "",
              "gw_base_tax_amount_invoiced": "",
              "gw_base_tax_amount_refunded": "",
              "gw_id": 0,
              "gw_price": "",
              "gw_price_invoiced": "",
              "gw_price_refunded": "",
              "gw_tax_amount": "",
              "gw_tax_amount_invoiced": "",
              "gw_tax_amount_refunded": "",
              "is_qty_decimal": 0,
              "is_virtual": 0,
              "item_id": 0,
              "locked_do_invoice": 0,
              "locked_do_ship": 0,
              "name": "",
              "no_discount": 0,
              "order_id": 0,
              "original_price": "",
              "parent_item": "",
              "parent_item_id": 0,
              "price": "",
              "price_incl_tax": "",
              "product_id": 0,
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty_backordered": "",
              "qty_canceled": "",
              "qty_invoiced": "",
              "qty_ordered": "",
              "qty_refunded": "",
              "qty_returned": "",
              "qty_shipped": "",
              "quote_item_id": 0,
              "row_invoiced": "",
              "row_total": "",
              "row_total_incl_tax": "",
              "row_weight": "",
              "sku": "",
              "store_id": 0,
              "tax_amount": "",
              "tax_before_discount": "",
              "tax_canceled": "",
              "tax_invoiced": "",
              "tax_percent": "",
              "tax_refunded": "",
              "updated_at": "",
              "weee_tax_applied": "",
              "weee_tax_applied_amount": "",
              "weee_tax_applied_row_amount": "",
              "weee_tax_disposition": "",
              "weee_tax_row_disposition": "",
              "weight": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {
              "collection_point": {
                "city": "",
                "collection_point_id": "",
                "country": "",
                "name": "",
                "postcode": "",
                "recipient_address_id": 0,
                "region": "",
                "street": []
              },
              "ext_order_id": "",
              "shipping_experience": {
                "code": "",
                "cost": "",
                "label": ""
              }
            },
            "method": "",
            "total": {
              "base_shipping_amount": "",
              "base_shipping_canceled": "",
              "base_shipping_discount_amount": "",
              "base_shipping_discount_tax_compensation_amnt": "",
              "base_shipping_incl_tax": "",
              "base_shipping_invoiced": "",
              "base_shipping_refunded": "",
              "base_shipping_tax_amount": "",
              "base_shipping_tax_refunded": "",
              "extension_attributes": {},
              "shipping_amount": "",
              "shipping_canceled": "",
              "shipping_discount_amount": "",
              "shipping_discount_tax_compensation_amount": "",
              "shipping_incl_tax": "",
              "shipping_invoiced": "",
              "shipping_refunded": "",
              "shipping_tax_amount": "",
              "shipping_tax_refunded": ""
            }
          },
          "stock_id": 0
        }
      ]
    },
    "forced_shipment_with_invoice": 0,
    "global_currency_code": "",
    "grand_total": "",
    "hold_before_state": "",
    "hold_before_status": "",
    "increment_id": "",
    "is_virtual": 0,
    "items": [
      {}
    ],
    "order_currency_code": "",
    "original_increment_id": "",
    "payment": {
      "account_status": "",
      "additional_data": "",
      "additional_information": [],
      "address_status": "",
      "amount_authorized": "",
      "amount_canceled": "",
      "amount_ordered": "",
      "amount_paid": "",
      "amount_refunded": "",
      "anet_trans_method": "",
      "base_amount_authorized": "",
      "base_amount_canceled": "",
      "base_amount_ordered": "",
      "base_amount_paid": "",
      "base_amount_paid_online": "",
      "base_amount_refunded": "",
      "base_amount_refunded_online": "",
      "base_shipping_amount": "",
      "base_shipping_captured": "",
      "base_shipping_refunded": "",
      "cc_approval": "",
      "cc_avs_status": "",
      "cc_cid_status": "",
      "cc_debug_request_body": "",
      "cc_debug_response_body": "",
      "cc_debug_response_serialized": "",
      "cc_exp_month": "",
      "cc_exp_year": "",
      "cc_last4": "",
      "cc_number_enc": "",
      "cc_owner": "",
      "cc_secure_verify": "",
      "cc_ss_issue": "",
      "cc_ss_start_month": "",
      "cc_ss_start_year": "",
      "cc_status": "",
      "cc_status_description": "",
      "cc_trans_id": "",
      "cc_type": "",
      "echeck_account_name": "",
      "echeck_account_type": "",
      "echeck_bank_name": "",
      "echeck_routing_number": "",
      "echeck_type": "",
      "entity_id": 0,
      "extension_attributes": {
        "vault_payment_token": {
          "created_at": "",
          "customer_id": 0,
          "entity_id": 0,
          "expires_at": "",
          "gateway_token": "",
          "is_active": false,
          "is_visible": false,
          "payment_method_code": "",
          "public_hash": "",
          "token_details": "",
          "type": ""
        }
      },
      "last_trans_id": "",
      "method": "",
      "parent_id": 0,
      "po_number": "",
      "protection_eligibility": "",
      "quote_payment_id": 0,
      "shipping_amount": "",
      "shipping_captured": "",
      "shipping_refunded": ""
    },
    "payment_auth_expiration": 0,
    "payment_authorization_amount": "",
    "protect_code": "",
    "quote_address_id": 0,
    "quote_id": 0,
    "relation_child_id": "",
    "relation_child_real_id": "",
    "relation_parent_id": "",
    "relation_parent_real_id": "",
    "remote_ip": "",
    "shipping_amount": "",
    "shipping_canceled": "",
    "shipping_description": "",
    "shipping_discount_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_invoiced": "",
    "shipping_refunded": "",
    "shipping_tax_amount": "",
    "shipping_tax_refunded": "",
    "state": "",
    "status": "",
    "status_histories": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "entity_name": "",
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0,
        "status": ""
      }
    ],
    "store_currency_code": "",
    "store_id": 0,
    "store_name": "",
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_canceled": "",
    "subtotal_incl_tax": "",
    "subtotal_invoiced": "",
    "subtotal_refunded": "",
    "tax_amount": "",
    "tax_canceled": "",
    "tax_invoiced": "",
    "tax_refunded": "",
    "total_canceled": "",
    "total_due": "",
    "total_invoiced": "",
    "total_item_count": 0,
    "total_offline_refunded": "",
    "total_online_refunded": "",
    "total_paid": "",
    "total_qty_ordered": "",
    "total_refunded": "",
    "updated_at": "",
    "weight": "",
    "x_forwarded_for": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/orders/create", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/orders/create"

payload = { "entity": {
        "adjustment_negative": "",
        "adjustment_positive": "",
        "applied_rule_ids": "",
        "base_adjustment_negative": "",
        "base_adjustment_positive": "",
        "base_currency_code": "",
        "base_discount_amount": "",
        "base_discount_canceled": "",
        "base_discount_invoiced": "",
        "base_discount_refunded": "",
        "base_discount_tax_compensation_amount": "",
        "base_discount_tax_compensation_invoiced": "",
        "base_discount_tax_compensation_refunded": "",
        "base_grand_total": "",
        "base_shipping_amount": "",
        "base_shipping_canceled": "",
        "base_shipping_discount_amount": "",
        "base_shipping_discount_tax_compensation_amnt": "",
        "base_shipping_incl_tax": "",
        "base_shipping_invoiced": "",
        "base_shipping_refunded": "",
        "base_shipping_tax_amount": "",
        "base_shipping_tax_refunded": "",
        "base_subtotal": "",
        "base_subtotal_canceled": "",
        "base_subtotal_incl_tax": "",
        "base_subtotal_invoiced": "",
        "base_subtotal_refunded": "",
        "base_tax_amount": "",
        "base_tax_canceled": "",
        "base_tax_invoiced": "",
        "base_tax_refunded": "",
        "base_to_global_rate": "",
        "base_to_order_rate": "",
        "base_total_canceled": "",
        "base_total_due": "",
        "base_total_invoiced": "",
        "base_total_invoiced_cost": "",
        "base_total_offline_refunded": "",
        "base_total_online_refunded": "",
        "base_total_paid": "",
        "base_total_qty_ordered": "",
        "base_total_refunded": "",
        "billing_address": {
            "address_type": "",
            "city": "",
            "company": "",
            "country_id": "",
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "entity_id": 0,
            "extension_attributes": { "checkout_fields": [
                    {
                        "attribute_code": "",
                        "value": ""
                    }
                ] },
            "fax": "",
            "firstname": "",
            "lastname": "",
            "middlename": "",
            "parent_id": 0,
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "street": [],
            "suffix": "",
            "telephone": "",
            "vat_id": "",
            "vat_is_valid": 0,
            "vat_request_date": "",
            "vat_request_id": "",
            "vat_request_success": 0
        },
        "billing_address_id": 0,
        "can_ship_partially": 0,
        "can_ship_partially_item": 0,
        "coupon_code": "",
        "created_at": "",
        "customer_dob": "",
        "customer_email": "",
        "customer_firstname": "",
        "customer_gender": 0,
        "customer_group_id": 0,
        "customer_id": 0,
        "customer_is_guest": 0,
        "customer_lastname": "",
        "customer_middlename": "",
        "customer_note": "",
        "customer_note_notify": 0,
        "customer_prefix": "",
        "customer_suffix": "",
        "customer_taxvat": "",
        "discount_amount": "",
        "discount_canceled": "",
        "discount_description": "",
        "discount_invoiced": "",
        "discount_refunded": "",
        "discount_tax_compensation_amount": "",
        "discount_tax_compensation_invoiced": "",
        "discount_tax_compensation_refunded": "",
        "edit_increment": 0,
        "email_sent": 0,
        "entity_id": 0,
        "ext_customer_id": "",
        "ext_order_id": "",
        "extension_attributes": {
            "amazon_order_reference_id": "",
            "applied_taxes": [
                {
                    "amount": "",
                    "base_amount": "",
                    "code": "",
                    "extension_attributes": { "rates": [
                            {
                                "code": "",
                                "extension_attributes": {},
                                "percent": "",
                                "title": ""
                            }
                        ] },
                    "percent": "",
                    "title": ""
                }
            ],
            "base_customer_balance_amount": "",
            "base_customer_balance_invoiced": "",
            "base_customer_balance_refunded": "",
            "base_customer_balance_total_refunded": "",
            "base_gift_cards_amount": "",
            "base_gift_cards_invoiced": "",
            "base_gift_cards_refunded": "",
            "base_reward_currency_amount": "",
            "company_order_attributes": {
                "company_id": 0,
                "company_name": "",
                "extension_attributes": {},
                "order_id": 0
            },
            "converting_from_quote": False,
            "customer_balance_amount": "",
            "customer_balance_invoiced": "",
            "customer_balance_refunded": "",
            "customer_balance_total_refunded": "",
            "gift_cards": [
                {
                    "amount": "",
                    "base_amount": "",
                    "code": "",
                    "id": 0
                }
            ],
            "gift_cards_amount": "",
            "gift_cards_invoiced": "",
            "gift_cards_refunded": "",
            "gift_message": {
                "customer_id": 0,
                "extension_attributes": {
                    "entity_id": "",
                    "entity_type": "",
                    "wrapping_add_printed_card": False,
                    "wrapping_allow_gift_receipt": False,
                    "wrapping_id": 0
                },
                "gift_message_id": 0,
                "message": "",
                "recipient": "",
                "sender": ""
            },
            "gw_add_card": "",
            "gw_allow_gift_receipt": "",
            "gw_base_price": "",
            "gw_base_price_incl_tax": "",
            "gw_base_price_invoiced": "",
            "gw_base_price_refunded": "",
            "gw_base_tax_amount": "",
            "gw_base_tax_amount_invoiced": "",
            "gw_base_tax_amount_refunded": "",
            "gw_card_base_price": "",
            "gw_card_base_price_incl_tax": "",
            "gw_card_base_price_invoiced": "",
            "gw_card_base_price_refunded": "",
            "gw_card_base_tax_amount": "",
            "gw_card_base_tax_invoiced": "",
            "gw_card_base_tax_refunded": "",
            "gw_card_price": "",
            "gw_card_price_incl_tax": "",
            "gw_card_price_invoiced": "",
            "gw_card_price_refunded": "",
            "gw_card_tax_amount": "",
            "gw_card_tax_invoiced": "",
            "gw_card_tax_refunded": "",
            "gw_id": "",
            "gw_items_base_price": "",
            "gw_items_base_price_incl_tax": "",
            "gw_items_base_price_invoiced": "",
            "gw_items_base_price_refunded": "",
            "gw_items_base_tax_amount": "",
            "gw_items_base_tax_invoiced": "",
            "gw_items_base_tax_refunded": "",
            "gw_items_price": "",
            "gw_items_price_incl_tax": "",
            "gw_items_price_invoiced": "",
            "gw_items_price_refunded": "",
            "gw_items_tax_amount": "",
            "gw_items_tax_invoiced": "",
            "gw_items_tax_refunded": "",
            "gw_price": "",
            "gw_price_incl_tax": "",
            "gw_price_invoiced": "",
            "gw_price_refunded": "",
            "gw_tax_amount": "",
            "gw_tax_amount_invoiced": "",
            "gw_tax_amount_refunded": "",
            "item_applied_taxes": [
                {
                    "applied_taxes": [{}],
                    "associated_item_id": 0,
                    "extension_attributes": {},
                    "item_id": 0,
                    "type": ""
                }
            ],
            "payment_additional_info": [
                {
                    "key": "",
                    "value": ""
                }
            ],
            "reward_currency_amount": "",
            "reward_points_balance": 0,
            "shipping_assignments": [
                {
                    "extension_attributes": {},
                    "items": [
                        {
                            "additional_data": "",
                            "amount_refunded": "",
                            "applied_rule_ids": "",
                            "base_amount_refunded": "",
                            "base_cost": "",
                            "base_discount_amount": "",
                            "base_discount_invoiced": "",
                            "base_discount_refunded": "",
                            "base_discount_tax_compensation_amount": "",
                            "base_discount_tax_compensation_invoiced": "",
                            "base_discount_tax_compensation_refunded": "",
                            "base_original_price": "",
                            "base_price": "",
                            "base_price_incl_tax": "",
                            "base_row_invoiced": "",
                            "base_row_total": "",
                            "base_row_total_incl_tax": "",
                            "base_tax_amount": "",
                            "base_tax_before_discount": "",
                            "base_tax_invoiced": "",
                            "base_tax_refunded": "",
                            "base_weee_tax_applied_amount": "",
                            "base_weee_tax_applied_row_amnt": "",
                            "base_weee_tax_disposition": "",
                            "base_weee_tax_row_disposition": "",
                            "created_at": "",
                            "description": "",
                            "discount_amount": "",
                            "discount_invoiced": "",
                            "discount_percent": "",
                            "discount_refunded": "",
                            "discount_tax_compensation_amount": "",
                            "discount_tax_compensation_canceled": "",
                            "discount_tax_compensation_invoiced": "",
                            "discount_tax_compensation_refunded": "",
                            "event_id": 0,
                            "ext_order_item_id": "",
                            "extension_attributes": {
                                "gift_message": {},
                                "gw_base_price": "",
                                "gw_base_price_invoiced": "",
                                "gw_base_price_refunded": "",
                                "gw_base_tax_amount": "",
                                "gw_base_tax_amount_invoiced": "",
                                "gw_base_tax_amount_refunded": "",
                                "gw_id": "",
                                "gw_price": "",
                                "gw_price_invoiced": "",
                                "gw_price_refunded": "",
                                "gw_tax_amount": "",
                                "gw_tax_amount_invoiced": "",
                                "gw_tax_amount_refunded": "",
                                "invoice_text_codes": [],
                                "tax_codes": [],
                                "vertex_tax_codes": []
                            },
                            "free_shipping": 0,
                            "gw_base_price": "",
                            "gw_base_price_invoiced": "",
                            "gw_base_price_refunded": "",
                            "gw_base_tax_amount": "",
                            "gw_base_tax_amount_invoiced": "",
                            "gw_base_tax_amount_refunded": "",
                            "gw_id": 0,
                            "gw_price": "",
                            "gw_price_invoiced": "",
                            "gw_price_refunded": "",
                            "gw_tax_amount": "",
                            "gw_tax_amount_invoiced": "",
                            "gw_tax_amount_refunded": "",
                            "is_qty_decimal": 0,
                            "is_virtual": 0,
                            "item_id": 0,
                            "locked_do_invoice": 0,
                            "locked_do_ship": 0,
                            "name": "",
                            "no_discount": 0,
                            "order_id": 0,
                            "original_price": "",
                            "parent_item": "",
                            "parent_item_id": 0,
                            "price": "",
                            "price_incl_tax": "",
                            "product_id": 0,
                            "product_option": { "extension_attributes": {
                                    "bundle_options": [
                                        {
                                            "extension_attributes": {},
                                            "option_id": 0,
                                            "option_qty": 0,
                                            "option_selections": []
                                        }
                                    ],
                                    "configurable_item_options": [
                                        {
                                            "extension_attributes": {},
                                            "option_id": "",
                                            "option_value": 0
                                        }
                                    ],
                                    "custom_options": [
                                        {
                                            "extension_attributes": { "file_info": {
                                                    "base64_encoded_data": "",
                                                    "name": "",
                                                    "type": ""
                                                } },
                                            "option_id": "",
                                            "option_value": ""
                                        }
                                    ],
                                    "downloadable_option": { "downloadable_links": [] },
                                    "giftcard_item_option": {
                                        "custom_giftcard_amount": "",
                                        "extension_attributes": {},
                                        "giftcard_amount": "",
                                        "giftcard_message": "",
                                        "giftcard_recipient_email": "",
                                        "giftcard_recipient_name": "",
                                        "giftcard_sender_email": "",
                                        "giftcard_sender_name": ""
                                    }
                                } },
                            "product_type": "",
                            "qty_backordered": "",
                            "qty_canceled": "",
                            "qty_invoiced": "",
                            "qty_ordered": "",
                            "qty_refunded": "",
                            "qty_returned": "",
                            "qty_shipped": "",
                            "quote_item_id": 0,
                            "row_invoiced": "",
                            "row_total": "",
                            "row_total_incl_tax": "",
                            "row_weight": "",
                            "sku": "",
                            "store_id": 0,
                            "tax_amount": "",
                            "tax_before_discount": "",
                            "tax_canceled": "",
                            "tax_invoiced": "",
                            "tax_percent": "",
                            "tax_refunded": "",
                            "updated_at": "",
                            "weee_tax_applied": "",
                            "weee_tax_applied_amount": "",
                            "weee_tax_applied_row_amount": "",
                            "weee_tax_disposition": "",
                            "weee_tax_row_disposition": "",
                            "weight": ""
                        }
                    ],
                    "shipping": {
                        "address": {},
                        "extension_attributes": {
                            "collection_point": {
                                "city": "",
                                "collection_point_id": "",
                                "country": "",
                                "name": "",
                                "postcode": "",
                                "recipient_address_id": 0,
                                "region": "",
                                "street": []
                            },
                            "ext_order_id": "",
                            "shipping_experience": {
                                "code": "",
                                "cost": "",
                                "label": ""
                            }
                        },
                        "method": "",
                        "total": {
                            "base_shipping_amount": "",
                            "base_shipping_canceled": "",
                            "base_shipping_discount_amount": "",
                            "base_shipping_discount_tax_compensation_amnt": "",
                            "base_shipping_incl_tax": "",
                            "base_shipping_invoiced": "",
                            "base_shipping_refunded": "",
                            "base_shipping_tax_amount": "",
                            "base_shipping_tax_refunded": "",
                            "extension_attributes": {},
                            "shipping_amount": "",
                            "shipping_canceled": "",
                            "shipping_discount_amount": "",
                            "shipping_discount_tax_compensation_amount": "",
                            "shipping_incl_tax": "",
                            "shipping_invoiced": "",
                            "shipping_refunded": "",
                            "shipping_tax_amount": "",
                            "shipping_tax_refunded": ""
                        }
                    },
                    "stock_id": 0
                }
            ]
        },
        "forced_shipment_with_invoice": 0,
        "global_currency_code": "",
        "grand_total": "",
        "hold_before_state": "",
        "hold_before_status": "",
        "increment_id": "",
        "is_virtual": 0,
        "items": [{}],
        "order_currency_code": "",
        "original_increment_id": "",
        "payment": {
            "account_status": "",
            "additional_data": "",
            "additional_information": [],
            "address_status": "",
            "amount_authorized": "",
            "amount_canceled": "",
            "amount_ordered": "",
            "amount_paid": "",
            "amount_refunded": "",
            "anet_trans_method": "",
            "base_amount_authorized": "",
            "base_amount_canceled": "",
            "base_amount_ordered": "",
            "base_amount_paid": "",
            "base_amount_paid_online": "",
            "base_amount_refunded": "",
            "base_amount_refunded_online": "",
            "base_shipping_amount": "",
            "base_shipping_captured": "",
            "base_shipping_refunded": "",
            "cc_approval": "",
            "cc_avs_status": "",
            "cc_cid_status": "",
            "cc_debug_request_body": "",
            "cc_debug_response_body": "",
            "cc_debug_response_serialized": "",
            "cc_exp_month": "",
            "cc_exp_year": "",
            "cc_last4": "",
            "cc_number_enc": "",
            "cc_owner": "",
            "cc_secure_verify": "",
            "cc_ss_issue": "",
            "cc_ss_start_month": "",
            "cc_ss_start_year": "",
            "cc_status": "",
            "cc_status_description": "",
            "cc_trans_id": "",
            "cc_type": "",
            "echeck_account_name": "",
            "echeck_account_type": "",
            "echeck_bank_name": "",
            "echeck_routing_number": "",
            "echeck_type": "",
            "entity_id": 0,
            "extension_attributes": { "vault_payment_token": {
                    "created_at": "",
                    "customer_id": 0,
                    "entity_id": 0,
                    "expires_at": "",
                    "gateway_token": "",
                    "is_active": False,
                    "is_visible": False,
                    "payment_method_code": "",
                    "public_hash": "",
                    "token_details": "",
                    "type": ""
                } },
            "last_trans_id": "",
            "method": "",
            "parent_id": 0,
            "po_number": "",
            "protection_eligibility": "",
            "quote_payment_id": 0,
            "shipping_amount": "",
            "shipping_captured": "",
            "shipping_refunded": ""
        },
        "payment_auth_expiration": 0,
        "payment_authorization_amount": "",
        "protect_code": "",
        "quote_address_id": 0,
        "quote_id": 0,
        "relation_child_id": "",
        "relation_child_real_id": "",
        "relation_parent_id": "",
        "relation_parent_real_id": "",
        "remote_ip": "",
        "shipping_amount": "",
        "shipping_canceled": "",
        "shipping_description": "",
        "shipping_discount_amount": "",
        "shipping_discount_tax_compensation_amount": "",
        "shipping_incl_tax": "",
        "shipping_invoiced": "",
        "shipping_refunded": "",
        "shipping_tax_amount": "",
        "shipping_tax_refunded": "",
        "state": "",
        "status": "",
        "status_histories": [
            {
                "comment": "",
                "created_at": "",
                "entity_id": 0,
                "entity_name": "",
                "extension_attributes": {},
                "is_customer_notified": 0,
                "is_visible_on_front": 0,
                "parent_id": 0,
                "status": ""
            }
        ],
        "store_currency_code": "",
        "store_id": 0,
        "store_name": "",
        "store_to_base_rate": "",
        "store_to_order_rate": "",
        "subtotal": "",
        "subtotal_canceled": "",
        "subtotal_incl_tax": "",
        "subtotal_invoiced": "",
        "subtotal_refunded": "",
        "tax_amount": "",
        "tax_canceled": "",
        "tax_invoiced": "",
        "tax_refunded": "",
        "total_canceled": "",
        "total_due": "",
        "total_invoiced": "",
        "total_item_count": 0,
        "total_offline_refunded": "",
        "total_online_refunded": "",
        "total_paid": "",
        "total_qty_ordered": "",
        "total_refunded": "",
        "updated_at": "",
        "weight": "",
        "x_forwarded_for": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/orders/create"

payload <- "{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/orders/create")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\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/V1/orders/create') do |req|
  req.body = "{\n  \"entity\": {\n    \"adjustment_negative\": \"\",\n    \"adjustment_positive\": \"\",\n    \"applied_rule_ids\": \"\",\n    \"base_adjustment_negative\": \"\",\n    \"base_adjustment_positive\": \"\",\n    \"base_currency_code\": \"\",\n    \"base_discount_amount\": \"\",\n    \"base_discount_canceled\": \"\",\n    \"base_discount_invoiced\": \"\",\n    \"base_discount_refunded\": \"\",\n    \"base_discount_tax_compensation_amount\": \"\",\n    \"base_discount_tax_compensation_invoiced\": \"\",\n    \"base_discount_tax_compensation_refunded\": \"\",\n    \"base_grand_total\": \"\",\n    \"base_shipping_amount\": \"\",\n    \"base_shipping_canceled\": \"\",\n    \"base_shipping_discount_amount\": \"\",\n    \"base_shipping_discount_tax_compensation_amnt\": \"\",\n    \"base_shipping_incl_tax\": \"\",\n    \"base_shipping_invoiced\": \"\",\n    \"base_shipping_refunded\": \"\",\n    \"base_shipping_tax_amount\": \"\",\n    \"base_shipping_tax_refunded\": \"\",\n    \"base_subtotal\": \"\",\n    \"base_subtotal_canceled\": \"\",\n    \"base_subtotal_incl_tax\": \"\",\n    \"base_subtotal_invoiced\": \"\",\n    \"base_subtotal_refunded\": \"\",\n    \"base_tax_amount\": \"\",\n    \"base_tax_canceled\": \"\",\n    \"base_tax_invoiced\": \"\",\n    \"base_tax_refunded\": \"\",\n    \"base_to_global_rate\": \"\",\n    \"base_to_order_rate\": \"\",\n    \"base_total_canceled\": \"\",\n    \"base_total_due\": \"\",\n    \"base_total_invoiced\": \"\",\n    \"base_total_invoiced_cost\": \"\",\n    \"base_total_offline_refunded\": \"\",\n    \"base_total_online_refunded\": \"\",\n    \"base_total_paid\": \"\",\n    \"base_total_qty_ordered\": \"\",\n    \"base_total_refunded\": \"\",\n    \"billing_address\": {\n      \"address_type\": \"\",\n      \"city\": \"\",\n      \"company\": \"\",\n      \"country_id\": \"\",\n      \"customer_address_id\": 0,\n      \"customer_id\": 0,\n      \"email\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"checkout_fields\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ]\n      },\n      \"fax\": \"\",\n      \"firstname\": \"\",\n      \"lastname\": \"\",\n      \"middlename\": \"\",\n      \"parent_id\": 0,\n      \"postcode\": \"\",\n      \"prefix\": \"\",\n      \"region\": \"\",\n      \"region_code\": \"\",\n      \"region_id\": 0,\n      \"street\": [],\n      \"suffix\": \"\",\n      \"telephone\": \"\",\n      \"vat_id\": \"\",\n      \"vat_is_valid\": 0,\n      \"vat_request_date\": \"\",\n      \"vat_request_id\": \"\",\n      \"vat_request_success\": 0\n    },\n    \"billing_address_id\": 0,\n    \"can_ship_partially\": 0,\n    \"can_ship_partially_item\": 0,\n    \"coupon_code\": \"\",\n    \"created_at\": \"\",\n    \"customer_dob\": \"\",\n    \"customer_email\": \"\",\n    \"customer_firstname\": \"\",\n    \"customer_gender\": 0,\n    \"customer_group_id\": 0,\n    \"customer_id\": 0,\n    \"customer_is_guest\": 0,\n    \"customer_lastname\": \"\",\n    \"customer_middlename\": \"\",\n    \"customer_note\": \"\",\n    \"customer_note_notify\": 0,\n    \"customer_prefix\": \"\",\n    \"customer_suffix\": \"\",\n    \"customer_taxvat\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_canceled\": \"\",\n    \"discount_description\": \"\",\n    \"discount_invoiced\": \"\",\n    \"discount_refunded\": \"\",\n    \"discount_tax_compensation_amount\": \"\",\n    \"discount_tax_compensation_invoiced\": \"\",\n    \"discount_tax_compensation_refunded\": \"\",\n    \"edit_increment\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"ext_customer_id\": \"\",\n    \"ext_order_id\": \"\",\n    \"extension_attributes\": {\n      \"amazon_order_reference_id\": \"\",\n      \"applied_taxes\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"extension_attributes\": {\n            \"rates\": [\n              {\n                \"code\": \"\",\n                \"extension_attributes\": {},\n                \"percent\": \"\",\n                \"title\": \"\"\n              }\n            ]\n          },\n          \"percent\": \"\",\n          \"title\": \"\"\n        }\n      ],\n      \"base_customer_balance_amount\": \"\",\n      \"base_customer_balance_invoiced\": \"\",\n      \"base_customer_balance_refunded\": \"\",\n      \"base_customer_balance_total_refunded\": \"\",\n      \"base_gift_cards_amount\": \"\",\n      \"base_gift_cards_invoiced\": \"\",\n      \"base_gift_cards_refunded\": \"\",\n      \"base_reward_currency_amount\": \"\",\n      \"company_order_attributes\": {\n        \"company_id\": 0,\n        \"company_name\": \"\",\n        \"extension_attributes\": {},\n        \"order_id\": 0\n      },\n      \"converting_from_quote\": false,\n      \"customer_balance_amount\": \"\",\n      \"customer_balance_invoiced\": \"\",\n      \"customer_balance_refunded\": \"\",\n      \"customer_balance_total_refunded\": \"\",\n      \"gift_cards\": [\n        {\n          \"amount\": \"\",\n          \"base_amount\": \"\",\n          \"code\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"gift_cards_amount\": \"\",\n      \"gift_cards_invoiced\": \"\",\n      \"gift_cards_refunded\": \"\",\n      \"gift_message\": {\n        \"customer_id\": 0,\n        \"extension_attributes\": {\n          \"entity_id\": \"\",\n          \"entity_type\": \"\",\n          \"wrapping_add_printed_card\": false,\n          \"wrapping_allow_gift_receipt\": false,\n          \"wrapping_id\": 0\n        },\n        \"gift_message_id\": 0,\n        \"message\": \"\",\n        \"recipient\": \"\",\n        \"sender\": \"\"\n      },\n      \"gw_add_card\": \"\",\n      \"gw_allow_gift_receipt\": \"\",\n      \"gw_base_price\": \"\",\n      \"gw_base_price_incl_tax\": \"\",\n      \"gw_base_price_invoiced\": \"\",\n      \"gw_base_price_refunded\": \"\",\n      \"gw_base_tax_amount\": \"\",\n      \"gw_base_tax_amount_invoiced\": \"\",\n      \"gw_base_tax_amount_refunded\": \"\",\n      \"gw_card_base_price\": \"\",\n      \"gw_card_base_price_incl_tax\": \"\",\n      \"gw_card_base_price_invoiced\": \"\",\n      \"gw_card_base_price_refunded\": \"\",\n      \"gw_card_base_tax_amount\": \"\",\n      \"gw_card_base_tax_invoiced\": \"\",\n      \"gw_card_base_tax_refunded\": \"\",\n      \"gw_card_price\": \"\",\n      \"gw_card_price_incl_tax\": \"\",\n      \"gw_card_price_invoiced\": \"\",\n      \"gw_card_price_refunded\": \"\",\n      \"gw_card_tax_amount\": \"\",\n      \"gw_card_tax_invoiced\": \"\",\n      \"gw_card_tax_refunded\": \"\",\n      \"gw_id\": \"\",\n      \"gw_items_base_price\": \"\",\n      \"gw_items_base_price_incl_tax\": \"\",\n      \"gw_items_base_price_invoiced\": \"\",\n      \"gw_items_base_price_refunded\": \"\",\n      \"gw_items_base_tax_amount\": \"\",\n      \"gw_items_base_tax_invoiced\": \"\",\n      \"gw_items_base_tax_refunded\": \"\",\n      \"gw_items_price\": \"\",\n      \"gw_items_price_incl_tax\": \"\",\n      \"gw_items_price_invoiced\": \"\",\n      \"gw_items_price_refunded\": \"\",\n      \"gw_items_tax_amount\": \"\",\n      \"gw_items_tax_invoiced\": \"\",\n      \"gw_items_tax_refunded\": \"\",\n      \"gw_price\": \"\",\n      \"gw_price_incl_tax\": \"\",\n      \"gw_price_invoiced\": \"\",\n      \"gw_price_refunded\": \"\",\n      \"gw_tax_amount\": \"\",\n      \"gw_tax_amount_invoiced\": \"\",\n      \"gw_tax_amount_refunded\": \"\",\n      \"item_applied_taxes\": [\n        {\n          \"applied_taxes\": [\n            {}\n          ],\n          \"associated_item_id\": 0,\n          \"extension_attributes\": {},\n          \"item_id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"payment_additional_info\": [\n        {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"reward_currency_amount\": \"\",\n      \"reward_points_balance\": 0,\n      \"shipping_assignments\": [\n        {\n          \"extension_attributes\": {},\n          \"items\": [\n            {\n              \"additional_data\": \"\",\n              \"amount_refunded\": \"\",\n              \"applied_rule_ids\": \"\",\n              \"base_amount_refunded\": \"\",\n              \"base_cost\": \"\",\n              \"base_discount_amount\": \"\",\n              \"base_discount_invoiced\": \"\",\n              \"base_discount_refunded\": \"\",\n              \"base_discount_tax_compensation_amount\": \"\",\n              \"base_discount_tax_compensation_invoiced\": \"\",\n              \"base_discount_tax_compensation_refunded\": \"\",\n              \"base_original_price\": \"\",\n              \"base_price\": \"\",\n              \"base_price_incl_tax\": \"\",\n              \"base_row_invoiced\": \"\",\n              \"base_row_total\": \"\",\n              \"base_row_total_incl_tax\": \"\",\n              \"base_tax_amount\": \"\",\n              \"base_tax_before_discount\": \"\",\n              \"base_tax_invoiced\": \"\",\n              \"base_tax_refunded\": \"\",\n              \"base_weee_tax_applied_amount\": \"\",\n              \"base_weee_tax_applied_row_amnt\": \"\",\n              \"base_weee_tax_disposition\": \"\",\n              \"base_weee_tax_row_disposition\": \"\",\n              \"created_at\": \"\",\n              \"description\": \"\",\n              \"discount_amount\": \"\",\n              \"discount_invoiced\": \"\",\n              \"discount_percent\": \"\",\n              \"discount_refunded\": \"\",\n              \"discount_tax_compensation_amount\": \"\",\n              \"discount_tax_compensation_canceled\": \"\",\n              \"discount_tax_compensation_invoiced\": \"\",\n              \"discount_tax_compensation_refunded\": \"\",\n              \"event_id\": 0,\n              \"ext_order_item_id\": \"\",\n              \"extension_attributes\": {\n                \"gift_message\": {},\n                \"gw_base_price\": \"\",\n                \"gw_base_price_invoiced\": \"\",\n                \"gw_base_price_refunded\": \"\",\n                \"gw_base_tax_amount\": \"\",\n                \"gw_base_tax_amount_invoiced\": \"\",\n                \"gw_base_tax_amount_refunded\": \"\",\n                \"gw_id\": \"\",\n                \"gw_price\": \"\",\n                \"gw_price_invoiced\": \"\",\n                \"gw_price_refunded\": \"\",\n                \"gw_tax_amount\": \"\",\n                \"gw_tax_amount_invoiced\": \"\",\n                \"gw_tax_amount_refunded\": \"\",\n                \"invoice_text_codes\": [],\n                \"tax_codes\": [],\n                \"vertex_tax_codes\": []\n              },\n              \"free_shipping\": 0,\n              \"gw_base_price\": \"\",\n              \"gw_base_price_invoiced\": \"\",\n              \"gw_base_price_refunded\": \"\",\n              \"gw_base_tax_amount\": \"\",\n              \"gw_base_tax_amount_invoiced\": \"\",\n              \"gw_base_tax_amount_refunded\": \"\",\n              \"gw_id\": 0,\n              \"gw_price\": \"\",\n              \"gw_price_invoiced\": \"\",\n              \"gw_price_refunded\": \"\",\n              \"gw_tax_amount\": \"\",\n              \"gw_tax_amount_invoiced\": \"\",\n              \"gw_tax_amount_refunded\": \"\",\n              \"is_qty_decimal\": 0,\n              \"is_virtual\": 0,\n              \"item_id\": 0,\n              \"locked_do_invoice\": 0,\n              \"locked_do_ship\": 0,\n              \"name\": \"\",\n              \"no_discount\": 0,\n              \"order_id\": 0,\n              \"original_price\": \"\",\n              \"parent_item\": \"\",\n              \"parent_item_id\": 0,\n              \"price\": \"\",\n              \"price_incl_tax\": \"\",\n              \"product_id\": 0,\n              \"product_option\": {\n                \"extension_attributes\": {\n                  \"bundle_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": 0,\n                      \"option_qty\": 0,\n                      \"option_selections\": []\n                    }\n                  ],\n                  \"configurable_item_options\": [\n                    {\n                      \"extension_attributes\": {},\n                      \"option_id\": \"\",\n                      \"option_value\": 0\n                    }\n                  ],\n                  \"custom_options\": [\n                    {\n                      \"extension_attributes\": {\n                        \"file_info\": {\n                          \"base64_encoded_data\": \"\",\n                          \"name\": \"\",\n                          \"type\": \"\"\n                        }\n                      },\n                      \"option_id\": \"\",\n                      \"option_value\": \"\"\n                    }\n                  ],\n                  \"downloadable_option\": {\n                    \"downloadable_links\": []\n                  },\n                  \"giftcard_item_option\": {\n                    \"custom_giftcard_amount\": \"\",\n                    \"extension_attributes\": {},\n                    \"giftcard_amount\": \"\",\n                    \"giftcard_message\": \"\",\n                    \"giftcard_recipient_email\": \"\",\n                    \"giftcard_recipient_name\": \"\",\n                    \"giftcard_sender_email\": \"\",\n                    \"giftcard_sender_name\": \"\"\n                  }\n                }\n              },\n              \"product_type\": \"\",\n              \"qty_backordered\": \"\",\n              \"qty_canceled\": \"\",\n              \"qty_invoiced\": \"\",\n              \"qty_ordered\": \"\",\n              \"qty_refunded\": \"\",\n              \"qty_returned\": \"\",\n              \"qty_shipped\": \"\",\n              \"quote_item_id\": 0,\n              \"row_invoiced\": \"\",\n              \"row_total\": \"\",\n              \"row_total_incl_tax\": \"\",\n              \"row_weight\": \"\",\n              \"sku\": \"\",\n              \"store_id\": 0,\n              \"tax_amount\": \"\",\n              \"tax_before_discount\": \"\",\n              \"tax_canceled\": \"\",\n              \"tax_invoiced\": \"\",\n              \"tax_percent\": \"\",\n              \"tax_refunded\": \"\",\n              \"updated_at\": \"\",\n              \"weee_tax_applied\": \"\",\n              \"weee_tax_applied_amount\": \"\",\n              \"weee_tax_applied_row_amount\": \"\",\n              \"weee_tax_disposition\": \"\",\n              \"weee_tax_row_disposition\": \"\",\n              \"weight\": \"\"\n            }\n          ],\n          \"shipping\": {\n            \"address\": {},\n            \"extension_attributes\": {\n              \"collection_point\": {\n                \"city\": \"\",\n                \"collection_point_id\": \"\",\n                \"country\": \"\",\n                \"name\": \"\",\n                \"postcode\": \"\",\n                \"recipient_address_id\": 0,\n                \"region\": \"\",\n                \"street\": []\n              },\n              \"ext_order_id\": \"\",\n              \"shipping_experience\": {\n                \"code\": \"\",\n                \"cost\": \"\",\n                \"label\": \"\"\n              }\n            },\n            \"method\": \"\",\n            \"total\": {\n              \"base_shipping_amount\": \"\",\n              \"base_shipping_canceled\": \"\",\n              \"base_shipping_discount_amount\": \"\",\n              \"base_shipping_discount_tax_compensation_amnt\": \"\",\n              \"base_shipping_incl_tax\": \"\",\n              \"base_shipping_invoiced\": \"\",\n              \"base_shipping_refunded\": \"\",\n              \"base_shipping_tax_amount\": \"\",\n              \"base_shipping_tax_refunded\": \"\",\n              \"extension_attributes\": {},\n              \"shipping_amount\": \"\",\n              \"shipping_canceled\": \"\",\n              \"shipping_discount_amount\": \"\",\n              \"shipping_discount_tax_compensation_amount\": \"\",\n              \"shipping_incl_tax\": \"\",\n              \"shipping_invoiced\": \"\",\n              \"shipping_refunded\": \"\",\n              \"shipping_tax_amount\": \"\",\n              \"shipping_tax_refunded\": \"\"\n            }\n          },\n          \"stock_id\": 0\n        }\n      ]\n    },\n    \"forced_shipment_with_invoice\": 0,\n    \"global_currency_code\": \"\",\n    \"grand_total\": \"\",\n    \"hold_before_state\": \"\",\n    \"hold_before_status\": \"\",\n    \"increment_id\": \"\",\n    \"is_virtual\": 0,\n    \"items\": [\n      {}\n    ],\n    \"order_currency_code\": \"\",\n    \"original_increment_id\": \"\",\n    \"payment\": {\n      \"account_status\": \"\",\n      \"additional_data\": \"\",\n      \"additional_information\": [],\n      \"address_status\": \"\",\n      \"amount_authorized\": \"\",\n      \"amount_canceled\": \"\",\n      \"amount_ordered\": \"\",\n      \"amount_paid\": \"\",\n      \"amount_refunded\": \"\",\n      \"anet_trans_method\": \"\",\n      \"base_amount_authorized\": \"\",\n      \"base_amount_canceled\": \"\",\n      \"base_amount_ordered\": \"\",\n      \"base_amount_paid\": \"\",\n      \"base_amount_paid_online\": \"\",\n      \"base_amount_refunded\": \"\",\n      \"base_amount_refunded_online\": \"\",\n      \"base_shipping_amount\": \"\",\n      \"base_shipping_captured\": \"\",\n      \"base_shipping_refunded\": \"\",\n      \"cc_approval\": \"\",\n      \"cc_avs_status\": \"\",\n      \"cc_cid_status\": \"\",\n      \"cc_debug_request_body\": \"\",\n      \"cc_debug_response_body\": \"\",\n      \"cc_debug_response_serialized\": \"\",\n      \"cc_exp_month\": \"\",\n      \"cc_exp_year\": \"\",\n      \"cc_last4\": \"\",\n      \"cc_number_enc\": \"\",\n      \"cc_owner\": \"\",\n      \"cc_secure_verify\": \"\",\n      \"cc_ss_issue\": \"\",\n      \"cc_ss_start_month\": \"\",\n      \"cc_ss_start_year\": \"\",\n      \"cc_status\": \"\",\n      \"cc_status_description\": \"\",\n      \"cc_trans_id\": \"\",\n      \"cc_type\": \"\",\n      \"echeck_account_name\": \"\",\n      \"echeck_account_type\": \"\",\n      \"echeck_bank_name\": \"\",\n      \"echeck_routing_number\": \"\",\n      \"echeck_type\": \"\",\n      \"entity_id\": 0,\n      \"extension_attributes\": {\n        \"vault_payment_token\": {\n          \"created_at\": \"\",\n          \"customer_id\": 0,\n          \"entity_id\": 0,\n          \"expires_at\": \"\",\n          \"gateway_token\": \"\",\n          \"is_active\": false,\n          \"is_visible\": false,\n          \"payment_method_code\": \"\",\n          \"public_hash\": \"\",\n          \"token_details\": \"\",\n          \"type\": \"\"\n        }\n      },\n      \"last_trans_id\": \"\",\n      \"method\": \"\",\n      \"parent_id\": 0,\n      \"po_number\": \"\",\n      \"protection_eligibility\": \"\",\n      \"quote_payment_id\": 0,\n      \"shipping_amount\": \"\",\n      \"shipping_captured\": \"\",\n      \"shipping_refunded\": \"\"\n    },\n    \"payment_auth_expiration\": 0,\n    \"payment_authorization_amount\": \"\",\n    \"protect_code\": \"\",\n    \"quote_address_id\": 0,\n    \"quote_id\": 0,\n    \"relation_child_id\": \"\",\n    \"relation_child_real_id\": \"\",\n    \"relation_parent_id\": \"\",\n    \"relation_parent_real_id\": \"\",\n    \"remote_ip\": \"\",\n    \"shipping_amount\": \"\",\n    \"shipping_canceled\": \"\",\n    \"shipping_description\": \"\",\n    \"shipping_discount_amount\": \"\",\n    \"shipping_discount_tax_compensation_amount\": \"\",\n    \"shipping_incl_tax\": \"\",\n    \"shipping_invoiced\": \"\",\n    \"shipping_refunded\": \"\",\n    \"shipping_tax_amount\": \"\",\n    \"shipping_tax_refunded\": \"\",\n    \"state\": \"\",\n    \"status\": \"\",\n    \"status_histories\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"entity_name\": \"\",\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"store_currency_code\": \"\",\n    \"store_id\": 0,\n    \"store_name\": \"\",\n    \"store_to_base_rate\": \"\",\n    \"store_to_order_rate\": \"\",\n    \"subtotal\": \"\",\n    \"subtotal_canceled\": \"\",\n    \"subtotal_incl_tax\": \"\",\n    \"subtotal_invoiced\": \"\",\n    \"subtotal_refunded\": \"\",\n    \"tax_amount\": \"\",\n    \"tax_canceled\": \"\",\n    \"tax_invoiced\": \"\",\n    \"tax_refunded\": \"\",\n    \"total_canceled\": \"\",\n    \"total_due\": \"\",\n    \"total_invoiced\": \"\",\n    \"total_item_count\": 0,\n    \"total_offline_refunded\": \"\",\n    \"total_online_refunded\": \"\",\n    \"total_paid\": \"\",\n    \"total_qty_ordered\": \"\",\n    \"total_refunded\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\",\n    \"x_forwarded_for\": \"\"\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}}/V1/orders/create";

    let payload = json!({"entity": json!({
            "adjustment_negative": "",
            "adjustment_positive": "",
            "applied_rule_ids": "",
            "base_adjustment_negative": "",
            "base_adjustment_positive": "",
            "base_currency_code": "",
            "base_discount_amount": "",
            "base_discount_canceled": "",
            "base_discount_invoiced": "",
            "base_discount_refunded": "",
            "base_discount_tax_compensation_amount": "",
            "base_discount_tax_compensation_invoiced": "",
            "base_discount_tax_compensation_refunded": "",
            "base_grand_total": "",
            "base_shipping_amount": "",
            "base_shipping_canceled": "",
            "base_shipping_discount_amount": "",
            "base_shipping_discount_tax_compensation_amnt": "",
            "base_shipping_incl_tax": "",
            "base_shipping_invoiced": "",
            "base_shipping_refunded": "",
            "base_shipping_tax_amount": "",
            "base_shipping_tax_refunded": "",
            "base_subtotal": "",
            "base_subtotal_canceled": "",
            "base_subtotal_incl_tax": "",
            "base_subtotal_invoiced": "",
            "base_subtotal_refunded": "",
            "base_tax_amount": "",
            "base_tax_canceled": "",
            "base_tax_invoiced": "",
            "base_tax_refunded": "",
            "base_to_global_rate": "",
            "base_to_order_rate": "",
            "base_total_canceled": "",
            "base_total_due": "",
            "base_total_invoiced": "",
            "base_total_invoiced_cost": "",
            "base_total_offline_refunded": "",
            "base_total_online_refunded": "",
            "base_total_paid": "",
            "base_total_qty_ordered": "",
            "base_total_refunded": "",
            "billing_address": json!({
                "address_type": "",
                "city": "",
                "company": "",
                "country_id": "",
                "customer_address_id": 0,
                "customer_id": 0,
                "email": "",
                "entity_id": 0,
                "extension_attributes": json!({"checkout_fields": (
                        json!({
                            "attribute_code": "",
                            "value": ""
                        })
                    )}),
                "fax": "",
                "firstname": "",
                "lastname": "",
                "middlename": "",
                "parent_id": 0,
                "postcode": "",
                "prefix": "",
                "region": "",
                "region_code": "",
                "region_id": 0,
                "street": (),
                "suffix": "",
                "telephone": "",
                "vat_id": "",
                "vat_is_valid": 0,
                "vat_request_date": "",
                "vat_request_id": "",
                "vat_request_success": 0
            }),
            "billing_address_id": 0,
            "can_ship_partially": 0,
            "can_ship_partially_item": 0,
            "coupon_code": "",
            "created_at": "",
            "customer_dob": "",
            "customer_email": "",
            "customer_firstname": "",
            "customer_gender": 0,
            "customer_group_id": 0,
            "customer_id": 0,
            "customer_is_guest": 0,
            "customer_lastname": "",
            "customer_middlename": "",
            "customer_note": "",
            "customer_note_notify": 0,
            "customer_prefix": "",
            "customer_suffix": "",
            "customer_taxvat": "",
            "discount_amount": "",
            "discount_canceled": "",
            "discount_description": "",
            "discount_invoiced": "",
            "discount_refunded": "",
            "discount_tax_compensation_amount": "",
            "discount_tax_compensation_invoiced": "",
            "discount_tax_compensation_refunded": "",
            "edit_increment": 0,
            "email_sent": 0,
            "entity_id": 0,
            "ext_customer_id": "",
            "ext_order_id": "",
            "extension_attributes": json!({
                "amazon_order_reference_id": "",
                "applied_taxes": (
                    json!({
                        "amount": "",
                        "base_amount": "",
                        "code": "",
                        "extension_attributes": json!({"rates": (
                                json!({
                                    "code": "",
                                    "extension_attributes": json!({}),
                                    "percent": "",
                                    "title": ""
                                })
                            )}),
                        "percent": "",
                        "title": ""
                    })
                ),
                "base_customer_balance_amount": "",
                "base_customer_balance_invoiced": "",
                "base_customer_balance_refunded": "",
                "base_customer_balance_total_refunded": "",
                "base_gift_cards_amount": "",
                "base_gift_cards_invoiced": "",
                "base_gift_cards_refunded": "",
                "base_reward_currency_amount": "",
                "company_order_attributes": json!({
                    "company_id": 0,
                    "company_name": "",
                    "extension_attributes": json!({}),
                    "order_id": 0
                }),
                "converting_from_quote": false,
                "customer_balance_amount": "",
                "customer_balance_invoiced": "",
                "customer_balance_refunded": "",
                "customer_balance_total_refunded": "",
                "gift_cards": (
                    json!({
                        "amount": "",
                        "base_amount": "",
                        "code": "",
                        "id": 0
                    })
                ),
                "gift_cards_amount": "",
                "gift_cards_invoiced": "",
                "gift_cards_refunded": "",
                "gift_message": json!({
                    "customer_id": 0,
                    "extension_attributes": json!({
                        "entity_id": "",
                        "entity_type": "",
                        "wrapping_add_printed_card": false,
                        "wrapping_allow_gift_receipt": false,
                        "wrapping_id": 0
                    }),
                    "gift_message_id": 0,
                    "message": "",
                    "recipient": "",
                    "sender": ""
                }),
                "gw_add_card": "",
                "gw_allow_gift_receipt": "",
                "gw_base_price": "",
                "gw_base_price_incl_tax": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_card_base_price": "",
                "gw_card_base_price_incl_tax": "",
                "gw_card_base_price_invoiced": "",
                "gw_card_base_price_refunded": "",
                "gw_card_base_tax_amount": "",
                "gw_card_base_tax_invoiced": "",
                "gw_card_base_tax_refunded": "",
                "gw_card_price": "",
                "gw_card_price_incl_tax": "",
                "gw_card_price_invoiced": "",
                "gw_card_price_refunded": "",
                "gw_card_tax_amount": "",
                "gw_card_tax_invoiced": "",
                "gw_card_tax_refunded": "",
                "gw_id": "",
                "gw_items_base_price": "",
                "gw_items_base_price_incl_tax": "",
                "gw_items_base_price_invoiced": "",
                "gw_items_base_price_refunded": "",
                "gw_items_base_tax_amount": "",
                "gw_items_base_tax_invoiced": "",
                "gw_items_base_tax_refunded": "",
                "gw_items_price": "",
                "gw_items_price_incl_tax": "",
                "gw_items_price_invoiced": "",
                "gw_items_price_refunded": "",
                "gw_items_tax_amount": "",
                "gw_items_tax_invoiced": "",
                "gw_items_tax_refunded": "",
                "gw_price": "",
                "gw_price_incl_tax": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "item_applied_taxes": (
                    json!({
                        "applied_taxes": (json!({})),
                        "associated_item_id": 0,
                        "extension_attributes": json!({}),
                        "item_id": 0,
                        "type": ""
                    })
                ),
                "payment_additional_info": (
                    json!({
                        "key": "",
                        "value": ""
                    })
                ),
                "reward_currency_amount": "",
                "reward_points_balance": 0,
                "shipping_assignments": (
                    json!({
                        "extension_attributes": json!({}),
                        "items": (
                            json!({
                                "additional_data": "",
                                "amount_refunded": "",
                                "applied_rule_ids": "",
                                "base_amount_refunded": "",
                                "base_cost": "",
                                "base_discount_amount": "",
                                "base_discount_invoiced": "",
                                "base_discount_refunded": "",
                                "base_discount_tax_compensation_amount": "",
                                "base_discount_tax_compensation_invoiced": "",
                                "base_discount_tax_compensation_refunded": "",
                                "base_original_price": "",
                                "base_price": "",
                                "base_price_incl_tax": "",
                                "base_row_invoiced": "",
                                "base_row_total": "",
                                "base_row_total_incl_tax": "",
                                "base_tax_amount": "",
                                "base_tax_before_discount": "",
                                "base_tax_invoiced": "",
                                "base_tax_refunded": "",
                                "base_weee_tax_applied_amount": "",
                                "base_weee_tax_applied_row_amnt": "",
                                "base_weee_tax_disposition": "",
                                "base_weee_tax_row_disposition": "",
                                "created_at": "",
                                "description": "",
                                "discount_amount": "",
                                "discount_invoiced": "",
                                "discount_percent": "",
                                "discount_refunded": "",
                                "discount_tax_compensation_amount": "",
                                "discount_tax_compensation_canceled": "",
                                "discount_tax_compensation_invoiced": "",
                                "discount_tax_compensation_refunded": "",
                                "event_id": 0,
                                "ext_order_item_id": "",
                                "extension_attributes": json!({
                                    "gift_message": json!({}),
                                    "gw_base_price": "",
                                    "gw_base_price_invoiced": "",
                                    "gw_base_price_refunded": "",
                                    "gw_base_tax_amount": "",
                                    "gw_base_tax_amount_invoiced": "",
                                    "gw_base_tax_amount_refunded": "",
                                    "gw_id": "",
                                    "gw_price": "",
                                    "gw_price_invoiced": "",
                                    "gw_price_refunded": "",
                                    "gw_tax_amount": "",
                                    "gw_tax_amount_invoiced": "",
                                    "gw_tax_amount_refunded": "",
                                    "invoice_text_codes": (),
                                    "tax_codes": (),
                                    "vertex_tax_codes": ()
                                }),
                                "free_shipping": 0,
                                "gw_base_price": "",
                                "gw_base_price_invoiced": "",
                                "gw_base_price_refunded": "",
                                "gw_base_tax_amount": "",
                                "gw_base_tax_amount_invoiced": "",
                                "gw_base_tax_amount_refunded": "",
                                "gw_id": 0,
                                "gw_price": "",
                                "gw_price_invoiced": "",
                                "gw_price_refunded": "",
                                "gw_tax_amount": "",
                                "gw_tax_amount_invoiced": "",
                                "gw_tax_amount_refunded": "",
                                "is_qty_decimal": 0,
                                "is_virtual": 0,
                                "item_id": 0,
                                "locked_do_invoice": 0,
                                "locked_do_ship": 0,
                                "name": "",
                                "no_discount": 0,
                                "order_id": 0,
                                "original_price": "",
                                "parent_item": "",
                                "parent_item_id": 0,
                                "price": "",
                                "price_incl_tax": "",
                                "product_id": 0,
                                "product_option": json!({"extension_attributes": json!({
                                        "bundle_options": (
                                            json!({
                                                "extension_attributes": json!({}),
                                                "option_id": 0,
                                                "option_qty": 0,
                                                "option_selections": ()
                                            })
                                        ),
                                        "configurable_item_options": (
                                            json!({
                                                "extension_attributes": json!({}),
                                                "option_id": "",
                                                "option_value": 0
                                            })
                                        ),
                                        "custom_options": (
                                            json!({
                                                "extension_attributes": json!({"file_info": json!({
                                                        "base64_encoded_data": "",
                                                        "name": "",
                                                        "type": ""
                                                    })}),
                                                "option_id": "",
                                                "option_value": ""
                                            })
                                        ),
                                        "downloadable_option": json!({"downloadable_links": ()}),
                                        "giftcard_item_option": json!({
                                            "custom_giftcard_amount": "",
                                            "extension_attributes": json!({}),
                                            "giftcard_amount": "",
                                            "giftcard_message": "",
                                            "giftcard_recipient_email": "",
                                            "giftcard_recipient_name": "",
                                            "giftcard_sender_email": "",
                                            "giftcard_sender_name": ""
                                        })
                                    })}),
                                "product_type": "",
                                "qty_backordered": "",
                                "qty_canceled": "",
                                "qty_invoiced": "",
                                "qty_ordered": "",
                                "qty_refunded": "",
                                "qty_returned": "",
                                "qty_shipped": "",
                                "quote_item_id": 0,
                                "row_invoiced": "",
                                "row_total": "",
                                "row_total_incl_tax": "",
                                "row_weight": "",
                                "sku": "",
                                "store_id": 0,
                                "tax_amount": "",
                                "tax_before_discount": "",
                                "tax_canceled": "",
                                "tax_invoiced": "",
                                "tax_percent": "",
                                "tax_refunded": "",
                                "updated_at": "",
                                "weee_tax_applied": "",
                                "weee_tax_applied_amount": "",
                                "weee_tax_applied_row_amount": "",
                                "weee_tax_disposition": "",
                                "weee_tax_row_disposition": "",
                                "weight": ""
                            })
                        ),
                        "shipping": json!({
                            "address": json!({}),
                            "extension_attributes": json!({
                                "collection_point": json!({
                                    "city": "",
                                    "collection_point_id": "",
                                    "country": "",
                                    "name": "",
                                    "postcode": "",
                                    "recipient_address_id": 0,
                                    "region": "",
                                    "street": ()
                                }),
                                "ext_order_id": "",
                                "shipping_experience": json!({
                                    "code": "",
                                    "cost": "",
                                    "label": ""
                                })
                            }),
                            "method": "",
                            "total": json!({
                                "base_shipping_amount": "",
                                "base_shipping_canceled": "",
                                "base_shipping_discount_amount": "",
                                "base_shipping_discount_tax_compensation_amnt": "",
                                "base_shipping_incl_tax": "",
                                "base_shipping_invoiced": "",
                                "base_shipping_refunded": "",
                                "base_shipping_tax_amount": "",
                                "base_shipping_tax_refunded": "",
                                "extension_attributes": json!({}),
                                "shipping_amount": "",
                                "shipping_canceled": "",
                                "shipping_discount_amount": "",
                                "shipping_discount_tax_compensation_amount": "",
                                "shipping_incl_tax": "",
                                "shipping_invoiced": "",
                                "shipping_refunded": "",
                                "shipping_tax_amount": "",
                                "shipping_tax_refunded": ""
                            })
                        }),
                        "stock_id": 0
                    })
                )
            }),
            "forced_shipment_with_invoice": 0,
            "global_currency_code": "",
            "grand_total": "",
            "hold_before_state": "",
            "hold_before_status": "",
            "increment_id": "",
            "is_virtual": 0,
            "items": (json!({})),
            "order_currency_code": "",
            "original_increment_id": "",
            "payment": json!({
                "account_status": "",
                "additional_data": "",
                "additional_information": (),
                "address_status": "",
                "amount_authorized": "",
                "amount_canceled": "",
                "amount_ordered": "",
                "amount_paid": "",
                "amount_refunded": "",
                "anet_trans_method": "",
                "base_amount_authorized": "",
                "base_amount_canceled": "",
                "base_amount_ordered": "",
                "base_amount_paid": "",
                "base_amount_paid_online": "",
                "base_amount_refunded": "",
                "base_amount_refunded_online": "",
                "base_shipping_amount": "",
                "base_shipping_captured": "",
                "base_shipping_refunded": "",
                "cc_approval": "",
                "cc_avs_status": "",
                "cc_cid_status": "",
                "cc_debug_request_body": "",
                "cc_debug_response_body": "",
                "cc_debug_response_serialized": "",
                "cc_exp_month": "",
                "cc_exp_year": "",
                "cc_last4": "",
                "cc_number_enc": "",
                "cc_owner": "",
                "cc_secure_verify": "",
                "cc_ss_issue": "",
                "cc_ss_start_month": "",
                "cc_ss_start_year": "",
                "cc_status": "",
                "cc_status_description": "",
                "cc_trans_id": "",
                "cc_type": "",
                "echeck_account_name": "",
                "echeck_account_type": "",
                "echeck_bank_name": "",
                "echeck_routing_number": "",
                "echeck_type": "",
                "entity_id": 0,
                "extension_attributes": json!({"vault_payment_token": json!({
                        "created_at": "",
                        "customer_id": 0,
                        "entity_id": 0,
                        "expires_at": "",
                        "gateway_token": "",
                        "is_active": false,
                        "is_visible": false,
                        "payment_method_code": "",
                        "public_hash": "",
                        "token_details": "",
                        "type": ""
                    })}),
                "last_trans_id": "",
                "method": "",
                "parent_id": 0,
                "po_number": "",
                "protection_eligibility": "",
                "quote_payment_id": 0,
                "shipping_amount": "",
                "shipping_captured": "",
                "shipping_refunded": ""
            }),
            "payment_auth_expiration": 0,
            "payment_authorization_amount": "",
            "protect_code": "",
            "quote_address_id": 0,
            "quote_id": 0,
            "relation_child_id": "",
            "relation_child_real_id": "",
            "relation_parent_id": "",
            "relation_parent_real_id": "",
            "remote_ip": "",
            "shipping_amount": "",
            "shipping_canceled": "",
            "shipping_description": "",
            "shipping_discount_amount": "",
            "shipping_discount_tax_compensation_amount": "",
            "shipping_incl_tax": "",
            "shipping_invoiced": "",
            "shipping_refunded": "",
            "shipping_tax_amount": "",
            "shipping_tax_refunded": "",
            "state": "",
            "status": "",
            "status_histories": (
                json!({
                    "comment": "",
                    "created_at": "",
                    "entity_id": 0,
                    "entity_name": "",
                    "extension_attributes": json!({}),
                    "is_customer_notified": 0,
                    "is_visible_on_front": 0,
                    "parent_id": 0,
                    "status": ""
                })
            ),
            "store_currency_code": "",
            "store_id": 0,
            "store_name": "",
            "store_to_base_rate": "",
            "store_to_order_rate": "",
            "subtotal": "",
            "subtotal_canceled": "",
            "subtotal_incl_tax": "",
            "subtotal_invoiced": "",
            "subtotal_refunded": "",
            "tax_amount": "",
            "tax_canceled": "",
            "tax_invoiced": "",
            "tax_refunded": "",
            "total_canceled": "",
            "total_due": "",
            "total_invoiced": "",
            "total_item_count": 0,
            "total_offline_refunded": "",
            "total_online_refunded": "",
            "total_paid": "",
            "total_qty_ordered": "",
            "total_refunded": "",
            "updated_at": "",
            "weight": "",
            "x_forwarded_for": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/orders/create \
  --header 'content-type: application/json' \
  --data '{
  "entity": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "applied_rule_ids": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_canceled": "",
    "base_discount_invoiced": "",
    "base_discount_refunded": "",
    "base_discount_tax_compensation_amount": "",
    "base_discount_tax_compensation_invoiced": "",
    "base_discount_tax_compensation_refunded": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_canceled": "",
    "base_shipping_discount_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_invoiced": "",
    "base_shipping_refunded": "",
    "base_shipping_tax_amount": "",
    "base_shipping_tax_refunded": "",
    "base_subtotal": "",
    "base_subtotal_canceled": "",
    "base_subtotal_incl_tax": "",
    "base_subtotal_invoiced": "",
    "base_subtotal_refunded": "",
    "base_tax_amount": "",
    "base_tax_canceled": "",
    "base_tax_invoiced": "",
    "base_tax_refunded": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_canceled": "",
    "base_total_due": "",
    "base_total_invoiced": "",
    "base_total_invoiced_cost": "",
    "base_total_offline_refunded": "",
    "base_total_online_refunded": "",
    "base_total_paid": "",
    "base_total_qty_ordered": "",
    "base_total_refunded": "",
    "billing_address": {
      "address_type": "",
      "city": "",
      "company": "",
      "country_id": "",
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "entity_id": 0,
      "extension_attributes": {
        "checkout_fields": [
          {
            "attribute_code": "",
            "value": ""
          }
        ]
      },
      "fax": "",
      "firstname": "",
      "lastname": "",
      "middlename": "",
      "parent_id": 0,
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": "",
      "vat_is_valid": 0,
      "vat_request_date": "",
      "vat_request_id": "",
      "vat_request_success": 0
    },
    "billing_address_id": 0,
    "can_ship_partially": 0,
    "can_ship_partially_item": 0,
    "coupon_code": "",
    "created_at": "",
    "customer_dob": "",
    "customer_email": "",
    "customer_firstname": "",
    "customer_gender": 0,
    "customer_group_id": 0,
    "customer_id": 0,
    "customer_is_guest": 0,
    "customer_lastname": "",
    "customer_middlename": "",
    "customer_note": "",
    "customer_note_notify": 0,
    "customer_prefix": "",
    "customer_suffix": "",
    "customer_taxvat": "",
    "discount_amount": "",
    "discount_canceled": "",
    "discount_description": "",
    "discount_invoiced": "",
    "discount_refunded": "",
    "discount_tax_compensation_amount": "",
    "discount_tax_compensation_invoiced": "",
    "discount_tax_compensation_refunded": "",
    "edit_increment": 0,
    "email_sent": 0,
    "entity_id": 0,
    "ext_customer_id": "",
    "ext_order_id": "",
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "applied_taxes": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "extension_attributes": {
            "rates": [
              {
                "code": "",
                "extension_attributes": {},
                "percent": "",
                "title": ""
              }
            ]
          },
          "percent": "",
          "title": ""
        }
      ],
      "base_customer_balance_amount": "",
      "base_customer_balance_invoiced": "",
      "base_customer_balance_refunded": "",
      "base_customer_balance_total_refunded": "",
      "base_gift_cards_amount": "",
      "base_gift_cards_invoiced": "",
      "base_gift_cards_refunded": "",
      "base_reward_currency_amount": "",
      "company_order_attributes": {
        "company_id": 0,
        "company_name": "",
        "extension_attributes": {},
        "order_id": 0
      },
      "converting_from_quote": false,
      "customer_balance_amount": "",
      "customer_balance_invoiced": "",
      "customer_balance_refunded": "",
      "customer_balance_total_refunded": "",
      "gift_cards": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "id": 0
        }
      ],
      "gift_cards_amount": "",
      "gift_cards_invoiced": "",
      "gift_cards_refunded": "",
      "gift_message": {
        "customer_id": 0,
        "extension_attributes": {
          "entity_id": "",
          "entity_type": "",
          "wrapping_add_printed_card": false,
          "wrapping_allow_gift_receipt": false,
          "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
      },
      "gw_add_card": "",
      "gw_allow_gift_receipt": "",
      "gw_base_price": "",
      "gw_base_price_incl_tax": "",
      "gw_base_price_invoiced": "",
      "gw_base_price_refunded": "",
      "gw_base_tax_amount": "",
      "gw_base_tax_amount_invoiced": "",
      "gw_base_tax_amount_refunded": "",
      "gw_card_base_price": "",
      "gw_card_base_price_incl_tax": "",
      "gw_card_base_price_invoiced": "",
      "gw_card_base_price_refunded": "",
      "gw_card_base_tax_amount": "",
      "gw_card_base_tax_invoiced": "",
      "gw_card_base_tax_refunded": "",
      "gw_card_price": "",
      "gw_card_price_incl_tax": "",
      "gw_card_price_invoiced": "",
      "gw_card_price_refunded": "",
      "gw_card_tax_amount": "",
      "gw_card_tax_invoiced": "",
      "gw_card_tax_refunded": "",
      "gw_id": "",
      "gw_items_base_price": "",
      "gw_items_base_price_incl_tax": "",
      "gw_items_base_price_invoiced": "",
      "gw_items_base_price_refunded": "",
      "gw_items_base_tax_amount": "",
      "gw_items_base_tax_invoiced": "",
      "gw_items_base_tax_refunded": "",
      "gw_items_price": "",
      "gw_items_price_incl_tax": "",
      "gw_items_price_invoiced": "",
      "gw_items_price_refunded": "",
      "gw_items_tax_amount": "",
      "gw_items_tax_invoiced": "",
      "gw_items_tax_refunded": "",
      "gw_price": "",
      "gw_price_incl_tax": "",
      "gw_price_invoiced": "",
      "gw_price_refunded": "",
      "gw_tax_amount": "",
      "gw_tax_amount_invoiced": "",
      "gw_tax_amount_refunded": "",
      "item_applied_taxes": [
        {
          "applied_taxes": [
            {}
          ],
          "associated_item_id": 0,
          "extension_attributes": {},
          "item_id": 0,
          "type": ""
        }
      ],
      "payment_additional_info": [
        {
          "key": "",
          "value": ""
        }
      ],
      "reward_currency_amount": "",
      "reward_points_balance": 0,
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "additional_data": "",
              "amount_refunded": "",
              "applied_rule_ids": "",
              "base_amount_refunded": "",
              "base_cost": "",
              "base_discount_amount": "",
              "base_discount_invoiced": "",
              "base_discount_refunded": "",
              "base_discount_tax_compensation_amount": "",
              "base_discount_tax_compensation_invoiced": "",
              "base_discount_tax_compensation_refunded": "",
              "base_original_price": "",
              "base_price": "",
              "base_price_incl_tax": "",
              "base_row_invoiced": "",
              "base_row_total": "",
              "base_row_total_incl_tax": "",
              "base_tax_amount": "",
              "base_tax_before_discount": "",
              "base_tax_invoiced": "",
              "base_tax_refunded": "",
              "base_weee_tax_applied_amount": "",
              "base_weee_tax_applied_row_amnt": "",
              "base_weee_tax_disposition": "",
              "base_weee_tax_row_disposition": "",
              "created_at": "",
              "description": "",
              "discount_amount": "",
              "discount_invoiced": "",
              "discount_percent": "",
              "discount_refunded": "",
              "discount_tax_compensation_amount": "",
              "discount_tax_compensation_canceled": "",
              "discount_tax_compensation_invoiced": "",
              "discount_tax_compensation_refunded": "",
              "event_id": 0,
              "ext_order_item_id": "",
              "extension_attributes": {
                "gift_message": {},
                "gw_base_price": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_id": "",
                "gw_price": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "invoice_text_codes": [],
                "tax_codes": [],
                "vertex_tax_codes": []
              },
              "free_shipping": 0,
              "gw_base_price": "",
              "gw_base_price_invoiced": "",
              "gw_base_price_refunded": "",
              "gw_base_tax_amount": "",
              "gw_base_tax_amount_invoiced": "",
              "gw_base_tax_amount_refunded": "",
              "gw_id": 0,
              "gw_price": "",
              "gw_price_invoiced": "",
              "gw_price_refunded": "",
              "gw_tax_amount": "",
              "gw_tax_amount_invoiced": "",
              "gw_tax_amount_refunded": "",
              "is_qty_decimal": 0,
              "is_virtual": 0,
              "item_id": 0,
              "locked_do_invoice": 0,
              "locked_do_ship": 0,
              "name": "",
              "no_discount": 0,
              "order_id": 0,
              "original_price": "",
              "parent_item": "",
              "parent_item_id": 0,
              "price": "",
              "price_incl_tax": "",
              "product_id": 0,
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty_backordered": "",
              "qty_canceled": "",
              "qty_invoiced": "",
              "qty_ordered": "",
              "qty_refunded": "",
              "qty_returned": "",
              "qty_shipped": "",
              "quote_item_id": 0,
              "row_invoiced": "",
              "row_total": "",
              "row_total_incl_tax": "",
              "row_weight": "",
              "sku": "",
              "store_id": 0,
              "tax_amount": "",
              "tax_before_discount": "",
              "tax_canceled": "",
              "tax_invoiced": "",
              "tax_percent": "",
              "tax_refunded": "",
              "updated_at": "",
              "weee_tax_applied": "",
              "weee_tax_applied_amount": "",
              "weee_tax_applied_row_amount": "",
              "weee_tax_disposition": "",
              "weee_tax_row_disposition": "",
              "weight": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {
              "collection_point": {
                "city": "",
                "collection_point_id": "",
                "country": "",
                "name": "",
                "postcode": "",
                "recipient_address_id": 0,
                "region": "",
                "street": []
              },
              "ext_order_id": "",
              "shipping_experience": {
                "code": "",
                "cost": "",
                "label": ""
              }
            },
            "method": "",
            "total": {
              "base_shipping_amount": "",
              "base_shipping_canceled": "",
              "base_shipping_discount_amount": "",
              "base_shipping_discount_tax_compensation_amnt": "",
              "base_shipping_incl_tax": "",
              "base_shipping_invoiced": "",
              "base_shipping_refunded": "",
              "base_shipping_tax_amount": "",
              "base_shipping_tax_refunded": "",
              "extension_attributes": {},
              "shipping_amount": "",
              "shipping_canceled": "",
              "shipping_discount_amount": "",
              "shipping_discount_tax_compensation_amount": "",
              "shipping_incl_tax": "",
              "shipping_invoiced": "",
              "shipping_refunded": "",
              "shipping_tax_amount": "",
              "shipping_tax_refunded": ""
            }
          },
          "stock_id": 0
        }
      ]
    },
    "forced_shipment_with_invoice": 0,
    "global_currency_code": "",
    "grand_total": "",
    "hold_before_state": "",
    "hold_before_status": "",
    "increment_id": "",
    "is_virtual": 0,
    "items": [
      {}
    ],
    "order_currency_code": "",
    "original_increment_id": "",
    "payment": {
      "account_status": "",
      "additional_data": "",
      "additional_information": [],
      "address_status": "",
      "amount_authorized": "",
      "amount_canceled": "",
      "amount_ordered": "",
      "amount_paid": "",
      "amount_refunded": "",
      "anet_trans_method": "",
      "base_amount_authorized": "",
      "base_amount_canceled": "",
      "base_amount_ordered": "",
      "base_amount_paid": "",
      "base_amount_paid_online": "",
      "base_amount_refunded": "",
      "base_amount_refunded_online": "",
      "base_shipping_amount": "",
      "base_shipping_captured": "",
      "base_shipping_refunded": "",
      "cc_approval": "",
      "cc_avs_status": "",
      "cc_cid_status": "",
      "cc_debug_request_body": "",
      "cc_debug_response_body": "",
      "cc_debug_response_serialized": "",
      "cc_exp_month": "",
      "cc_exp_year": "",
      "cc_last4": "",
      "cc_number_enc": "",
      "cc_owner": "",
      "cc_secure_verify": "",
      "cc_ss_issue": "",
      "cc_ss_start_month": "",
      "cc_ss_start_year": "",
      "cc_status": "",
      "cc_status_description": "",
      "cc_trans_id": "",
      "cc_type": "",
      "echeck_account_name": "",
      "echeck_account_type": "",
      "echeck_bank_name": "",
      "echeck_routing_number": "",
      "echeck_type": "",
      "entity_id": 0,
      "extension_attributes": {
        "vault_payment_token": {
          "created_at": "",
          "customer_id": 0,
          "entity_id": 0,
          "expires_at": "",
          "gateway_token": "",
          "is_active": false,
          "is_visible": false,
          "payment_method_code": "",
          "public_hash": "",
          "token_details": "",
          "type": ""
        }
      },
      "last_trans_id": "",
      "method": "",
      "parent_id": 0,
      "po_number": "",
      "protection_eligibility": "",
      "quote_payment_id": 0,
      "shipping_amount": "",
      "shipping_captured": "",
      "shipping_refunded": ""
    },
    "payment_auth_expiration": 0,
    "payment_authorization_amount": "",
    "protect_code": "",
    "quote_address_id": 0,
    "quote_id": 0,
    "relation_child_id": "",
    "relation_child_real_id": "",
    "relation_parent_id": "",
    "relation_parent_real_id": "",
    "remote_ip": "",
    "shipping_amount": "",
    "shipping_canceled": "",
    "shipping_description": "",
    "shipping_discount_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_invoiced": "",
    "shipping_refunded": "",
    "shipping_tax_amount": "",
    "shipping_tax_refunded": "",
    "state": "",
    "status": "",
    "status_histories": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "entity_name": "",
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0,
        "status": ""
      }
    ],
    "store_currency_code": "",
    "store_id": 0,
    "store_name": "",
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_canceled": "",
    "subtotal_incl_tax": "",
    "subtotal_invoiced": "",
    "subtotal_refunded": "",
    "tax_amount": "",
    "tax_canceled": "",
    "tax_invoiced": "",
    "tax_refunded": "",
    "total_canceled": "",
    "total_due": "",
    "total_invoiced": "",
    "total_item_count": 0,
    "total_offline_refunded": "",
    "total_online_refunded": "",
    "total_paid": "",
    "total_qty_ordered": "",
    "total_refunded": "",
    "updated_at": "",
    "weight": "",
    "x_forwarded_for": ""
  }
}'
echo '{
  "entity": {
    "adjustment_negative": "",
    "adjustment_positive": "",
    "applied_rule_ids": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_canceled": "",
    "base_discount_invoiced": "",
    "base_discount_refunded": "",
    "base_discount_tax_compensation_amount": "",
    "base_discount_tax_compensation_invoiced": "",
    "base_discount_tax_compensation_refunded": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_canceled": "",
    "base_shipping_discount_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_invoiced": "",
    "base_shipping_refunded": "",
    "base_shipping_tax_amount": "",
    "base_shipping_tax_refunded": "",
    "base_subtotal": "",
    "base_subtotal_canceled": "",
    "base_subtotal_incl_tax": "",
    "base_subtotal_invoiced": "",
    "base_subtotal_refunded": "",
    "base_tax_amount": "",
    "base_tax_canceled": "",
    "base_tax_invoiced": "",
    "base_tax_refunded": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_canceled": "",
    "base_total_due": "",
    "base_total_invoiced": "",
    "base_total_invoiced_cost": "",
    "base_total_offline_refunded": "",
    "base_total_online_refunded": "",
    "base_total_paid": "",
    "base_total_qty_ordered": "",
    "base_total_refunded": "",
    "billing_address": {
      "address_type": "",
      "city": "",
      "company": "",
      "country_id": "",
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "entity_id": 0,
      "extension_attributes": {
        "checkout_fields": [
          {
            "attribute_code": "",
            "value": ""
          }
        ]
      },
      "fax": "",
      "firstname": "",
      "lastname": "",
      "middlename": "",
      "parent_id": 0,
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": "",
      "vat_is_valid": 0,
      "vat_request_date": "",
      "vat_request_id": "",
      "vat_request_success": 0
    },
    "billing_address_id": 0,
    "can_ship_partially": 0,
    "can_ship_partially_item": 0,
    "coupon_code": "",
    "created_at": "",
    "customer_dob": "",
    "customer_email": "",
    "customer_firstname": "",
    "customer_gender": 0,
    "customer_group_id": 0,
    "customer_id": 0,
    "customer_is_guest": 0,
    "customer_lastname": "",
    "customer_middlename": "",
    "customer_note": "",
    "customer_note_notify": 0,
    "customer_prefix": "",
    "customer_suffix": "",
    "customer_taxvat": "",
    "discount_amount": "",
    "discount_canceled": "",
    "discount_description": "",
    "discount_invoiced": "",
    "discount_refunded": "",
    "discount_tax_compensation_amount": "",
    "discount_tax_compensation_invoiced": "",
    "discount_tax_compensation_refunded": "",
    "edit_increment": 0,
    "email_sent": 0,
    "entity_id": 0,
    "ext_customer_id": "",
    "ext_order_id": "",
    "extension_attributes": {
      "amazon_order_reference_id": "",
      "applied_taxes": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "extension_attributes": {
            "rates": [
              {
                "code": "",
                "extension_attributes": {},
                "percent": "",
                "title": ""
              }
            ]
          },
          "percent": "",
          "title": ""
        }
      ],
      "base_customer_balance_amount": "",
      "base_customer_balance_invoiced": "",
      "base_customer_balance_refunded": "",
      "base_customer_balance_total_refunded": "",
      "base_gift_cards_amount": "",
      "base_gift_cards_invoiced": "",
      "base_gift_cards_refunded": "",
      "base_reward_currency_amount": "",
      "company_order_attributes": {
        "company_id": 0,
        "company_name": "",
        "extension_attributes": {},
        "order_id": 0
      },
      "converting_from_quote": false,
      "customer_balance_amount": "",
      "customer_balance_invoiced": "",
      "customer_balance_refunded": "",
      "customer_balance_total_refunded": "",
      "gift_cards": [
        {
          "amount": "",
          "base_amount": "",
          "code": "",
          "id": 0
        }
      ],
      "gift_cards_amount": "",
      "gift_cards_invoiced": "",
      "gift_cards_refunded": "",
      "gift_message": {
        "customer_id": 0,
        "extension_attributes": {
          "entity_id": "",
          "entity_type": "",
          "wrapping_add_printed_card": false,
          "wrapping_allow_gift_receipt": false,
          "wrapping_id": 0
        },
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
      },
      "gw_add_card": "",
      "gw_allow_gift_receipt": "",
      "gw_base_price": "",
      "gw_base_price_incl_tax": "",
      "gw_base_price_invoiced": "",
      "gw_base_price_refunded": "",
      "gw_base_tax_amount": "",
      "gw_base_tax_amount_invoiced": "",
      "gw_base_tax_amount_refunded": "",
      "gw_card_base_price": "",
      "gw_card_base_price_incl_tax": "",
      "gw_card_base_price_invoiced": "",
      "gw_card_base_price_refunded": "",
      "gw_card_base_tax_amount": "",
      "gw_card_base_tax_invoiced": "",
      "gw_card_base_tax_refunded": "",
      "gw_card_price": "",
      "gw_card_price_incl_tax": "",
      "gw_card_price_invoiced": "",
      "gw_card_price_refunded": "",
      "gw_card_tax_amount": "",
      "gw_card_tax_invoiced": "",
      "gw_card_tax_refunded": "",
      "gw_id": "",
      "gw_items_base_price": "",
      "gw_items_base_price_incl_tax": "",
      "gw_items_base_price_invoiced": "",
      "gw_items_base_price_refunded": "",
      "gw_items_base_tax_amount": "",
      "gw_items_base_tax_invoiced": "",
      "gw_items_base_tax_refunded": "",
      "gw_items_price": "",
      "gw_items_price_incl_tax": "",
      "gw_items_price_invoiced": "",
      "gw_items_price_refunded": "",
      "gw_items_tax_amount": "",
      "gw_items_tax_invoiced": "",
      "gw_items_tax_refunded": "",
      "gw_price": "",
      "gw_price_incl_tax": "",
      "gw_price_invoiced": "",
      "gw_price_refunded": "",
      "gw_tax_amount": "",
      "gw_tax_amount_invoiced": "",
      "gw_tax_amount_refunded": "",
      "item_applied_taxes": [
        {
          "applied_taxes": [
            {}
          ],
          "associated_item_id": 0,
          "extension_attributes": {},
          "item_id": 0,
          "type": ""
        }
      ],
      "payment_additional_info": [
        {
          "key": "",
          "value": ""
        }
      ],
      "reward_currency_amount": "",
      "reward_points_balance": 0,
      "shipping_assignments": [
        {
          "extension_attributes": {},
          "items": [
            {
              "additional_data": "",
              "amount_refunded": "",
              "applied_rule_ids": "",
              "base_amount_refunded": "",
              "base_cost": "",
              "base_discount_amount": "",
              "base_discount_invoiced": "",
              "base_discount_refunded": "",
              "base_discount_tax_compensation_amount": "",
              "base_discount_tax_compensation_invoiced": "",
              "base_discount_tax_compensation_refunded": "",
              "base_original_price": "",
              "base_price": "",
              "base_price_incl_tax": "",
              "base_row_invoiced": "",
              "base_row_total": "",
              "base_row_total_incl_tax": "",
              "base_tax_amount": "",
              "base_tax_before_discount": "",
              "base_tax_invoiced": "",
              "base_tax_refunded": "",
              "base_weee_tax_applied_amount": "",
              "base_weee_tax_applied_row_amnt": "",
              "base_weee_tax_disposition": "",
              "base_weee_tax_row_disposition": "",
              "created_at": "",
              "description": "",
              "discount_amount": "",
              "discount_invoiced": "",
              "discount_percent": "",
              "discount_refunded": "",
              "discount_tax_compensation_amount": "",
              "discount_tax_compensation_canceled": "",
              "discount_tax_compensation_invoiced": "",
              "discount_tax_compensation_refunded": "",
              "event_id": 0,
              "ext_order_item_id": "",
              "extension_attributes": {
                "gift_message": {},
                "gw_base_price": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_id": "",
                "gw_price": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "invoice_text_codes": [],
                "tax_codes": [],
                "vertex_tax_codes": []
              },
              "free_shipping": 0,
              "gw_base_price": "",
              "gw_base_price_invoiced": "",
              "gw_base_price_refunded": "",
              "gw_base_tax_amount": "",
              "gw_base_tax_amount_invoiced": "",
              "gw_base_tax_amount_refunded": "",
              "gw_id": 0,
              "gw_price": "",
              "gw_price_invoiced": "",
              "gw_price_refunded": "",
              "gw_tax_amount": "",
              "gw_tax_amount_invoiced": "",
              "gw_tax_amount_refunded": "",
              "is_qty_decimal": 0,
              "is_virtual": 0,
              "item_id": 0,
              "locked_do_invoice": 0,
              "locked_do_ship": 0,
              "name": "",
              "no_discount": 0,
              "order_id": 0,
              "original_price": "",
              "parent_item": "",
              "parent_item_id": 0,
              "price": "",
              "price_incl_tax": "",
              "product_id": 0,
              "product_option": {
                "extension_attributes": {
                  "bundle_options": [
                    {
                      "extension_attributes": {},
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    }
                  ],
                  "configurable_item_options": [
                    {
                      "extension_attributes": {},
                      "option_id": "",
                      "option_value": 0
                    }
                  ],
                  "custom_options": [
                    {
                      "extension_attributes": {
                        "file_info": {
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        }
                      },
                      "option_id": "",
                      "option_value": ""
                    }
                  ],
                  "downloadable_option": {
                    "downloadable_links": []
                  },
                  "giftcard_item_option": {
                    "custom_giftcard_amount": "",
                    "extension_attributes": {},
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  }
                }
              },
              "product_type": "",
              "qty_backordered": "",
              "qty_canceled": "",
              "qty_invoiced": "",
              "qty_ordered": "",
              "qty_refunded": "",
              "qty_returned": "",
              "qty_shipped": "",
              "quote_item_id": 0,
              "row_invoiced": "",
              "row_total": "",
              "row_total_incl_tax": "",
              "row_weight": "",
              "sku": "",
              "store_id": 0,
              "tax_amount": "",
              "tax_before_discount": "",
              "tax_canceled": "",
              "tax_invoiced": "",
              "tax_percent": "",
              "tax_refunded": "",
              "updated_at": "",
              "weee_tax_applied": "",
              "weee_tax_applied_amount": "",
              "weee_tax_applied_row_amount": "",
              "weee_tax_disposition": "",
              "weee_tax_row_disposition": "",
              "weight": ""
            }
          ],
          "shipping": {
            "address": {},
            "extension_attributes": {
              "collection_point": {
                "city": "",
                "collection_point_id": "",
                "country": "",
                "name": "",
                "postcode": "",
                "recipient_address_id": 0,
                "region": "",
                "street": []
              },
              "ext_order_id": "",
              "shipping_experience": {
                "code": "",
                "cost": "",
                "label": ""
              }
            },
            "method": "",
            "total": {
              "base_shipping_amount": "",
              "base_shipping_canceled": "",
              "base_shipping_discount_amount": "",
              "base_shipping_discount_tax_compensation_amnt": "",
              "base_shipping_incl_tax": "",
              "base_shipping_invoiced": "",
              "base_shipping_refunded": "",
              "base_shipping_tax_amount": "",
              "base_shipping_tax_refunded": "",
              "extension_attributes": {},
              "shipping_amount": "",
              "shipping_canceled": "",
              "shipping_discount_amount": "",
              "shipping_discount_tax_compensation_amount": "",
              "shipping_incl_tax": "",
              "shipping_invoiced": "",
              "shipping_refunded": "",
              "shipping_tax_amount": "",
              "shipping_tax_refunded": ""
            }
          },
          "stock_id": 0
        }
      ]
    },
    "forced_shipment_with_invoice": 0,
    "global_currency_code": "",
    "grand_total": "",
    "hold_before_state": "",
    "hold_before_status": "",
    "increment_id": "",
    "is_virtual": 0,
    "items": [
      {}
    ],
    "order_currency_code": "",
    "original_increment_id": "",
    "payment": {
      "account_status": "",
      "additional_data": "",
      "additional_information": [],
      "address_status": "",
      "amount_authorized": "",
      "amount_canceled": "",
      "amount_ordered": "",
      "amount_paid": "",
      "amount_refunded": "",
      "anet_trans_method": "",
      "base_amount_authorized": "",
      "base_amount_canceled": "",
      "base_amount_ordered": "",
      "base_amount_paid": "",
      "base_amount_paid_online": "",
      "base_amount_refunded": "",
      "base_amount_refunded_online": "",
      "base_shipping_amount": "",
      "base_shipping_captured": "",
      "base_shipping_refunded": "",
      "cc_approval": "",
      "cc_avs_status": "",
      "cc_cid_status": "",
      "cc_debug_request_body": "",
      "cc_debug_response_body": "",
      "cc_debug_response_serialized": "",
      "cc_exp_month": "",
      "cc_exp_year": "",
      "cc_last4": "",
      "cc_number_enc": "",
      "cc_owner": "",
      "cc_secure_verify": "",
      "cc_ss_issue": "",
      "cc_ss_start_month": "",
      "cc_ss_start_year": "",
      "cc_status": "",
      "cc_status_description": "",
      "cc_trans_id": "",
      "cc_type": "",
      "echeck_account_name": "",
      "echeck_account_type": "",
      "echeck_bank_name": "",
      "echeck_routing_number": "",
      "echeck_type": "",
      "entity_id": 0,
      "extension_attributes": {
        "vault_payment_token": {
          "created_at": "",
          "customer_id": 0,
          "entity_id": 0,
          "expires_at": "",
          "gateway_token": "",
          "is_active": false,
          "is_visible": false,
          "payment_method_code": "",
          "public_hash": "",
          "token_details": "",
          "type": ""
        }
      },
      "last_trans_id": "",
      "method": "",
      "parent_id": 0,
      "po_number": "",
      "protection_eligibility": "",
      "quote_payment_id": 0,
      "shipping_amount": "",
      "shipping_captured": "",
      "shipping_refunded": ""
    },
    "payment_auth_expiration": 0,
    "payment_authorization_amount": "",
    "protect_code": "",
    "quote_address_id": 0,
    "quote_id": 0,
    "relation_child_id": "",
    "relation_child_real_id": "",
    "relation_parent_id": "",
    "relation_parent_real_id": "",
    "remote_ip": "",
    "shipping_amount": "",
    "shipping_canceled": "",
    "shipping_description": "",
    "shipping_discount_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_invoiced": "",
    "shipping_refunded": "",
    "shipping_tax_amount": "",
    "shipping_tax_refunded": "",
    "state": "",
    "status": "",
    "status_histories": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "entity_name": "",
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0,
        "status": ""
      }
    ],
    "store_currency_code": "",
    "store_id": 0,
    "store_name": "",
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_canceled": "",
    "subtotal_incl_tax": "",
    "subtotal_invoiced": "",
    "subtotal_refunded": "",
    "tax_amount": "",
    "tax_canceled": "",
    "tax_invoiced": "",
    "tax_refunded": "",
    "total_canceled": "",
    "total_due": "",
    "total_invoiced": "",
    "total_item_count": 0,
    "total_offline_refunded": "",
    "total_online_refunded": "",
    "total_paid": "",
    "total_qty_ordered": "",
    "total_refunded": "",
    "updated_at": "",
    "weight": "",
    "x_forwarded_for": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/orders/create \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "entity": {\n    "adjustment_negative": "",\n    "adjustment_positive": "",\n    "applied_rule_ids": "",\n    "base_adjustment_negative": "",\n    "base_adjustment_positive": "",\n    "base_currency_code": "",\n    "base_discount_amount": "",\n    "base_discount_canceled": "",\n    "base_discount_invoiced": "",\n    "base_discount_refunded": "",\n    "base_discount_tax_compensation_amount": "",\n    "base_discount_tax_compensation_invoiced": "",\n    "base_discount_tax_compensation_refunded": "",\n    "base_grand_total": "",\n    "base_shipping_amount": "",\n    "base_shipping_canceled": "",\n    "base_shipping_discount_amount": "",\n    "base_shipping_discount_tax_compensation_amnt": "",\n    "base_shipping_incl_tax": "",\n    "base_shipping_invoiced": "",\n    "base_shipping_refunded": "",\n    "base_shipping_tax_amount": "",\n    "base_shipping_tax_refunded": "",\n    "base_subtotal": "",\n    "base_subtotal_canceled": "",\n    "base_subtotal_incl_tax": "",\n    "base_subtotal_invoiced": "",\n    "base_subtotal_refunded": "",\n    "base_tax_amount": "",\n    "base_tax_canceled": "",\n    "base_tax_invoiced": "",\n    "base_tax_refunded": "",\n    "base_to_global_rate": "",\n    "base_to_order_rate": "",\n    "base_total_canceled": "",\n    "base_total_due": "",\n    "base_total_invoiced": "",\n    "base_total_invoiced_cost": "",\n    "base_total_offline_refunded": "",\n    "base_total_online_refunded": "",\n    "base_total_paid": "",\n    "base_total_qty_ordered": "",\n    "base_total_refunded": "",\n    "billing_address": {\n      "address_type": "",\n      "city": "",\n      "company": "",\n      "country_id": "",\n      "customer_address_id": 0,\n      "customer_id": 0,\n      "email": "",\n      "entity_id": 0,\n      "extension_attributes": {\n        "checkout_fields": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ]\n      },\n      "fax": "",\n      "firstname": "",\n      "lastname": "",\n      "middlename": "",\n      "parent_id": 0,\n      "postcode": "",\n      "prefix": "",\n      "region": "",\n      "region_code": "",\n      "region_id": 0,\n      "street": [],\n      "suffix": "",\n      "telephone": "",\n      "vat_id": "",\n      "vat_is_valid": 0,\n      "vat_request_date": "",\n      "vat_request_id": "",\n      "vat_request_success": 0\n    },\n    "billing_address_id": 0,\n    "can_ship_partially": 0,\n    "can_ship_partially_item": 0,\n    "coupon_code": "",\n    "created_at": "",\n    "customer_dob": "",\n    "customer_email": "",\n    "customer_firstname": "",\n    "customer_gender": 0,\n    "customer_group_id": 0,\n    "customer_id": 0,\n    "customer_is_guest": 0,\n    "customer_lastname": "",\n    "customer_middlename": "",\n    "customer_note": "",\n    "customer_note_notify": 0,\n    "customer_prefix": "",\n    "customer_suffix": "",\n    "customer_taxvat": "",\n    "discount_amount": "",\n    "discount_canceled": "",\n    "discount_description": "",\n    "discount_invoiced": "",\n    "discount_refunded": "",\n    "discount_tax_compensation_amount": "",\n    "discount_tax_compensation_invoiced": "",\n    "discount_tax_compensation_refunded": "",\n    "edit_increment": 0,\n    "email_sent": 0,\n    "entity_id": 0,\n    "ext_customer_id": "",\n    "ext_order_id": "",\n    "extension_attributes": {\n      "amazon_order_reference_id": "",\n      "applied_taxes": [\n        {\n          "amount": "",\n          "base_amount": "",\n          "code": "",\n          "extension_attributes": {\n            "rates": [\n              {\n                "code": "",\n                "extension_attributes": {},\n                "percent": "",\n                "title": ""\n              }\n            ]\n          },\n          "percent": "",\n          "title": ""\n        }\n      ],\n      "base_customer_balance_amount": "",\n      "base_customer_balance_invoiced": "",\n      "base_customer_balance_refunded": "",\n      "base_customer_balance_total_refunded": "",\n      "base_gift_cards_amount": "",\n      "base_gift_cards_invoiced": "",\n      "base_gift_cards_refunded": "",\n      "base_reward_currency_amount": "",\n      "company_order_attributes": {\n        "company_id": 0,\n        "company_name": "",\n        "extension_attributes": {},\n        "order_id": 0\n      },\n      "converting_from_quote": false,\n      "customer_balance_amount": "",\n      "customer_balance_invoiced": "",\n      "customer_balance_refunded": "",\n      "customer_balance_total_refunded": "",\n      "gift_cards": [\n        {\n          "amount": "",\n          "base_amount": "",\n          "code": "",\n          "id": 0\n        }\n      ],\n      "gift_cards_amount": "",\n      "gift_cards_invoiced": "",\n      "gift_cards_refunded": "",\n      "gift_message": {\n        "customer_id": 0,\n        "extension_attributes": {\n          "entity_id": "",\n          "entity_type": "",\n          "wrapping_add_printed_card": false,\n          "wrapping_allow_gift_receipt": false,\n          "wrapping_id": 0\n        },\n        "gift_message_id": 0,\n        "message": "",\n        "recipient": "",\n        "sender": ""\n      },\n      "gw_add_card": "",\n      "gw_allow_gift_receipt": "",\n      "gw_base_price": "",\n      "gw_base_price_incl_tax": "",\n      "gw_base_price_invoiced": "",\n      "gw_base_price_refunded": "",\n      "gw_base_tax_amount": "",\n      "gw_base_tax_amount_invoiced": "",\n      "gw_base_tax_amount_refunded": "",\n      "gw_card_base_price": "",\n      "gw_card_base_price_incl_tax": "",\n      "gw_card_base_price_invoiced": "",\n      "gw_card_base_price_refunded": "",\n      "gw_card_base_tax_amount": "",\n      "gw_card_base_tax_invoiced": "",\n      "gw_card_base_tax_refunded": "",\n      "gw_card_price": "",\n      "gw_card_price_incl_tax": "",\n      "gw_card_price_invoiced": "",\n      "gw_card_price_refunded": "",\n      "gw_card_tax_amount": "",\n      "gw_card_tax_invoiced": "",\n      "gw_card_tax_refunded": "",\n      "gw_id": "",\n      "gw_items_base_price": "",\n      "gw_items_base_price_incl_tax": "",\n      "gw_items_base_price_invoiced": "",\n      "gw_items_base_price_refunded": "",\n      "gw_items_base_tax_amount": "",\n      "gw_items_base_tax_invoiced": "",\n      "gw_items_base_tax_refunded": "",\n      "gw_items_price": "",\n      "gw_items_price_incl_tax": "",\n      "gw_items_price_invoiced": "",\n      "gw_items_price_refunded": "",\n      "gw_items_tax_amount": "",\n      "gw_items_tax_invoiced": "",\n      "gw_items_tax_refunded": "",\n      "gw_price": "",\n      "gw_price_incl_tax": "",\n      "gw_price_invoiced": "",\n      "gw_price_refunded": "",\n      "gw_tax_amount": "",\n      "gw_tax_amount_invoiced": "",\n      "gw_tax_amount_refunded": "",\n      "item_applied_taxes": [\n        {\n          "applied_taxes": [\n            {}\n          ],\n          "associated_item_id": 0,\n          "extension_attributes": {},\n          "item_id": 0,\n          "type": ""\n        }\n      ],\n      "payment_additional_info": [\n        {\n          "key": "",\n          "value": ""\n        }\n      ],\n      "reward_currency_amount": "",\n      "reward_points_balance": 0,\n      "shipping_assignments": [\n        {\n          "extension_attributes": {},\n          "items": [\n            {\n              "additional_data": "",\n              "amount_refunded": "",\n              "applied_rule_ids": "",\n              "base_amount_refunded": "",\n              "base_cost": "",\n              "base_discount_amount": "",\n              "base_discount_invoiced": "",\n              "base_discount_refunded": "",\n              "base_discount_tax_compensation_amount": "",\n              "base_discount_tax_compensation_invoiced": "",\n              "base_discount_tax_compensation_refunded": "",\n              "base_original_price": "",\n              "base_price": "",\n              "base_price_incl_tax": "",\n              "base_row_invoiced": "",\n              "base_row_total": "",\n              "base_row_total_incl_tax": "",\n              "base_tax_amount": "",\n              "base_tax_before_discount": "",\n              "base_tax_invoiced": "",\n              "base_tax_refunded": "",\n              "base_weee_tax_applied_amount": "",\n              "base_weee_tax_applied_row_amnt": "",\n              "base_weee_tax_disposition": "",\n              "base_weee_tax_row_disposition": "",\n              "created_at": "",\n              "description": "",\n              "discount_amount": "",\n              "discount_invoiced": "",\n              "discount_percent": "",\n              "discount_refunded": "",\n              "discount_tax_compensation_amount": "",\n              "discount_tax_compensation_canceled": "",\n              "discount_tax_compensation_invoiced": "",\n              "discount_tax_compensation_refunded": "",\n              "event_id": 0,\n              "ext_order_item_id": "",\n              "extension_attributes": {\n                "gift_message": {},\n                "gw_base_price": "",\n                "gw_base_price_invoiced": "",\n                "gw_base_price_refunded": "",\n                "gw_base_tax_amount": "",\n                "gw_base_tax_amount_invoiced": "",\n                "gw_base_tax_amount_refunded": "",\n                "gw_id": "",\n                "gw_price": "",\n                "gw_price_invoiced": "",\n                "gw_price_refunded": "",\n                "gw_tax_amount": "",\n                "gw_tax_amount_invoiced": "",\n                "gw_tax_amount_refunded": "",\n                "invoice_text_codes": [],\n                "tax_codes": [],\n                "vertex_tax_codes": []\n              },\n              "free_shipping": 0,\n              "gw_base_price": "",\n              "gw_base_price_invoiced": "",\n              "gw_base_price_refunded": "",\n              "gw_base_tax_amount": "",\n              "gw_base_tax_amount_invoiced": "",\n              "gw_base_tax_amount_refunded": "",\n              "gw_id": 0,\n              "gw_price": "",\n              "gw_price_invoiced": "",\n              "gw_price_refunded": "",\n              "gw_tax_amount": "",\n              "gw_tax_amount_invoiced": "",\n              "gw_tax_amount_refunded": "",\n              "is_qty_decimal": 0,\n              "is_virtual": 0,\n              "item_id": 0,\n              "locked_do_invoice": 0,\n              "locked_do_ship": 0,\n              "name": "",\n              "no_discount": 0,\n              "order_id": 0,\n              "original_price": "",\n              "parent_item": "",\n              "parent_item_id": 0,\n              "price": "",\n              "price_incl_tax": "",\n              "product_id": 0,\n              "product_option": {\n                "extension_attributes": {\n                  "bundle_options": [\n                    {\n                      "extension_attributes": {},\n                      "option_id": 0,\n                      "option_qty": 0,\n                      "option_selections": []\n                    }\n                  ],\n                  "configurable_item_options": [\n                    {\n                      "extension_attributes": {},\n                      "option_id": "",\n                      "option_value": 0\n                    }\n                  ],\n                  "custom_options": [\n                    {\n                      "extension_attributes": {\n                        "file_info": {\n                          "base64_encoded_data": "",\n                          "name": "",\n                          "type": ""\n                        }\n                      },\n                      "option_id": "",\n                      "option_value": ""\n                    }\n                  ],\n                  "downloadable_option": {\n                    "downloadable_links": []\n                  },\n                  "giftcard_item_option": {\n                    "custom_giftcard_amount": "",\n                    "extension_attributes": {},\n                    "giftcard_amount": "",\n                    "giftcard_message": "",\n                    "giftcard_recipient_email": "",\n                    "giftcard_recipient_name": "",\n                    "giftcard_sender_email": "",\n                    "giftcard_sender_name": ""\n                  }\n                }\n              },\n              "product_type": "",\n              "qty_backordered": "",\n              "qty_canceled": "",\n              "qty_invoiced": "",\n              "qty_ordered": "",\n              "qty_refunded": "",\n              "qty_returned": "",\n              "qty_shipped": "",\n              "quote_item_id": 0,\n              "row_invoiced": "",\n              "row_total": "",\n              "row_total_incl_tax": "",\n              "row_weight": "",\n              "sku": "",\n              "store_id": 0,\n              "tax_amount": "",\n              "tax_before_discount": "",\n              "tax_canceled": "",\n              "tax_invoiced": "",\n              "tax_percent": "",\n              "tax_refunded": "",\n              "updated_at": "",\n              "weee_tax_applied": "",\n              "weee_tax_applied_amount": "",\n              "weee_tax_applied_row_amount": "",\n              "weee_tax_disposition": "",\n              "weee_tax_row_disposition": "",\n              "weight": ""\n            }\n          ],\n          "shipping": {\n            "address": {},\n            "extension_attributes": {\n              "collection_point": {\n                "city": "",\n                "collection_point_id": "",\n                "country": "",\n                "name": "",\n                "postcode": "",\n                "recipient_address_id": 0,\n                "region": "",\n                "street": []\n              },\n              "ext_order_id": "",\n              "shipping_experience": {\n                "code": "",\n                "cost": "",\n                "label": ""\n              }\n            },\n            "method": "",\n            "total": {\n              "base_shipping_amount": "",\n              "base_shipping_canceled": "",\n              "base_shipping_discount_amount": "",\n              "base_shipping_discount_tax_compensation_amnt": "",\n              "base_shipping_incl_tax": "",\n              "base_shipping_invoiced": "",\n              "base_shipping_refunded": "",\n              "base_shipping_tax_amount": "",\n              "base_shipping_tax_refunded": "",\n              "extension_attributes": {},\n              "shipping_amount": "",\n              "shipping_canceled": "",\n              "shipping_discount_amount": "",\n              "shipping_discount_tax_compensation_amount": "",\n              "shipping_incl_tax": "",\n              "shipping_invoiced": "",\n              "shipping_refunded": "",\n              "shipping_tax_amount": "",\n              "shipping_tax_refunded": ""\n            }\n          },\n          "stock_id": 0\n        }\n      ]\n    },\n    "forced_shipment_with_invoice": 0,\n    "global_currency_code": "",\n    "grand_total": "",\n    "hold_before_state": "",\n    "hold_before_status": "",\n    "increment_id": "",\n    "is_virtual": 0,\n    "items": [\n      {}\n    ],\n    "order_currency_code": "",\n    "original_increment_id": "",\n    "payment": {\n      "account_status": "",\n      "additional_data": "",\n      "additional_information": [],\n      "address_status": "",\n      "amount_authorized": "",\n      "amount_canceled": "",\n      "amount_ordered": "",\n      "amount_paid": "",\n      "amount_refunded": "",\n      "anet_trans_method": "",\n      "base_amount_authorized": "",\n      "base_amount_canceled": "",\n      "base_amount_ordered": "",\n      "base_amount_paid": "",\n      "base_amount_paid_online": "",\n      "base_amount_refunded": "",\n      "base_amount_refunded_online": "",\n      "base_shipping_amount": "",\n      "base_shipping_captured": "",\n      "base_shipping_refunded": "",\n      "cc_approval": "",\n      "cc_avs_status": "",\n      "cc_cid_status": "",\n      "cc_debug_request_body": "",\n      "cc_debug_response_body": "",\n      "cc_debug_response_serialized": "",\n      "cc_exp_month": "",\n      "cc_exp_year": "",\n      "cc_last4": "",\n      "cc_number_enc": "",\n      "cc_owner": "",\n      "cc_secure_verify": "",\n      "cc_ss_issue": "",\n      "cc_ss_start_month": "",\n      "cc_ss_start_year": "",\n      "cc_status": "",\n      "cc_status_description": "",\n      "cc_trans_id": "",\n      "cc_type": "",\n      "echeck_account_name": "",\n      "echeck_account_type": "",\n      "echeck_bank_name": "",\n      "echeck_routing_number": "",\n      "echeck_type": "",\n      "entity_id": 0,\n      "extension_attributes": {\n        "vault_payment_token": {\n          "created_at": "",\n          "customer_id": 0,\n          "entity_id": 0,\n          "expires_at": "",\n          "gateway_token": "",\n          "is_active": false,\n          "is_visible": false,\n          "payment_method_code": "",\n          "public_hash": "",\n          "token_details": "",\n          "type": ""\n        }\n      },\n      "last_trans_id": "",\n      "method": "",\n      "parent_id": 0,\n      "po_number": "",\n      "protection_eligibility": "",\n      "quote_payment_id": 0,\n      "shipping_amount": "",\n      "shipping_captured": "",\n      "shipping_refunded": ""\n    },\n    "payment_auth_expiration": 0,\n    "payment_authorization_amount": "",\n    "protect_code": "",\n    "quote_address_id": 0,\n    "quote_id": 0,\n    "relation_child_id": "",\n    "relation_child_real_id": "",\n    "relation_parent_id": "",\n    "relation_parent_real_id": "",\n    "remote_ip": "",\n    "shipping_amount": "",\n    "shipping_canceled": "",\n    "shipping_description": "",\n    "shipping_discount_amount": "",\n    "shipping_discount_tax_compensation_amount": "",\n    "shipping_incl_tax": "",\n    "shipping_invoiced": "",\n    "shipping_refunded": "",\n    "shipping_tax_amount": "",\n    "shipping_tax_refunded": "",\n    "state": "",\n    "status": "",\n    "status_histories": [\n      {\n        "comment": "",\n        "created_at": "",\n        "entity_id": 0,\n        "entity_name": "",\n        "extension_attributes": {},\n        "is_customer_notified": 0,\n        "is_visible_on_front": 0,\n        "parent_id": 0,\n        "status": ""\n      }\n    ],\n    "store_currency_code": "",\n    "store_id": 0,\n    "store_name": "",\n    "store_to_base_rate": "",\n    "store_to_order_rate": "",\n    "subtotal": "",\n    "subtotal_canceled": "",\n    "subtotal_incl_tax": "",\n    "subtotal_invoiced": "",\n    "subtotal_refunded": "",\n    "tax_amount": "",\n    "tax_canceled": "",\n    "tax_invoiced": "",\n    "tax_refunded": "",\n    "total_canceled": "",\n    "total_due": "",\n    "total_invoiced": "",\n    "total_item_count": 0,\n    "total_offline_refunded": "",\n    "total_online_refunded": "",\n    "total_paid": "",\n    "total_qty_ordered": "",\n    "total_refunded": "",\n    "updated_at": "",\n    "weight": "",\n    "x_forwarded_for": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/orders/create
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["entity": [
    "adjustment_negative": "",
    "adjustment_positive": "",
    "applied_rule_ids": "",
    "base_adjustment_negative": "",
    "base_adjustment_positive": "",
    "base_currency_code": "",
    "base_discount_amount": "",
    "base_discount_canceled": "",
    "base_discount_invoiced": "",
    "base_discount_refunded": "",
    "base_discount_tax_compensation_amount": "",
    "base_discount_tax_compensation_invoiced": "",
    "base_discount_tax_compensation_refunded": "",
    "base_grand_total": "",
    "base_shipping_amount": "",
    "base_shipping_canceled": "",
    "base_shipping_discount_amount": "",
    "base_shipping_discount_tax_compensation_amnt": "",
    "base_shipping_incl_tax": "",
    "base_shipping_invoiced": "",
    "base_shipping_refunded": "",
    "base_shipping_tax_amount": "",
    "base_shipping_tax_refunded": "",
    "base_subtotal": "",
    "base_subtotal_canceled": "",
    "base_subtotal_incl_tax": "",
    "base_subtotal_invoiced": "",
    "base_subtotal_refunded": "",
    "base_tax_amount": "",
    "base_tax_canceled": "",
    "base_tax_invoiced": "",
    "base_tax_refunded": "",
    "base_to_global_rate": "",
    "base_to_order_rate": "",
    "base_total_canceled": "",
    "base_total_due": "",
    "base_total_invoiced": "",
    "base_total_invoiced_cost": "",
    "base_total_offline_refunded": "",
    "base_total_online_refunded": "",
    "base_total_paid": "",
    "base_total_qty_ordered": "",
    "base_total_refunded": "",
    "billing_address": [
      "address_type": "",
      "city": "",
      "company": "",
      "country_id": "",
      "customer_address_id": 0,
      "customer_id": 0,
      "email": "",
      "entity_id": 0,
      "extension_attributes": ["checkout_fields": [
          [
            "attribute_code": "",
            "value": ""
          ]
        ]],
      "fax": "",
      "firstname": "",
      "lastname": "",
      "middlename": "",
      "parent_id": 0,
      "postcode": "",
      "prefix": "",
      "region": "",
      "region_code": "",
      "region_id": 0,
      "street": [],
      "suffix": "",
      "telephone": "",
      "vat_id": "",
      "vat_is_valid": 0,
      "vat_request_date": "",
      "vat_request_id": "",
      "vat_request_success": 0
    ],
    "billing_address_id": 0,
    "can_ship_partially": 0,
    "can_ship_partially_item": 0,
    "coupon_code": "",
    "created_at": "",
    "customer_dob": "",
    "customer_email": "",
    "customer_firstname": "",
    "customer_gender": 0,
    "customer_group_id": 0,
    "customer_id": 0,
    "customer_is_guest": 0,
    "customer_lastname": "",
    "customer_middlename": "",
    "customer_note": "",
    "customer_note_notify": 0,
    "customer_prefix": "",
    "customer_suffix": "",
    "customer_taxvat": "",
    "discount_amount": "",
    "discount_canceled": "",
    "discount_description": "",
    "discount_invoiced": "",
    "discount_refunded": "",
    "discount_tax_compensation_amount": "",
    "discount_tax_compensation_invoiced": "",
    "discount_tax_compensation_refunded": "",
    "edit_increment": 0,
    "email_sent": 0,
    "entity_id": 0,
    "ext_customer_id": "",
    "ext_order_id": "",
    "extension_attributes": [
      "amazon_order_reference_id": "",
      "applied_taxes": [
        [
          "amount": "",
          "base_amount": "",
          "code": "",
          "extension_attributes": ["rates": [
              [
                "code": "",
                "extension_attributes": [],
                "percent": "",
                "title": ""
              ]
            ]],
          "percent": "",
          "title": ""
        ]
      ],
      "base_customer_balance_amount": "",
      "base_customer_balance_invoiced": "",
      "base_customer_balance_refunded": "",
      "base_customer_balance_total_refunded": "",
      "base_gift_cards_amount": "",
      "base_gift_cards_invoiced": "",
      "base_gift_cards_refunded": "",
      "base_reward_currency_amount": "",
      "company_order_attributes": [
        "company_id": 0,
        "company_name": "",
        "extension_attributes": [],
        "order_id": 0
      ],
      "converting_from_quote": false,
      "customer_balance_amount": "",
      "customer_balance_invoiced": "",
      "customer_balance_refunded": "",
      "customer_balance_total_refunded": "",
      "gift_cards": [
        [
          "amount": "",
          "base_amount": "",
          "code": "",
          "id": 0
        ]
      ],
      "gift_cards_amount": "",
      "gift_cards_invoiced": "",
      "gift_cards_refunded": "",
      "gift_message": [
        "customer_id": 0,
        "extension_attributes": [
          "entity_id": "",
          "entity_type": "",
          "wrapping_add_printed_card": false,
          "wrapping_allow_gift_receipt": false,
          "wrapping_id": 0
        ],
        "gift_message_id": 0,
        "message": "",
        "recipient": "",
        "sender": ""
      ],
      "gw_add_card": "",
      "gw_allow_gift_receipt": "",
      "gw_base_price": "",
      "gw_base_price_incl_tax": "",
      "gw_base_price_invoiced": "",
      "gw_base_price_refunded": "",
      "gw_base_tax_amount": "",
      "gw_base_tax_amount_invoiced": "",
      "gw_base_tax_amount_refunded": "",
      "gw_card_base_price": "",
      "gw_card_base_price_incl_tax": "",
      "gw_card_base_price_invoiced": "",
      "gw_card_base_price_refunded": "",
      "gw_card_base_tax_amount": "",
      "gw_card_base_tax_invoiced": "",
      "gw_card_base_tax_refunded": "",
      "gw_card_price": "",
      "gw_card_price_incl_tax": "",
      "gw_card_price_invoiced": "",
      "gw_card_price_refunded": "",
      "gw_card_tax_amount": "",
      "gw_card_tax_invoiced": "",
      "gw_card_tax_refunded": "",
      "gw_id": "",
      "gw_items_base_price": "",
      "gw_items_base_price_incl_tax": "",
      "gw_items_base_price_invoiced": "",
      "gw_items_base_price_refunded": "",
      "gw_items_base_tax_amount": "",
      "gw_items_base_tax_invoiced": "",
      "gw_items_base_tax_refunded": "",
      "gw_items_price": "",
      "gw_items_price_incl_tax": "",
      "gw_items_price_invoiced": "",
      "gw_items_price_refunded": "",
      "gw_items_tax_amount": "",
      "gw_items_tax_invoiced": "",
      "gw_items_tax_refunded": "",
      "gw_price": "",
      "gw_price_incl_tax": "",
      "gw_price_invoiced": "",
      "gw_price_refunded": "",
      "gw_tax_amount": "",
      "gw_tax_amount_invoiced": "",
      "gw_tax_amount_refunded": "",
      "item_applied_taxes": [
        [
          "applied_taxes": [[]],
          "associated_item_id": 0,
          "extension_attributes": [],
          "item_id": 0,
          "type": ""
        ]
      ],
      "payment_additional_info": [
        [
          "key": "",
          "value": ""
        ]
      ],
      "reward_currency_amount": "",
      "reward_points_balance": 0,
      "shipping_assignments": [
        [
          "extension_attributes": [],
          "items": [
            [
              "additional_data": "",
              "amount_refunded": "",
              "applied_rule_ids": "",
              "base_amount_refunded": "",
              "base_cost": "",
              "base_discount_amount": "",
              "base_discount_invoiced": "",
              "base_discount_refunded": "",
              "base_discount_tax_compensation_amount": "",
              "base_discount_tax_compensation_invoiced": "",
              "base_discount_tax_compensation_refunded": "",
              "base_original_price": "",
              "base_price": "",
              "base_price_incl_tax": "",
              "base_row_invoiced": "",
              "base_row_total": "",
              "base_row_total_incl_tax": "",
              "base_tax_amount": "",
              "base_tax_before_discount": "",
              "base_tax_invoiced": "",
              "base_tax_refunded": "",
              "base_weee_tax_applied_amount": "",
              "base_weee_tax_applied_row_amnt": "",
              "base_weee_tax_disposition": "",
              "base_weee_tax_row_disposition": "",
              "created_at": "",
              "description": "",
              "discount_amount": "",
              "discount_invoiced": "",
              "discount_percent": "",
              "discount_refunded": "",
              "discount_tax_compensation_amount": "",
              "discount_tax_compensation_canceled": "",
              "discount_tax_compensation_invoiced": "",
              "discount_tax_compensation_refunded": "",
              "event_id": 0,
              "ext_order_item_id": "",
              "extension_attributes": [
                "gift_message": [],
                "gw_base_price": "",
                "gw_base_price_invoiced": "",
                "gw_base_price_refunded": "",
                "gw_base_tax_amount": "",
                "gw_base_tax_amount_invoiced": "",
                "gw_base_tax_amount_refunded": "",
                "gw_id": "",
                "gw_price": "",
                "gw_price_invoiced": "",
                "gw_price_refunded": "",
                "gw_tax_amount": "",
                "gw_tax_amount_invoiced": "",
                "gw_tax_amount_refunded": "",
                "invoice_text_codes": [],
                "tax_codes": [],
                "vertex_tax_codes": []
              ],
              "free_shipping": 0,
              "gw_base_price": "",
              "gw_base_price_invoiced": "",
              "gw_base_price_refunded": "",
              "gw_base_tax_amount": "",
              "gw_base_tax_amount_invoiced": "",
              "gw_base_tax_amount_refunded": "",
              "gw_id": 0,
              "gw_price": "",
              "gw_price_invoiced": "",
              "gw_price_refunded": "",
              "gw_tax_amount": "",
              "gw_tax_amount_invoiced": "",
              "gw_tax_amount_refunded": "",
              "is_qty_decimal": 0,
              "is_virtual": 0,
              "item_id": 0,
              "locked_do_invoice": 0,
              "locked_do_ship": 0,
              "name": "",
              "no_discount": 0,
              "order_id": 0,
              "original_price": "",
              "parent_item": "",
              "parent_item_id": 0,
              "price": "",
              "price_incl_tax": "",
              "product_id": 0,
              "product_option": ["extension_attributes": [
                  "bundle_options": [
                    [
                      "extension_attributes": [],
                      "option_id": 0,
                      "option_qty": 0,
                      "option_selections": []
                    ]
                  ],
                  "configurable_item_options": [
                    [
                      "extension_attributes": [],
                      "option_id": "",
                      "option_value": 0
                    ]
                  ],
                  "custom_options": [
                    [
                      "extension_attributes": ["file_info": [
                          "base64_encoded_data": "",
                          "name": "",
                          "type": ""
                        ]],
                      "option_id": "",
                      "option_value": ""
                    ]
                  ],
                  "downloadable_option": ["downloadable_links": []],
                  "giftcard_item_option": [
                    "custom_giftcard_amount": "",
                    "extension_attributes": [],
                    "giftcard_amount": "",
                    "giftcard_message": "",
                    "giftcard_recipient_email": "",
                    "giftcard_recipient_name": "",
                    "giftcard_sender_email": "",
                    "giftcard_sender_name": ""
                  ]
                ]],
              "product_type": "",
              "qty_backordered": "",
              "qty_canceled": "",
              "qty_invoiced": "",
              "qty_ordered": "",
              "qty_refunded": "",
              "qty_returned": "",
              "qty_shipped": "",
              "quote_item_id": 0,
              "row_invoiced": "",
              "row_total": "",
              "row_total_incl_tax": "",
              "row_weight": "",
              "sku": "",
              "store_id": 0,
              "tax_amount": "",
              "tax_before_discount": "",
              "tax_canceled": "",
              "tax_invoiced": "",
              "tax_percent": "",
              "tax_refunded": "",
              "updated_at": "",
              "weee_tax_applied": "",
              "weee_tax_applied_amount": "",
              "weee_tax_applied_row_amount": "",
              "weee_tax_disposition": "",
              "weee_tax_row_disposition": "",
              "weight": ""
            ]
          ],
          "shipping": [
            "address": [],
            "extension_attributes": [
              "collection_point": [
                "city": "",
                "collection_point_id": "",
                "country": "",
                "name": "",
                "postcode": "",
                "recipient_address_id": 0,
                "region": "",
                "street": []
              ],
              "ext_order_id": "",
              "shipping_experience": [
                "code": "",
                "cost": "",
                "label": ""
              ]
            ],
            "method": "",
            "total": [
              "base_shipping_amount": "",
              "base_shipping_canceled": "",
              "base_shipping_discount_amount": "",
              "base_shipping_discount_tax_compensation_amnt": "",
              "base_shipping_incl_tax": "",
              "base_shipping_invoiced": "",
              "base_shipping_refunded": "",
              "base_shipping_tax_amount": "",
              "base_shipping_tax_refunded": "",
              "extension_attributes": [],
              "shipping_amount": "",
              "shipping_canceled": "",
              "shipping_discount_amount": "",
              "shipping_discount_tax_compensation_amount": "",
              "shipping_incl_tax": "",
              "shipping_invoiced": "",
              "shipping_refunded": "",
              "shipping_tax_amount": "",
              "shipping_tax_refunded": ""
            ]
          ],
          "stock_id": 0
        ]
      ]
    ],
    "forced_shipment_with_invoice": 0,
    "global_currency_code": "",
    "grand_total": "",
    "hold_before_state": "",
    "hold_before_status": "",
    "increment_id": "",
    "is_virtual": 0,
    "items": [[]],
    "order_currency_code": "",
    "original_increment_id": "",
    "payment": [
      "account_status": "",
      "additional_data": "",
      "additional_information": [],
      "address_status": "",
      "amount_authorized": "",
      "amount_canceled": "",
      "amount_ordered": "",
      "amount_paid": "",
      "amount_refunded": "",
      "anet_trans_method": "",
      "base_amount_authorized": "",
      "base_amount_canceled": "",
      "base_amount_ordered": "",
      "base_amount_paid": "",
      "base_amount_paid_online": "",
      "base_amount_refunded": "",
      "base_amount_refunded_online": "",
      "base_shipping_amount": "",
      "base_shipping_captured": "",
      "base_shipping_refunded": "",
      "cc_approval": "",
      "cc_avs_status": "",
      "cc_cid_status": "",
      "cc_debug_request_body": "",
      "cc_debug_response_body": "",
      "cc_debug_response_serialized": "",
      "cc_exp_month": "",
      "cc_exp_year": "",
      "cc_last4": "",
      "cc_number_enc": "",
      "cc_owner": "",
      "cc_secure_verify": "",
      "cc_ss_issue": "",
      "cc_ss_start_month": "",
      "cc_ss_start_year": "",
      "cc_status": "",
      "cc_status_description": "",
      "cc_trans_id": "",
      "cc_type": "",
      "echeck_account_name": "",
      "echeck_account_type": "",
      "echeck_bank_name": "",
      "echeck_routing_number": "",
      "echeck_type": "",
      "entity_id": 0,
      "extension_attributes": ["vault_payment_token": [
          "created_at": "",
          "customer_id": 0,
          "entity_id": 0,
          "expires_at": "",
          "gateway_token": "",
          "is_active": false,
          "is_visible": false,
          "payment_method_code": "",
          "public_hash": "",
          "token_details": "",
          "type": ""
        ]],
      "last_trans_id": "",
      "method": "",
      "parent_id": 0,
      "po_number": "",
      "protection_eligibility": "",
      "quote_payment_id": 0,
      "shipping_amount": "",
      "shipping_captured": "",
      "shipping_refunded": ""
    ],
    "payment_auth_expiration": 0,
    "payment_authorization_amount": "",
    "protect_code": "",
    "quote_address_id": 0,
    "quote_id": 0,
    "relation_child_id": "",
    "relation_child_real_id": "",
    "relation_parent_id": "",
    "relation_parent_real_id": "",
    "remote_ip": "",
    "shipping_amount": "",
    "shipping_canceled": "",
    "shipping_description": "",
    "shipping_discount_amount": "",
    "shipping_discount_tax_compensation_amount": "",
    "shipping_incl_tax": "",
    "shipping_invoiced": "",
    "shipping_refunded": "",
    "shipping_tax_amount": "",
    "shipping_tax_refunded": "",
    "state": "",
    "status": "",
    "status_histories": [
      [
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "entity_name": "",
        "extension_attributes": [],
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0,
        "status": ""
      ]
    ],
    "store_currency_code": "",
    "store_id": 0,
    "store_name": "",
    "store_to_base_rate": "",
    "store_to_order_rate": "",
    "subtotal": "",
    "subtotal_canceled": "",
    "subtotal_incl_tax": "",
    "subtotal_invoiced": "",
    "subtotal_refunded": "",
    "tax_amount": "",
    "tax_canceled": "",
    "tax_invoiced": "",
    "tax_refunded": "",
    "total_canceled": "",
    "total_due": "",
    "total_invoiced": "",
    "total_item_count": 0,
    "total_offline_refunded": "",
    "total_online_refunded": "",
    "total_paid": "",
    "total_qty_ordered": "",
    "total_refunded": "",
    "updated_at": "",
    "weight": "",
    "x_forwarded_for": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/orders/create")! 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 orders-items
{{baseUrl}}/V1/orders/items
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/orders/items");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/orders/items")
require "http/client"

url = "{{baseUrl}}/V1/orders/items"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/orders/items"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/orders/items");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/orders/items"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/orders/items HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/orders/items")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/orders/items"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/orders/items")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/orders/items")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/orders/items');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders/items'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/orders/items';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/orders/items',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/orders/items")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/orders/items',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders/items'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/orders/items');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders/items'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/orders/items';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/orders/items"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/orders/items" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/orders/items",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/orders/items');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/orders/items');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/orders/items');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/orders/items' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/orders/items' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/orders/items")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/orders/items"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/orders/items"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/orders/items")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/orders/items') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/orders/items";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/orders/items
http GET {{baseUrl}}/V1/orders/items
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/orders/items
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/orders/items")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET orders-items-{id}
{{baseUrl}}/V1/orders/items/:id
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/orders/items/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/orders/items/:id")
require "http/client"

url = "{{baseUrl}}/V1/orders/items/:id"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/orders/items/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/orders/items/:id");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/orders/items/:id"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/orders/items/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/orders/items/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/orders/items/:id"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/orders/items/:id")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/orders/items/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/orders/items/:id');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders/items/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/orders/items/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/orders/items/:id',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/orders/items/:id")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/orders/items/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders/items/:id'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/orders/items/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/orders/items/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/orders/items/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/orders/items/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/orders/items/:id" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/orders/items/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/orders/items/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/orders/items/:id');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/orders/items/:id');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/orders/items/:id' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/orders/items/:id' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/orders/items/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/orders/items/:id"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/orders/items/:id"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/orders/items/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/orders/items/:id') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/orders/items/:id";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/orders/items/:id
http GET {{baseUrl}}/V1/orders/items/:id
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/orders/items/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/orders/items/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST products (POST)
{{baseUrl}}/V1/products
BODY json

{
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {
          "attribute_id": "",
          "extension_attributes": {},
          "id": 0,
          "is_use_default": false,
          "label": "",
          "position": 0,
          "product_id": 0,
          "values": [
            {
              "extension_attributes": {},
              "value_index": 0
            }
          ]
        }
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  },
  "saveOptions": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products" {:content-type :json
                                                        :form-params {:product {:attribute_set_id 0
                                                                                :created_at ""
                                                                                :custom_attributes [{:attribute_code ""
                                                                                                     :value ""}]
                                                                                :extension_attributes {:bundle_product_options [{:extension_attributes {}
                                                                                                                                 :option_id 0
                                                                                                                                 :position 0
                                                                                                                                 :product_links [{:can_change_quantity 0
                                                                                                                                                  :extension_attributes {}
                                                                                                                                                  :id ""
                                                                                                                                                  :is_default false
                                                                                                                                                  :option_id 0
                                                                                                                                                  :position 0
                                                                                                                                                  :price ""
                                                                                                                                                  :price_type 0
                                                                                                                                                  :qty ""
                                                                                                                                                  :sku ""}]
                                                                                                                                 :required false
                                                                                                                                 :sku ""
                                                                                                                                 :title ""
                                                                                                                                 :type ""}]
                                                                                                       :category_links [{:category_id ""
                                                                                                                         :extension_attributes {}
                                                                                                                         :position 0}]
                                                                                                       :configurable_product_links []
                                                                                                       :configurable_product_options [{:attribute_id ""
                                                                                                                                       :extension_attributes {}
                                                                                                                                       :id 0
                                                                                                                                       :is_use_default false
                                                                                                                                       :label ""
                                                                                                                                       :position 0
                                                                                                                                       :product_id 0
                                                                                                                                       :values [{:extension_attributes {}
                                                                                                                                                 :value_index 0}]}]
                                                                                                       :downloadable_product_links [{:extension_attributes {}
                                                                                                                                     :id 0
                                                                                                                                     :is_shareable 0
                                                                                                                                     :link_file ""
                                                                                                                                     :link_file_content {:extension_attributes {}
                                                                                                                                                         :file_data ""
                                                                                                                                                         :name ""}
                                                                                                                                     :link_type ""
                                                                                                                                     :link_url ""
                                                                                                                                     :number_of_downloads 0
                                                                                                                                     :price ""
                                                                                                                                     :sample_file ""
                                                                                                                                     :sample_file_content {}
                                                                                                                                     :sample_type ""
                                                                                                                                     :sample_url ""
                                                                                                                                     :sort_order 0
                                                                                                                                     :title ""}]
                                                                                                       :downloadable_product_samples [{:extension_attributes {}
                                                                                                                                       :id 0
                                                                                                                                       :sample_file ""
                                                                                                                                       :sample_file_content {}
                                                                                                                                       :sample_type ""
                                                                                                                                       :sample_url ""
                                                                                                                                       :sort_order 0
                                                                                                                                       :title ""}]
                                                                                                       :giftcard_amounts [{:attribute_id 0
                                                                                                                           :extension_attributes {}
                                                                                                                           :value ""
                                                                                                                           :website_id 0
                                                                                                                           :website_value ""}]
                                                                                                       :stock_item {:backorders 0
                                                                                                                    :enable_qty_increments false
                                                                                                                    :extension_attributes {}
                                                                                                                    :is_decimal_divided false
                                                                                                                    :is_in_stock false
                                                                                                                    :is_qty_decimal false
                                                                                                                    :item_id 0
                                                                                                                    :low_stock_date ""
                                                                                                                    :manage_stock false
                                                                                                                    :max_sale_qty ""
                                                                                                                    :min_qty ""
                                                                                                                    :min_sale_qty ""
                                                                                                                    :notify_stock_qty ""
                                                                                                                    :product_id 0
                                                                                                                    :qty ""
                                                                                                                    :qty_increments ""
                                                                                                                    :show_default_notification_message false
                                                                                                                    :stock_id 0
                                                                                                                    :stock_status_changed_auto 0
                                                                                                                    :use_config_backorders false
                                                                                                                    :use_config_enable_qty_inc false
                                                                                                                    :use_config_manage_stock false
                                                                                                                    :use_config_max_sale_qty false
                                                                                                                    :use_config_min_qty false
                                                                                                                    :use_config_min_sale_qty 0
                                                                                                                    :use_config_notify_stock_qty false
                                                                                                                    :use_config_qty_increments false}
                                                                                                       :website_ids []}
                                                                                :id 0
                                                                                :media_gallery_entries [{:content {:base64_encoded_data ""
                                                                                                                   :name ""
                                                                                                                   :type ""}
                                                                                                         :disabled false
                                                                                                         :extension_attributes {:video_content {:media_type ""
                                                                                                                                                :video_description ""
                                                                                                                                                :video_metadata ""
                                                                                                                                                :video_provider ""
                                                                                                                                                :video_title ""
                                                                                                                                                :video_url ""}}
                                                                                                         :file ""
                                                                                                         :id 0
                                                                                                         :label ""
                                                                                                         :media_type ""
                                                                                                         :position 0
                                                                                                         :types []}]
                                                                                :name ""
                                                                                :options [{:extension_attributes {:vertex_flex_field ""}
                                                                                           :file_extension ""
                                                                                           :image_size_x 0
                                                                                           :image_size_y 0
                                                                                           :is_require false
                                                                                           :max_characters 0
                                                                                           :option_id 0
                                                                                           :price ""
                                                                                           :price_type ""
                                                                                           :product_sku ""
                                                                                           :sku ""
                                                                                           :sort_order 0
                                                                                           :title ""
                                                                                           :type ""
                                                                                           :values [{:option_type_id 0
                                                                                                     :price ""
                                                                                                     :price_type ""
                                                                                                     :sku ""
                                                                                                     :sort_order 0
                                                                                                     :title ""}]}]
                                                                                :price ""
                                                                                :product_links [{:extension_attributes {:qty ""}
                                                                                                 :link_type ""
                                                                                                 :linked_product_sku ""
                                                                                                 :linked_product_type ""
                                                                                                 :position 0
                                                                                                 :sku ""}]
                                                                                :sku ""
                                                                                :status 0
                                                                                :tier_prices [{:customer_group_id 0
                                                                                               :extension_attributes {:percentage_value ""
                                                                                                                      :website_id 0}
                                                                                               :qty ""
                                                                                               :value ""}]
                                                                                :type_id ""
                                                                                :updated_at ""
                                                                                :visibility 0
                                                                                :weight ""}
                                                                      :saveOptions false}})
require "http/client"

url = "{{baseUrl}}/V1/products"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": 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}}/V1/products"),
    Content = new StringContent("{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": 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}}/V1/products");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products"

	payload := strings.NewReader("{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 5402

{
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {
          "attribute_id": "",
          "extension_attributes": {},
          "id": 0,
          "is_use_default": false,
          "label": "",
          "position": 0,
          "product_id": 0,
          "values": [
            {
              "extension_attributes": {},
              "value_index": 0
            }
          ]
        }
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  },
  "saveOptions": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": 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  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products")
  .header("content-type", "application/json")
  .body("{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}")
  .asString();
const data = JSON.stringify({
  product: {
    attribute_set_id: 0,
    created_at: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    extension_attributes: {
      bundle_product_options: [
        {
          extension_attributes: {},
          option_id: 0,
          position: 0,
          product_links: [
            {
              can_change_quantity: 0,
              extension_attributes: {},
              id: '',
              is_default: false,
              option_id: 0,
              position: 0,
              price: '',
              price_type: 0,
              qty: '',
              sku: ''
            }
          ],
          required: false,
          sku: '',
          title: '',
          type: ''
        }
      ],
      category_links: [
        {
          category_id: '',
          extension_attributes: {},
          position: 0
        }
      ],
      configurable_product_links: [],
      configurable_product_options: [
        {
          attribute_id: '',
          extension_attributes: {},
          id: 0,
          is_use_default: false,
          label: '',
          position: 0,
          product_id: 0,
          values: [
            {
              extension_attributes: {},
              value_index: 0
            }
          ]
        }
      ],
      downloadable_product_links: [
        {
          extension_attributes: {},
          id: 0,
          is_shareable: 0,
          link_file: '',
          link_file_content: {
            extension_attributes: {},
            file_data: '',
            name: ''
          },
          link_type: '',
          link_url: '',
          number_of_downloads: 0,
          price: '',
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      downloadable_product_samples: [
        {
          extension_attributes: {},
          id: 0,
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      giftcard_amounts: [
        {
          attribute_id: 0,
          extension_attributes: {},
          value: '',
          website_id: 0,
          website_value: ''
        }
      ],
      stock_item: {
        backorders: 0,
        enable_qty_increments: false,
        extension_attributes: {},
        is_decimal_divided: false,
        is_in_stock: false,
        is_qty_decimal: false,
        item_id: 0,
        low_stock_date: '',
        manage_stock: false,
        max_sale_qty: '',
        min_qty: '',
        min_sale_qty: '',
        notify_stock_qty: '',
        product_id: 0,
        qty: '',
        qty_increments: '',
        show_default_notification_message: false,
        stock_id: 0,
        stock_status_changed_auto: 0,
        use_config_backorders: false,
        use_config_enable_qty_inc: false,
        use_config_manage_stock: false,
        use_config_max_sale_qty: false,
        use_config_min_qty: false,
        use_config_min_sale_qty: 0,
        use_config_notify_stock_qty: false,
        use_config_qty_increments: false
      },
      website_ids: []
    },
    id: 0,
    media_gallery_entries: [
      {
        content: {
          base64_encoded_data: '',
          name: '',
          type: ''
        },
        disabled: false,
        extension_attributes: {
          video_content: {
            media_type: '',
            video_description: '',
            video_metadata: '',
            video_provider: '',
            video_title: '',
            video_url: ''
          }
        },
        file: '',
        id: 0,
        label: '',
        media_type: '',
        position: 0,
        types: []
      }
    ],
    name: '',
    options: [
      {
        extension_attributes: {
          vertex_flex_field: ''
        },
        file_extension: '',
        image_size_x: 0,
        image_size_y: 0,
        is_require: false,
        max_characters: 0,
        option_id: 0,
        price: '',
        price_type: '',
        product_sku: '',
        sku: '',
        sort_order: 0,
        title: '',
        type: '',
        values: [
          {
            option_type_id: 0,
            price: '',
            price_type: '',
            sku: '',
            sort_order: 0,
            title: ''
          }
        ]
      }
    ],
    price: '',
    product_links: [
      {
        extension_attributes: {
          qty: ''
        },
        link_type: '',
        linked_product_sku: '',
        linked_product_type: '',
        position: 0,
        sku: ''
      }
    ],
    sku: '',
    status: 0,
    tier_prices: [
      {
        customer_group_id: 0,
        extension_attributes: {
          percentage_value: '',
          website_id: 0
        },
        qty: '',
        value: ''
      }
    ],
    type_id: '',
    updated_at: '',
    visibility: 0,
    weight: ''
  },
  saveOptions: 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}}/V1/products');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products',
  headers: {'content-type': 'application/json'},
  data: {
    product: {
      attribute_set_id: 0,
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {
        bundle_product_options: [
          {
            extension_attributes: {},
            option_id: 0,
            position: 0,
            product_links: [
              {
                can_change_quantity: 0,
                extension_attributes: {},
                id: '',
                is_default: false,
                option_id: 0,
                position: 0,
                price: '',
                price_type: 0,
                qty: '',
                sku: ''
              }
            ],
            required: false,
            sku: '',
            title: '',
            type: ''
          }
        ],
        category_links: [{category_id: '', extension_attributes: {}, position: 0}],
        configurable_product_links: [],
        configurable_product_options: [
          {
            attribute_id: '',
            extension_attributes: {},
            id: 0,
            is_use_default: false,
            label: '',
            position: 0,
            product_id: 0,
            values: [{extension_attributes: {}, value_index: 0}]
          }
        ],
        downloadable_product_links: [
          {
            extension_attributes: {},
            id: 0,
            is_shareable: 0,
            link_file: '',
            link_file_content: {extension_attributes: {}, file_data: '', name: ''},
            link_type: '',
            link_url: '',
            number_of_downloads: 0,
            price: '',
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        downloadable_product_samples: [
          {
            extension_attributes: {},
            id: 0,
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        giftcard_amounts: [
          {
            attribute_id: 0,
            extension_attributes: {},
            value: '',
            website_id: 0,
            website_value: ''
          }
        ],
        stock_item: {
          backorders: 0,
          enable_qty_increments: false,
          extension_attributes: {},
          is_decimal_divided: false,
          is_in_stock: false,
          is_qty_decimal: false,
          item_id: 0,
          low_stock_date: '',
          manage_stock: false,
          max_sale_qty: '',
          min_qty: '',
          min_sale_qty: '',
          notify_stock_qty: '',
          product_id: 0,
          qty: '',
          qty_increments: '',
          show_default_notification_message: false,
          stock_id: 0,
          stock_status_changed_auto: 0,
          use_config_backorders: false,
          use_config_enable_qty_inc: false,
          use_config_manage_stock: false,
          use_config_max_sale_qty: false,
          use_config_min_qty: false,
          use_config_min_sale_qty: 0,
          use_config_notify_stock_qty: false,
          use_config_qty_increments: false
        },
        website_ids: []
      },
      id: 0,
      media_gallery_entries: [
        {
          content: {base64_encoded_data: '', name: '', type: ''},
          disabled: false,
          extension_attributes: {
            video_content: {
              media_type: '',
              video_description: '',
              video_metadata: '',
              video_provider: '',
              video_title: '',
              video_url: ''
            }
          },
          file: '',
          id: 0,
          label: '',
          media_type: '',
          position: 0,
          types: []
        }
      ],
      name: '',
      options: [
        {
          extension_attributes: {vertex_flex_field: ''},
          file_extension: '',
          image_size_x: 0,
          image_size_y: 0,
          is_require: false,
          max_characters: 0,
          option_id: 0,
          price: '',
          price_type: '',
          product_sku: '',
          sku: '',
          sort_order: 0,
          title: '',
          type: '',
          values: [
            {
              option_type_id: 0,
              price: '',
              price_type: '',
              sku: '',
              sort_order: 0,
              title: ''
            }
          ]
        }
      ],
      price: '',
      product_links: [
        {
          extension_attributes: {qty: ''},
          link_type: '',
          linked_product_sku: '',
          linked_product_type: '',
          position: 0,
          sku: ''
        }
      ],
      sku: '',
      status: 0,
      tier_prices: [
        {
          customer_group_id: 0,
          extension_attributes: {percentage_value: '', website_id: 0},
          qty: '',
          value: ''
        }
      ],
      type_id: '',
      updated_at: '',
      visibility: 0,
      weight: ''
    },
    saveOptions: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"product":{"attribute_set_id":0,"created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{"bundle_product_options":[{"extension_attributes":{},"option_id":0,"position":0,"product_links":[{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}],"required":false,"sku":"","title":"","type":""}],"category_links":[{"category_id":"","extension_attributes":{},"position":0}],"configurable_product_links":[],"configurable_product_options":[{"attribute_id":"","extension_attributes":{},"id":0,"is_use_default":false,"label":"","position":0,"product_id":0,"values":[{"extension_attributes":{},"value_index":0}]}],"downloadable_product_links":[{"extension_attributes":{},"id":0,"is_shareable":0,"link_file":"","link_file_content":{"extension_attributes":{},"file_data":"","name":""},"link_type":"","link_url":"","number_of_downloads":0,"price":"","sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"downloadable_product_samples":[{"extension_attributes":{},"id":0,"sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"giftcard_amounts":[{"attribute_id":0,"extension_attributes":{},"value":"","website_id":0,"website_value":""}],"stock_item":{"backorders":0,"enable_qty_increments":false,"extension_attributes":{},"is_decimal_divided":false,"is_in_stock":false,"is_qty_decimal":false,"item_id":0,"low_stock_date":"","manage_stock":false,"max_sale_qty":"","min_qty":"","min_sale_qty":"","notify_stock_qty":"","product_id":0,"qty":"","qty_increments":"","show_default_notification_message":false,"stock_id":0,"stock_status_changed_auto":0,"use_config_backorders":false,"use_config_enable_qty_inc":false,"use_config_manage_stock":false,"use_config_max_sale_qty":false,"use_config_min_qty":false,"use_config_min_sale_qty":0,"use_config_notify_stock_qty":false,"use_config_qty_increments":false},"website_ids":[]},"id":0,"media_gallery_entries":[{"content":{"base64_encoded_data":"","name":"","type":""},"disabled":false,"extension_attributes":{"video_content":{"media_type":"","video_description":"","video_metadata":"","video_provider":"","video_title":"","video_url":""}},"file":"","id":0,"label":"","media_type":"","position":0,"types":[]}],"name":"","options":[{"extension_attributes":{"vertex_flex_field":""},"file_extension":"","image_size_x":0,"image_size_y":0,"is_require":false,"max_characters":0,"option_id":0,"price":"","price_type":"","product_sku":"","sku":"","sort_order":0,"title":"","type":"","values":[{"option_type_id":0,"price":"","price_type":"","sku":"","sort_order":0,"title":""}]}],"price":"","product_links":[{"extension_attributes":{"qty":""},"link_type":"","linked_product_sku":"","linked_product_type":"","position":0,"sku":""}],"sku":"","status":0,"tier_prices":[{"customer_group_id":0,"extension_attributes":{"percentage_value":"","website_id":0},"qty":"","value":""}],"type_id":"","updated_at":"","visibility":0,"weight":""},"saveOptions":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}}/V1/products',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "product": {\n    "attribute_set_id": 0,\n    "created_at": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "extension_attributes": {\n      "bundle_product_options": [\n        {\n          "extension_attributes": {},\n          "option_id": 0,\n          "position": 0,\n          "product_links": [\n            {\n              "can_change_quantity": 0,\n              "extension_attributes": {},\n              "id": "",\n              "is_default": false,\n              "option_id": 0,\n              "position": 0,\n              "price": "",\n              "price_type": 0,\n              "qty": "",\n              "sku": ""\n            }\n          ],\n          "required": false,\n          "sku": "",\n          "title": "",\n          "type": ""\n        }\n      ],\n      "category_links": [\n        {\n          "category_id": "",\n          "extension_attributes": {},\n          "position": 0\n        }\n      ],\n      "configurable_product_links": [],\n      "configurable_product_options": [\n        {\n          "attribute_id": "",\n          "extension_attributes": {},\n          "id": 0,\n          "is_use_default": false,\n          "label": "",\n          "position": 0,\n          "product_id": 0,\n          "values": [\n            {\n              "extension_attributes": {},\n              "value_index": 0\n            }\n          ]\n        }\n      ],\n      "downloadable_product_links": [\n        {\n          "extension_attributes": {},\n          "id": 0,\n          "is_shareable": 0,\n          "link_file": "",\n          "link_file_content": {\n            "extension_attributes": {},\n            "file_data": "",\n            "name": ""\n          },\n          "link_type": "",\n          "link_url": "",\n          "number_of_downloads": 0,\n          "price": "",\n          "sample_file": "",\n          "sample_file_content": {},\n          "sample_type": "",\n          "sample_url": "",\n          "sort_order": 0,\n          "title": ""\n        }\n      ],\n      "downloadable_product_samples": [\n        {\n          "extension_attributes": {},\n          "id": 0,\n          "sample_file": "",\n          "sample_file_content": {},\n          "sample_type": "",\n          "sample_url": "",\n          "sort_order": 0,\n          "title": ""\n        }\n      ],\n      "giftcard_amounts": [\n        {\n          "attribute_id": 0,\n          "extension_attributes": {},\n          "value": "",\n          "website_id": 0,\n          "website_value": ""\n        }\n      ],\n      "stock_item": {\n        "backorders": 0,\n        "enable_qty_increments": false,\n        "extension_attributes": {},\n        "is_decimal_divided": false,\n        "is_in_stock": false,\n        "is_qty_decimal": false,\n        "item_id": 0,\n        "low_stock_date": "",\n        "manage_stock": false,\n        "max_sale_qty": "",\n        "min_qty": "",\n        "min_sale_qty": "",\n        "notify_stock_qty": "",\n        "product_id": 0,\n        "qty": "",\n        "qty_increments": "",\n        "show_default_notification_message": false,\n        "stock_id": 0,\n        "stock_status_changed_auto": 0,\n        "use_config_backorders": false,\n        "use_config_enable_qty_inc": false,\n        "use_config_manage_stock": false,\n        "use_config_max_sale_qty": false,\n        "use_config_min_qty": false,\n        "use_config_min_sale_qty": 0,\n        "use_config_notify_stock_qty": false,\n        "use_config_qty_increments": false\n      },\n      "website_ids": []\n    },\n    "id": 0,\n    "media_gallery_entries": [\n      {\n        "content": {\n          "base64_encoded_data": "",\n          "name": "",\n          "type": ""\n        },\n        "disabled": false,\n        "extension_attributes": {\n          "video_content": {\n            "media_type": "",\n            "video_description": "",\n            "video_metadata": "",\n            "video_provider": "",\n            "video_title": "",\n            "video_url": ""\n          }\n        },\n        "file": "",\n        "id": 0,\n        "label": "",\n        "media_type": "",\n        "position": 0,\n        "types": []\n      }\n    ],\n    "name": "",\n    "options": [\n      {\n        "extension_attributes": {\n          "vertex_flex_field": ""\n        },\n        "file_extension": "",\n        "image_size_x": 0,\n        "image_size_y": 0,\n        "is_require": false,\n        "max_characters": 0,\n        "option_id": 0,\n        "price": "",\n        "price_type": "",\n        "product_sku": "",\n        "sku": "",\n        "sort_order": 0,\n        "title": "",\n        "type": "",\n        "values": [\n          {\n            "option_type_id": 0,\n            "price": "",\n            "price_type": "",\n            "sku": "",\n            "sort_order": 0,\n            "title": ""\n          }\n        ]\n      }\n    ],\n    "price": "",\n    "product_links": [\n      {\n        "extension_attributes": {\n          "qty": ""\n        },\n        "link_type": "",\n        "linked_product_sku": "",\n        "linked_product_type": "",\n        "position": 0,\n        "sku": ""\n      }\n    ],\n    "sku": "",\n    "status": 0,\n    "tier_prices": [\n      {\n        "customer_group_id": 0,\n        "extension_attributes": {\n          "percentage_value": "",\n          "website_id": 0\n        },\n        "qty": "",\n        "value": ""\n      }\n    ],\n    "type_id": "",\n    "updated_at": "",\n    "visibility": 0,\n    "weight": ""\n  },\n  "saveOptions": 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  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  product: {
    attribute_set_id: 0,
    created_at: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    extension_attributes: {
      bundle_product_options: [
        {
          extension_attributes: {},
          option_id: 0,
          position: 0,
          product_links: [
            {
              can_change_quantity: 0,
              extension_attributes: {},
              id: '',
              is_default: false,
              option_id: 0,
              position: 0,
              price: '',
              price_type: 0,
              qty: '',
              sku: ''
            }
          ],
          required: false,
          sku: '',
          title: '',
          type: ''
        }
      ],
      category_links: [{category_id: '', extension_attributes: {}, position: 0}],
      configurable_product_links: [],
      configurable_product_options: [
        {
          attribute_id: '',
          extension_attributes: {},
          id: 0,
          is_use_default: false,
          label: '',
          position: 0,
          product_id: 0,
          values: [{extension_attributes: {}, value_index: 0}]
        }
      ],
      downloadable_product_links: [
        {
          extension_attributes: {},
          id: 0,
          is_shareable: 0,
          link_file: '',
          link_file_content: {extension_attributes: {}, file_data: '', name: ''},
          link_type: '',
          link_url: '',
          number_of_downloads: 0,
          price: '',
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      downloadable_product_samples: [
        {
          extension_attributes: {},
          id: 0,
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      giftcard_amounts: [
        {
          attribute_id: 0,
          extension_attributes: {},
          value: '',
          website_id: 0,
          website_value: ''
        }
      ],
      stock_item: {
        backorders: 0,
        enable_qty_increments: false,
        extension_attributes: {},
        is_decimal_divided: false,
        is_in_stock: false,
        is_qty_decimal: false,
        item_id: 0,
        low_stock_date: '',
        manage_stock: false,
        max_sale_qty: '',
        min_qty: '',
        min_sale_qty: '',
        notify_stock_qty: '',
        product_id: 0,
        qty: '',
        qty_increments: '',
        show_default_notification_message: false,
        stock_id: 0,
        stock_status_changed_auto: 0,
        use_config_backorders: false,
        use_config_enable_qty_inc: false,
        use_config_manage_stock: false,
        use_config_max_sale_qty: false,
        use_config_min_qty: false,
        use_config_min_sale_qty: 0,
        use_config_notify_stock_qty: false,
        use_config_qty_increments: false
      },
      website_ids: []
    },
    id: 0,
    media_gallery_entries: [
      {
        content: {base64_encoded_data: '', name: '', type: ''},
        disabled: false,
        extension_attributes: {
          video_content: {
            media_type: '',
            video_description: '',
            video_metadata: '',
            video_provider: '',
            video_title: '',
            video_url: ''
          }
        },
        file: '',
        id: 0,
        label: '',
        media_type: '',
        position: 0,
        types: []
      }
    ],
    name: '',
    options: [
      {
        extension_attributes: {vertex_flex_field: ''},
        file_extension: '',
        image_size_x: 0,
        image_size_y: 0,
        is_require: false,
        max_characters: 0,
        option_id: 0,
        price: '',
        price_type: '',
        product_sku: '',
        sku: '',
        sort_order: 0,
        title: '',
        type: '',
        values: [
          {
            option_type_id: 0,
            price: '',
            price_type: '',
            sku: '',
            sort_order: 0,
            title: ''
          }
        ]
      }
    ],
    price: '',
    product_links: [
      {
        extension_attributes: {qty: ''},
        link_type: '',
        linked_product_sku: '',
        linked_product_type: '',
        position: 0,
        sku: ''
      }
    ],
    sku: '',
    status: 0,
    tier_prices: [
      {
        customer_group_id: 0,
        extension_attributes: {percentage_value: '', website_id: 0},
        qty: '',
        value: ''
      }
    ],
    type_id: '',
    updated_at: '',
    visibility: 0,
    weight: ''
  },
  saveOptions: false
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products',
  headers: {'content-type': 'application/json'},
  body: {
    product: {
      attribute_set_id: 0,
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {
        bundle_product_options: [
          {
            extension_attributes: {},
            option_id: 0,
            position: 0,
            product_links: [
              {
                can_change_quantity: 0,
                extension_attributes: {},
                id: '',
                is_default: false,
                option_id: 0,
                position: 0,
                price: '',
                price_type: 0,
                qty: '',
                sku: ''
              }
            ],
            required: false,
            sku: '',
            title: '',
            type: ''
          }
        ],
        category_links: [{category_id: '', extension_attributes: {}, position: 0}],
        configurable_product_links: [],
        configurable_product_options: [
          {
            attribute_id: '',
            extension_attributes: {},
            id: 0,
            is_use_default: false,
            label: '',
            position: 0,
            product_id: 0,
            values: [{extension_attributes: {}, value_index: 0}]
          }
        ],
        downloadable_product_links: [
          {
            extension_attributes: {},
            id: 0,
            is_shareable: 0,
            link_file: '',
            link_file_content: {extension_attributes: {}, file_data: '', name: ''},
            link_type: '',
            link_url: '',
            number_of_downloads: 0,
            price: '',
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        downloadable_product_samples: [
          {
            extension_attributes: {},
            id: 0,
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        giftcard_amounts: [
          {
            attribute_id: 0,
            extension_attributes: {},
            value: '',
            website_id: 0,
            website_value: ''
          }
        ],
        stock_item: {
          backorders: 0,
          enable_qty_increments: false,
          extension_attributes: {},
          is_decimal_divided: false,
          is_in_stock: false,
          is_qty_decimal: false,
          item_id: 0,
          low_stock_date: '',
          manage_stock: false,
          max_sale_qty: '',
          min_qty: '',
          min_sale_qty: '',
          notify_stock_qty: '',
          product_id: 0,
          qty: '',
          qty_increments: '',
          show_default_notification_message: false,
          stock_id: 0,
          stock_status_changed_auto: 0,
          use_config_backorders: false,
          use_config_enable_qty_inc: false,
          use_config_manage_stock: false,
          use_config_max_sale_qty: false,
          use_config_min_qty: false,
          use_config_min_sale_qty: 0,
          use_config_notify_stock_qty: false,
          use_config_qty_increments: false
        },
        website_ids: []
      },
      id: 0,
      media_gallery_entries: [
        {
          content: {base64_encoded_data: '', name: '', type: ''},
          disabled: false,
          extension_attributes: {
            video_content: {
              media_type: '',
              video_description: '',
              video_metadata: '',
              video_provider: '',
              video_title: '',
              video_url: ''
            }
          },
          file: '',
          id: 0,
          label: '',
          media_type: '',
          position: 0,
          types: []
        }
      ],
      name: '',
      options: [
        {
          extension_attributes: {vertex_flex_field: ''},
          file_extension: '',
          image_size_x: 0,
          image_size_y: 0,
          is_require: false,
          max_characters: 0,
          option_id: 0,
          price: '',
          price_type: '',
          product_sku: '',
          sku: '',
          sort_order: 0,
          title: '',
          type: '',
          values: [
            {
              option_type_id: 0,
              price: '',
              price_type: '',
              sku: '',
              sort_order: 0,
              title: ''
            }
          ]
        }
      ],
      price: '',
      product_links: [
        {
          extension_attributes: {qty: ''},
          link_type: '',
          linked_product_sku: '',
          linked_product_type: '',
          position: 0,
          sku: ''
        }
      ],
      sku: '',
      status: 0,
      tier_prices: [
        {
          customer_group_id: 0,
          extension_attributes: {percentage_value: '', website_id: 0},
          qty: '',
          value: ''
        }
      ],
      type_id: '',
      updated_at: '',
      visibility: 0,
      weight: ''
    },
    saveOptions: 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}}/V1/products');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  product: {
    attribute_set_id: 0,
    created_at: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    extension_attributes: {
      bundle_product_options: [
        {
          extension_attributes: {},
          option_id: 0,
          position: 0,
          product_links: [
            {
              can_change_quantity: 0,
              extension_attributes: {},
              id: '',
              is_default: false,
              option_id: 0,
              position: 0,
              price: '',
              price_type: 0,
              qty: '',
              sku: ''
            }
          ],
          required: false,
          sku: '',
          title: '',
          type: ''
        }
      ],
      category_links: [
        {
          category_id: '',
          extension_attributes: {},
          position: 0
        }
      ],
      configurable_product_links: [],
      configurable_product_options: [
        {
          attribute_id: '',
          extension_attributes: {},
          id: 0,
          is_use_default: false,
          label: '',
          position: 0,
          product_id: 0,
          values: [
            {
              extension_attributes: {},
              value_index: 0
            }
          ]
        }
      ],
      downloadable_product_links: [
        {
          extension_attributes: {},
          id: 0,
          is_shareable: 0,
          link_file: '',
          link_file_content: {
            extension_attributes: {},
            file_data: '',
            name: ''
          },
          link_type: '',
          link_url: '',
          number_of_downloads: 0,
          price: '',
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      downloadable_product_samples: [
        {
          extension_attributes: {},
          id: 0,
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      giftcard_amounts: [
        {
          attribute_id: 0,
          extension_attributes: {},
          value: '',
          website_id: 0,
          website_value: ''
        }
      ],
      stock_item: {
        backorders: 0,
        enable_qty_increments: false,
        extension_attributes: {},
        is_decimal_divided: false,
        is_in_stock: false,
        is_qty_decimal: false,
        item_id: 0,
        low_stock_date: '',
        manage_stock: false,
        max_sale_qty: '',
        min_qty: '',
        min_sale_qty: '',
        notify_stock_qty: '',
        product_id: 0,
        qty: '',
        qty_increments: '',
        show_default_notification_message: false,
        stock_id: 0,
        stock_status_changed_auto: 0,
        use_config_backorders: false,
        use_config_enable_qty_inc: false,
        use_config_manage_stock: false,
        use_config_max_sale_qty: false,
        use_config_min_qty: false,
        use_config_min_sale_qty: 0,
        use_config_notify_stock_qty: false,
        use_config_qty_increments: false
      },
      website_ids: []
    },
    id: 0,
    media_gallery_entries: [
      {
        content: {
          base64_encoded_data: '',
          name: '',
          type: ''
        },
        disabled: false,
        extension_attributes: {
          video_content: {
            media_type: '',
            video_description: '',
            video_metadata: '',
            video_provider: '',
            video_title: '',
            video_url: ''
          }
        },
        file: '',
        id: 0,
        label: '',
        media_type: '',
        position: 0,
        types: []
      }
    ],
    name: '',
    options: [
      {
        extension_attributes: {
          vertex_flex_field: ''
        },
        file_extension: '',
        image_size_x: 0,
        image_size_y: 0,
        is_require: false,
        max_characters: 0,
        option_id: 0,
        price: '',
        price_type: '',
        product_sku: '',
        sku: '',
        sort_order: 0,
        title: '',
        type: '',
        values: [
          {
            option_type_id: 0,
            price: '',
            price_type: '',
            sku: '',
            sort_order: 0,
            title: ''
          }
        ]
      }
    ],
    price: '',
    product_links: [
      {
        extension_attributes: {
          qty: ''
        },
        link_type: '',
        linked_product_sku: '',
        linked_product_type: '',
        position: 0,
        sku: ''
      }
    ],
    sku: '',
    status: 0,
    tier_prices: [
      {
        customer_group_id: 0,
        extension_attributes: {
          percentage_value: '',
          website_id: 0
        },
        qty: '',
        value: ''
      }
    ],
    type_id: '',
    updated_at: '',
    visibility: 0,
    weight: ''
  },
  saveOptions: 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}}/V1/products',
  headers: {'content-type': 'application/json'},
  data: {
    product: {
      attribute_set_id: 0,
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {
        bundle_product_options: [
          {
            extension_attributes: {},
            option_id: 0,
            position: 0,
            product_links: [
              {
                can_change_quantity: 0,
                extension_attributes: {},
                id: '',
                is_default: false,
                option_id: 0,
                position: 0,
                price: '',
                price_type: 0,
                qty: '',
                sku: ''
              }
            ],
            required: false,
            sku: '',
            title: '',
            type: ''
          }
        ],
        category_links: [{category_id: '', extension_attributes: {}, position: 0}],
        configurable_product_links: [],
        configurable_product_options: [
          {
            attribute_id: '',
            extension_attributes: {},
            id: 0,
            is_use_default: false,
            label: '',
            position: 0,
            product_id: 0,
            values: [{extension_attributes: {}, value_index: 0}]
          }
        ],
        downloadable_product_links: [
          {
            extension_attributes: {},
            id: 0,
            is_shareable: 0,
            link_file: '',
            link_file_content: {extension_attributes: {}, file_data: '', name: ''},
            link_type: '',
            link_url: '',
            number_of_downloads: 0,
            price: '',
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        downloadable_product_samples: [
          {
            extension_attributes: {},
            id: 0,
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        giftcard_amounts: [
          {
            attribute_id: 0,
            extension_attributes: {},
            value: '',
            website_id: 0,
            website_value: ''
          }
        ],
        stock_item: {
          backorders: 0,
          enable_qty_increments: false,
          extension_attributes: {},
          is_decimal_divided: false,
          is_in_stock: false,
          is_qty_decimal: false,
          item_id: 0,
          low_stock_date: '',
          manage_stock: false,
          max_sale_qty: '',
          min_qty: '',
          min_sale_qty: '',
          notify_stock_qty: '',
          product_id: 0,
          qty: '',
          qty_increments: '',
          show_default_notification_message: false,
          stock_id: 0,
          stock_status_changed_auto: 0,
          use_config_backorders: false,
          use_config_enable_qty_inc: false,
          use_config_manage_stock: false,
          use_config_max_sale_qty: false,
          use_config_min_qty: false,
          use_config_min_sale_qty: 0,
          use_config_notify_stock_qty: false,
          use_config_qty_increments: false
        },
        website_ids: []
      },
      id: 0,
      media_gallery_entries: [
        {
          content: {base64_encoded_data: '', name: '', type: ''},
          disabled: false,
          extension_attributes: {
            video_content: {
              media_type: '',
              video_description: '',
              video_metadata: '',
              video_provider: '',
              video_title: '',
              video_url: ''
            }
          },
          file: '',
          id: 0,
          label: '',
          media_type: '',
          position: 0,
          types: []
        }
      ],
      name: '',
      options: [
        {
          extension_attributes: {vertex_flex_field: ''},
          file_extension: '',
          image_size_x: 0,
          image_size_y: 0,
          is_require: false,
          max_characters: 0,
          option_id: 0,
          price: '',
          price_type: '',
          product_sku: '',
          sku: '',
          sort_order: 0,
          title: '',
          type: '',
          values: [
            {
              option_type_id: 0,
              price: '',
              price_type: '',
              sku: '',
              sort_order: 0,
              title: ''
            }
          ]
        }
      ],
      price: '',
      product_links: [
        {
          extension_attributes: {qty: ''},
          link_type: '',
          linked_product_sku: '',
          linked_product_type: '',
          position: 0,
          sku: ''
        }
      ],
      sku: '',
      status: 0,
      tier_prices: [
        {
          customer_group_id: 0,
          extension_attributes: {percentage_value: '', website_id: 0},
          qty: '',
          value: ''
        }
      ],
      type_id: '',
      updated_at: '',
      visibility: 0,
      weight: ''
    },
    saveOptions: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"product":{"attribute_set_id":0,"created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{"bundle_product_options":[{"extension_attributes":{},"option_id":0,"position":0,"product_links":[{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}],"required":false,"sku":"","title":"","type":""}],"category_links":[{"category_id":"","extension_attributes":{},"position":0}],"configurable_product_links":[],"configurable_product_options":[{"attribute_id":"","extension_attributes":{},"id":0,"is_use_default":false,"label":"","position":0,"product_id":0,"values":[{"extension_attributes":{},"value_index":0}]}],"downloadable_product_links":[{"extension_attributes":{},"id":0,"is_shareable":0,"link_file":"","link_file_content":{"extension_attributes":{},"file_data":"","name":""},"link_type":"","link_url":"","number_of_downloads":0,"price":"","sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"downloadable_product_samples":[{"extension_attributes":{},"id":0,"sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"giftcard_amounts":[{"attribute_id":0,"extension_attributes":{},"value":"","website_id":0,"website_value":""}],"stock_item":{"backorders":0,"enable_qty_increments":false,"extension_attributes":{},"is_decimal_divided":false,"is_in_stock":false,"is_qty_decimal":false,"item_id":0,"low_stock_date":"","manage_stock":false,"max_sale_qty":"","min_qty":"","min_sale_qty":"","notify_stock_qty":"","product_id":0,"qty":"","qty_increments":"","show_default_notification_message":false,"stock_id":0,"stock_status_changed_auto":0,"use_config_backorders":false,"use_config_enable_qty_inc":false,"use_config_manage_stock":false,"use_config_max_sale_qty":false,"use_config_min_qty":false,"use_config_min_sale_qty":0,"use_config_notify_stock_qty":false,"use_config_qty_increments":false},"website_ids":[]},"id":0,"media_gallery_entries":[{"content":{"base64_encoded_data":"","name":"","type":""},"disabled":false,"extension_attributes":{"video_content":{"media_type":"","video_description":"","video_metadata":"","video_provider":"","video_title":"","video_url":""}},"file":"","id":0,"label":"","media_type":"","position":0,"types":[]}],"name":"","options":[{"extension_attributes":{"vertex_flex_field":""},"file_extension":"","image_size_x":0,"image_size_y":0,"is_require":false,"max_characters":0,"option_id":0,"price":"","price_type":"","product_sku":"","sku":"","sort_order":0,"title":"","type":"","values":[{"option_type_id":0,"price":"","price_type":"","sku":"","sort_order":0,"title":""}]}],"price":"","product_links":[{"extension_attributes":{"qty":""},"link_type":"","linked_product_sku":"","linked_product_type":"","position":0,"sku":""}],"sku":"","status":0,"tier_prices":[{"customer_group_id":0,"extension_attributes":{"percentage_value":"","website_id":0},"qty":"","value":""}],"type_id":"","updated_at":"","visibility":0,"weight":""},"saveOptions":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"product": @{ @"attribute_set_id": @0, @"created_at": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"extension_attributes": @{ @"bundle_product_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @0, @"position": @0, @"product_links": @[ @{ @"can_change_quantity": @0, @"extension_attributes": @{  }, @"id": @"", @"is_default": @NO, @"option_id": @0, @"position": @0, @"price": @"", @"price_type": @0, @"qty": @"", @"sku": @"" } ], @"required": @NO, @"sku": @"", @"title": @"", @"type": @"" } ], @"category_links": @[ @{ @"category_id": @"", @"extension_attributes": @{  }, @"position": @0 } ], @"configurable_product_links": @[  ], @"configurable_product_options": @[ @{ @"attribute_id": @"", @"extension_attributes": @{  }, @"id": @0, @"is_use_default": @NO, @"label": @"", @"position": @0, @"product_id": @0, @"values": @[ @{ @"extension_attributes": @{  }, @"value_index": @0 } ] } ], @"downloadable_product_links": @[ @{ @"extension_attributes": @{  }, @"id": @0, @"is_shareable": @0, @"link_file": @"", @"link_file_content": @{ @"extension_attributes": @{  }, @"file_data": @"", @"name": @"" }, @"link_type": @"", @"link_url": @"", @"number_of_downloads": @0, @"price": @"", @"sample_file": @"", @"sample_file_content": @{  }, @"sample_type": @"", @"sample_url": @"", @"sort_order": @0, @"title": @"" } ], @"downloadable_product_samples": @[ @{ @"extension_attributes": @{  }, @"id": @0, @"sample_file": @"", @"sample_file_content": @{  }, @"sample_type": @"", @"sample_url": @"", @"sort_order": @0, @"title": @"" } ], @"giftcard_amounts": @[ @{ @"attribute_id": @0, @"extension_attributes": @{  }, @"value": @"", @"website_id": @0, @"website_value": @"" } ], @"stock_item": @{ @"backorders": @0, @"enable_qty_increments": @NO, @"extension_attributes": @{  }, @"is_decimal_divided": @NO, @"is_in_stock": @NO, @"is_qty_decimal": @NO, @"item_id": @0, @"low_stock_date": @"", @"manage_stock": @NO, @"max_sale_qty": @"", @"min_qty": @"", @"min_sale_qty": @"", @"notify_stock_qty": @"", @"product_id": @0, @"qty": @"", @"qty_increments": @"", @"show_default_notification_message": @NO, @"stock_id": @0, @"stock_status_changed_auto": @0, @"use_config_backorders": @NO, @"use_config_enable_qty_inc": @NO, @"use_config_manage_stock": @NO, @"use_config_max_sale_qty": @NO, @"use_config_min_qty": @NO, @"use_config_min_sale_qty": @0, @"use_config_notify_stock_qty": @NO, @"use_config_qty_increments": @NO }, @"website_ids": @[  ] }, @"id": @0, @"media_gallery_entries": @[ @{ @"content": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" }, @"disabled": @NO, @"extension_attributes": @{ @"video_content": @{ @"media_type": @"", @"video_description": @"", @"video_metadata": @"", @"video_provider": @"", @"video_title": @"", @"video_url": @"" } }, @"file": @"", @"id": @0, @"label": @"", @"media_type": @"", @"position": @0, @"types": @[  ] } ], @"name": @"", @"options": @[ @{ @"extension_attributes": @{ @"vertex_flex_field": @"" }, @"file_extension": @"", @"image_size_x": @0, @"image_size_y": @0, @"is_require": @NO, @"max_characters": @0, @"option_id": @0, @"price": @"", @"price_type": @"", @"product_sku": @"", @"sku": @"", @"sort_order": @0, @"title": @"", @"type": @"", @"values": @[ @{ @"option_type_id": @0, @"price": @"", @"price_type": @"", @"sku": @"", @"sort_order": @0, @"title": @"" } ] } ], @"price": @"", @"product_links": @[ @{ @"extension_attributes": @{ @"qty": @"" }, @"link_type": @"", @"linked_product_sku": @"", @"linked_product_type": @"", @"position": @0, @"sku": @"" } ], @"sku": @"", @"status": @0, @"tier_prices": @[ @{ @"customer_group_id": @0, @"extension_attributes": @{ @"percentage_value": @"", @"website_id": @0 }, @"qty": @"", @"value": @"" } ], @"type_id": @"", @"updated_at": @"", @"visibility": @0, @"weight": @"" },
                              @"saveOptions": @NO };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'product' => [
        'attribute_set_id' => 0,
        'created_at' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'extension_attributes' => [
                'bundle_product_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'position' => 0,
                                                                'product_links' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'can_change_quantity' => 0,
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'id' => '',
                                                                                                                                                                                                                                                                'is_default' => null,
                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                'position' => 0,
                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                'price_type' => 0,
                                                                                                                                                                                                                                                                'qty' => '',
                                                                                                                                                                                                                                                                'sku' => ''
                                                                                                                                ]
                                                                ],
                                                                'required' => null,
                                                                'sku' => '',
                                                                'title' => '',
                                                                'type' => ''
                                ]
                ],
                'category_links' => [
                                [
                                                                'category_id' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'position' => 0
                                ]
                ],
                'configurable_product_links' => [
                                
                ],
                'configurable_product_options' => [
                                [
                                                                'attribute_id' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'is_use_default' => null,
                                                                'label' => '',
                                                                'position' => 0,
                                                                'product_id' => 0,
                                                                'values' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'value_index' => 0
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'downloadable_product_links' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'is_shareable' => 0,
                                                                'link_file' => '',
                                                                'link_file_content' => [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'file_data' => '',
                                                                                                                                'name' => ''
                                                                ],
                                                                'link_type' => '',
                                                                'link_url' => '',
                                                                'number_of_downloads' => 0,
                                                                'price' => '',
                                                                'sample_file' => '',
                                                                'sample_file_content' => [
                                                                                                                                
                                                                ],
                                                                'sample_type' => '',
                                                                'sample_url' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ],
                'downloadable_product_samples' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'sample_file' => '',
                                                                'sample_file_content' => [
                                                                                                                                
                                                                ],
                                                                'sample_type' => '',
                                                                'sample_url' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ],
                'giftcard_amounts' => [
                                [
                                                                'attribute_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'value' => '',
                                                                'website_id' => 0,
                                                                'website_value' => ''
                                ]
                ],
                'stock_item' => [
                                'backorders' => 0,
                                'enable_qty_increments' => null,
                                'extension_attributes' => [
                                                                
                                ],
                                'is_decimal_divided' => null,
                                'is_in_stock' => null,
                                'is_qty_decimal' => null,
                                'item_id' => 0,
                                'low_stock_date' => '',
                                'manage_stock' => null,
                                'max_sale_qty' => '',
                                'min_qty' => '',
                                'min_sale_qty' => '',
                                'notify_stock_qty' => '',
                                'product_id' => 0,
                                'qty' => '',
                                'qty_increments' => '',
                                'show_default_notification_message' => null,
                                'stock_id' => 0,
                                'stock_status_changed_auto' => 0,
                                'use_config_backorders' => null,
                                'use_config_enable_qty_inc' => null,
                                'use_config_manage_stock' => null,
                                'use_config_max_sale_qty' => null,
                                'use_config_min_qty' => null,
                                'use_config_min_sale_qty' => 0,
                                'use_config_notify_stock_qty' => null,
                                'use_config_qty_increments' => null
                ],
                'website_ids' => [
                                
                ]
        ],
        'id' => 0,
        'media_gallery_entries' => [
                [
                                'content' => [
                                                                'base64_encoded_data' => '',
                                                                'name' => '',
                                                                'type' => ''
                                ],
                                'disabled' => null,
                                'extension_attributes' => [
                                                                'video_content' => [
                                                                                                                                'media_type' => '',
                                                                                                                                'video_description' => '',
                                                                                                                                'video_metadata' => '',
                                                                                                                                'video_provider' => '',
                                                                                                                                'video_title' => '',
                                                                                                                                'video_url' => ''
                                                                ]
                                ],
                                'file' => '',
                                'id' => 0,
                                'label' => '',
                                'media_type' => '',
                                'position' => 0,
                                'types' => [
                                                                
                                ]
                ]
        ],
        'name' => '',
        'options' => [
                [
                                'extension_attributes' => [
                                                                'vertex_flex_field' => ''
                                ],
                                'file_extension' => '',
                                'image_size_x' => 0,
                                'image_size_y' => 0,
                                'is_require' => null,
                                'max_characters' => 0,
                                'option_id' => 0,
                                'price' => '',
                                'price_type' => '',
                                'product_sku' => '',
                                'sku' => '',
                                'sort_order' => 0,
                                'title' => '',
                                'type' => '',
                                'values' => [
                                                                [
                                                                                                                                'option_type_id' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'price_type' => '',
                                                                                                                                'sku' => '',
                                                                                                                                'sort_order' => 0,
                                                                                                                                'title' => ''
                                                                ]
                                ]
                ]
        ],
        'price' => '',
        'product_links' => [
                [
                                'extension_attributes' => [
                                                                'qty' => ''
                                ],
                                'link_type' => '',
                                'linked_product_sku' => '',
                                'linked_product_type' => '',
                                'position' => 0,
                                'sku' => ''
                ]
        ],
        'sku' => '',
        'status' => 0,
        'tier_prices' => [
                [
                                'customer_group_id' => 0,
                                'extension_attributes' => [
                                                                'percentage_value' => '',
                                                                'website_id' => 0
                                ],
                                'qty' => '',
                                'value' => ''
                ]
        ],
        'type_id' => '',
        'updated_at' => '',
        'visibility' => 0,
        'weight' => ''
    ],
    'saveOptions' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products', [
  'body' => '{
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {
          "attribute_id": "",
          "extension_attributes": {},
          "id": 0,
          "is_use_default": false,
          "label": "",
          "position": 0,
          "product_id": 0,
          "values": [
            {
              "extension_attributes": {},
              "value_index": 0
            }
          ]
        }
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  },
  "saveOptions": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'product' => [
    'attribute_set_id' => 0,
    'created_at' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'extension_attributes' => [
        'bundle_product_options' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'option_id' => 0,
                                'position' => 0,
                                'product_links' => [
                                                                [
                                                                                                                                'can_change_quantity' => 0,
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => '',
                                                                                                                                'is_default' => null,
                                                                                                                                'option_id' => 0,
                                                                                                                                'position' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'price_type' => 0,
                                                                                                                                'qty' => '',
                                                                                                                                'sku' => ''
                                                                ]
                                ],
                                'required' => null,
                                'sku' => '',
                                'title' => '',
                                'type' => ''
                ]
        ],
        'category_links' => [
                [
                                'category_id' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'position' => 0
                ]
        ],
        'configurable_product_links' => [
                
        ],
        'configurable_product_options' => [
                [
                                'attribute_id' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => 0,
                                'is_use_default' => null,
                                'label' => '',
                                'position' => 0,
                                'product_id' => 0,
                                'values' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'value_index' => 0
                                                                ]
                                ]
                ]
        ],
        'downloadable_product_links' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => 0,
                                'is_shareable' => 0,
                                'link_file' => '',
                                'link_file_content' => [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'file_data' => '',
                                                                'name' => ''
                                ],
                                'link_type' => '',
                                'link_url' => '',
                                'number_of_downloads' => 0,
                                'price' => '',
                                'sample_file' => '',
                                'sample_file_content' => [
                                                                
                                ],
                                'sample_type' => '',
                                'sample_url' => '',
                                'sort_order' => 0,
                                'title' => ''
                ]
        ],
        'downloadable_product_samples' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => 0,
                                'sample_file' => '',
                                'sample_file_content' => [
                                                                
                                ],
                                'sample_type' => '',
                                'sample_url' => '',
                                'sort_order' => 0,
                                'title' => ''
                ]
        ],
        'giftcard_amounts' => [
                [
                                'attribute_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'value' => '',
                                'website_id' => 0,
                                'website_value' => ''
                ]
        ],
        'stock_item' => [
                'backorders' => 0,
                'enable_qty_increments' => null,
                'extension_attributes' => [
                                
                ],
                'is_decimal_divided' => null,
                'is_in_stock' => null,
                'is_qty_decimal' => null,
                'item_id' => 0,
                'low_stock_date' => '',
                'manage_stock' => null,
                'max_sale_qty' => '',
                'min_qty' => '',
                'min_sale_qty' => '',
                'notify_stock_qty' => '',
                'product_id' => 0,
                'qty' => '',
                'qty_increments' => '',
                'show_default_notification_message' => null,
                'stock_id' => 0,
                'stock_status_changed_auto' => 0,
                'use_config_backorders' => null,
                'use_config_enable_qty_inc' => null,
                'use_config_manage_stock' => null,
                'use_config_max_sale_qty' => null,
                'use_config_min_qty' => null,
                'use_config_min_sale_qty' => 0,
                'use_config_notify_stock_qty' => null,
                'use_config_qty_increments' => null
        ],
        'website_ids' => [
                
        ]
    ],
    'id' => 0,
    'media_gallery_entries' => [
        [
                'content' => [
                                'base64_encoded_data' => '',
                                'name' => '',
                                'type' => ''
                ],
                'disabled' => null,
                'extension_attributes' => [
                                'video_content' => [
                                                                'media_type' => '',
                                                                'video_description' => '',
                                                                'video_metadata' => '',
                                                                'video_provider' => '',
                                                                'video_title' => '',
                                                                'video_url' => ''
                                ]
                ],
                'file' => '',
                'id' => 0,
                'label' => '',
                'media_type' => '',
                'position' => 0,
                'types' => [
                                
                ]
        ]
    ],
    'name' => '',
    'options' => [
        [
                'extension_attributes' => [
                                'vertex_flex_field' => ''
                ],
                'file_extension' => '',
                'image_size_x' => 0,
                'image_size_y' => 0,
                'is_require' => null,
                'max_characters' => 0,
                'option_id' => 0,
                'price' => '',
                'price_type' => '',
                'product_sku' => '',
                'sku' => '',
                'sort_order' => 0,
                'title' => '',
                'type' => '',
                'values' => [
                                [
                                                                'option_type_id' => 0,
                                                                'price' => '',
                                                                'price_type' => '',
                                                                'sku' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ]
        ]
    ],
    'price' => '',
    'product_links' => [
        [
                'extension_attributes' => [
                                'qty' => ''
                ],
                'link_type' => '',
                'linked_product_sku' => '',
                'linked_product_type' => '',
                'position' => 0,
                'sku' => ''
        ]
    ],
    'sku' => '',
    'status' => 0,
    'tier_prices' => [
        [
                'customer_group_id' => 0,
                'extension_attributes' => [
                                'percentage_value' => '',
                                'website_id' => 0
                ],
                'qty' => '',
                'value' => ''
        ]
    ],
    'type_id' => '',
    'updated_at' => '',
    'visibility' => 0,
    'weight' => ''
  ],
  'saveOptions' => null
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'product' => [
    'attribute_set_id' => 0,
    'created_at' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'extension_attributes' => [
        'bundle_product_options' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'option_id' => 0,
                                'position' => 0,
                                'product_links' => [
                                                                [
                                                                                                                                'can_change_quantity' => 0,
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => '',
                                                                                                                                'is_default' => null,
                                                                                                                                'option_id' => 0,
                                                                                                                                'position' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'price_type' => 0,
                                                                                                                                'qty' => '',
                                                                                                                                'sku' => ''
                                                                ]
                                ],
                                'required' => null,
                                'sku' => '',
                                'title' => '',
                                'type' => ''
                ]
        ],
        'category_links' => [
                [
                                'category_id' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'position' => 0
                ]
        ],
        'configurable_product_links' => [
                
        ],
        'configurable_product_options' => [
                [
                                'attribute_id' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => 0,
                                'is_use_default' => null,
                                'label' => '',
                                'position' => 0,
                                'product_id' => 0,
                                'values' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'value_index' => 0
                                                                ]
                                ]
                ]
        ],
        'downloadable_product_links' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => 0,
                                'is_shareable' => 0,
                                'link_file' => '',
                                'link_file_content' => [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'file_data' => '',
                                                                'name' => ''
                                ],
                                'link_type' => '',
                                'link_url' => '',
                                'number_of_downloads' => 0,
                                'price' => '',
                                'sample_file' => '',
                                'sample_file_content' => [
                                                                
                                ],
                                'sample_type' => '',
                                'sample_url' => '',
                                'sort_order' => 0,
                                'title' => ''
                ]
        ],
        'downloadable_product_samples' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => 0,
                                'sample_file' => '',
                                'sample_file_content' => [
                                                                
                                ],
                                'sample_type' => '',
                                'sample_url' => '',
                                'sort_order' => 0,
                                'title' => ''
                ]
        ],
        'giftcard_amounts' => [
                [
                                'attribute_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'value' => '',
                                'website_id' => 0,
                                'website_value' => ''
                ]
        ],
        'stock_item' => [
                'backorders' => 0,
                'enable_qty_increments' => null,
                'extension_attributes' => [
                                
                ],
                'is_decimal_divided' => null,
                'is_in_stock' => null,
                'is_qty_decimal' => null,
                'item_id' => 0,
                'low_stock_date' => '',
                'manage_stock' => null,
                'max_sale_qty' => '',
                'min_qty' => '',
                'min_sale_qty' => '',
                'notify_stock_qty' => '',
                'product_id' => 0,
                'qty' => '',
                'qty_increments' => '',
                'show_default_notification_message' => null,
                'stock_id' => 0,
                'stock_status_changed_auto' => 0,
                'use_config_backorders' => null,
                'use_config_enable_qty_inc' => null,
                'use_config_manage_stock' => null,
                'use_config_max_sale_qty' => null,
                'use_config_min_qty' => null,
                'use_config_min_sale_qty' => 0,
                'use_config_notify_stock_qty' => null,
                'use_config_qty_increments' => null
        ],
        'website_ids' => [
                
        ]
    ],
    'id' => 0,
    'media_gallery_entries' => [
        [
                'content' => [
                                'base64_encoded_data' => '',
                                'name' => '',
                                'type' => ''
                ],
                'disabled' => null,
                'extension_attributes' => [
                                'video_content' => [
                                                                'media_type' => '',
                                                                'video_description' => '',
                                                                'video_metadata' => '',
                                                                'video_provider' => '',
                                                                'video_title' => '',
                                                                'video_url' => ''
                                ]
                ],
                'file' => '',
                'id' => 0,
                'label' => '',
                'media_type' => '',
                'position' => 0,
                'types' => [
                                
                ]
        ]
    ],
    'name' => '',
    'options' => [
        [
                'extension_attributes' => [
                                'vertex_flex_field' => ''
                ],
                'file_extension' => '',
                'image_size_x' => 0,
                'image_size_y' => 0,
                'is_require' => null,
                'max_characters' => 0,
                'option_id' => 0,
                'price' => '',
                'price_type' => '',
                'product_sku' => '',
                'sku' => '',
                'sort_order' => 0,
                'title' => '',
                'type' => '',
                'values' => [
                                [
                                                                'option_type_id' => 0,
                                                                'price' => '',
                                                                'price_type' => '',
                                                                'sku' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ]
        ]
    ],
    'price' => '',
    'product_links' => [
        [
                'extension_attributes' => [
                                'qty' => ''
                ],
                'link_type' => '',
                'linked_product_sku' => '',
                'linked_product_type' => '',
                'position' => 0,
                'sku' => ''
        ]
    ],
    'sku' => '',
    'status' => 0,
    'tier_prices' => [
        [
                'customer_group_id' => 0,
                'extension_attributes' => [
                                'percentage_value' => '',
                                'website_id' => 0
                ],
                'qty' => '',
                'value' => ''
        ]
    ],
    'type_id' => '',
    'updated_at' => '',
    'visibility' => 0,
    'weight' => ''
  ],
  'saveOptions' => null
]));
$request->setRequestUrl('{{baseUrl}}/V1/products');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {
          "attribute_id": "",
          "extension_attributes": {},
          "id": 0,
          "is_use_default": false,
          "label": "",
          "position": 0,
          "product_id": 0,
          "values": [
            {
              "extension_attributes": {},
              "value_index": 0
            }
          ]
        }
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  },
  "saveOptions": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {
          "attribute_id": "",
          "extension_attributes": {},
          "id": 0,
          "is_use_default": false,
          "label": "",
          "position": 0,
          "product_id": 0,
          "values": [
            {
              "extension_attributes": {},
              "value_index": 0
            }
          ]
        }
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  },
  "saveOptions": false
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products"

payload = {
    "product": {
        "attribute_set_id": 0,
        "created_at": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "extension_attributes": {
            "bundle_product_options": [
                {
                    "extension_attributes": {},
                    "option_id": 0,
                    "position": 0,
                    "product_links": [
                        {
                            "can_change_quantity": 0,
                            "extension_attributes": {},
                            "id": "",
                            "is_default": False,
                            "option_id": 0,
                            "position": 0,
                            "price": "",
                            "price_type": 0,
                            "qty": "",
                            "sku": ""
                        }
                    ],
                    "required": False,
                    "sku": "",
                    "title": "",
                    "type": ""
                }
            ],
            "category_links": [
                {
                    "category_id": "",
                    "extension_attributes": {},
                    "position": 0
                }
            ],
            "configurable_product_links": [],
            "configurable_product_options": [
                {
                    "attribute_id": "",
                    "extension_attributes": {},
                    "id": 0,
                    "is_use_default": False,
                    "label": "",
                    "position": 0,
                    "product_id": 0,
                    "values": [
                        {
                            "extension_attributes": {},
                            "value_index": 0
                        }
                    ]
                }
            ],
            "downloadable_product_links": [
                {
                    "extension_attributes": {},
                    "id": 0,
                    "is_shareable": 0,
                    "link_file": "",
                    "link_file_content": {
                        "extension_attributes": {},
                        "file_data": "",
                        "name": ""
                    },
                    "link_type": "",
                    "link_url": "",
                    "number_of_downloads": 0,
                    "price": "",
                    "sample_file": "",
                    "sample_file_content": {},
                    "sample_type": "",
                    "sample_url": "",
                    "sort_order": 0,
                    "title": ""
                }
            ],
            "downloadable_product_samples": [
                {
                    "extension_attributes": {},
                    "id": 0,
                    "sample_file": "",
                    "sample_file_content": {},
                    "sample_type": "",
                    "sample_url": "",
                    "sort_order": 0,
                    "title": ""
                }
            ],
            "giftcard_amounts": [
                {
                    "attribute_id": 0,
                    "extension_attributes": {},
                    "value": "",
                    "website_id": 0,
                    "website_value": ""
                }
            ],
            "stock_item": {
                "backorders": 0,
                "enable_qty_increments": False,
                "extension_attributes": {},
                "is_decimal_divided": False,
                "is_in_stock": False,
                "is_qty_decimal": False,
                "item_id": 0,
                "low_stock_date": "",
                "manage_stock": False,
                "max_sale_qty": "",
                "min_qty": "",
                "min_sale_qty": "",
                "notify_stock_qty": "",
                "product_id": 0,
                "qty": "",
                "qty_increments": "",
                "show_default_notification_message": False,
                "stock_id": 0,
                "stock_status_changed_auto": 0,
                "use_config_backorders": False,
                "use_config_enable_qty_inc": False,
                "use_config_manage_stock": False,
                "use_config_max_sale_qty": False,
                "use_config_min_qty": False,
                "use_config_min_sale_qty": 0,
                "use_config_notify_stock_qty": False,
                "use_config_qty_increments": False
            },
            "website_ids": []
        },
        "id": 0,
        "media_gallery_entries": [
            {
                "content": {
                    "base64_encoded_data": "",
                    "name": "",
                    "type": ""
                },
                "disabled": False,
                "extension_attributes": { "video_content": {
                        "media_type": "",
                        "video_description": "",
                        "video_metadata": "",
                        "video_provider": "",
                        "video_title": "",
                        "video_url": ""
                    } },
                "file": "",
                "id": 0,
                "label": "",
                "media_type": "",
                "position": 0,
                "types": []
            }
        ],
        "name": "",
        "options": [
            {
                "extension_attributes": { "vertex_flex_field": "" },
                "file_extension": "",
                "image_size_x": 0,
                "image_size_y": 0,
                "is_require": False,
                "max_characters": 0,
                "option_id": 0,
                "price": "",
                "price_type": "",
                "product_sku": "",
                "sku": "",
                "sort_order": 0,
                "title": "",
                "type": "",
                "values": [
                    {
                        "option_type_id": 0,
                        "price": "",
                        "price_type": "",
                        "sku": "",
                        "sort_order": 0,
                        "title": ""
                    }
                ]
            }
        ],
        "price": "",
        "product_links": [
            {
                "extension_attributes": { "qty": "" },
                "link_type": "",
                "linked_product_sku": "",
                "linked_product_type": "",
                "position": 0,
                "sku": ""
            }
        ],
        "sku": "",
        "status": 0,
        "tier_prices": [
            {
                "customer_group_id": 0,
                "extension_attributes": {
                    "percentage_value": "",
                    "website_id": 0
                },
                "qty": "",
                "value": ""
            }
        ],
        "type_id": "",
        "updated_at": "",
        "visibility": 0,
        "weight": ""
    },
    "saveOptions": False
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products"

payload <- "{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": 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/V1/products') do |req|
  req.body = "{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products";

    let payload = json!({
        "product": json!({
            "attribute_set_id": 0,
            "created_at": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "extension_attributes": json!({
                "bundle_product_options": (
                    json!({
                        "extension_attributes": json!({}),
                        "option_id": 0,
                        "position": 0,
                        "product_links": (
                            json!({
                                "can_change_quantity": 0,
                                "extension_attributes": json!({}),
                                "id": "",
                                "is_default": false,
                                "option_id": 0,
                                "position": 0,
                                "price": "",
                                "price_type": 0,
                                "qty": "",
                                "sku": ""
                            })
                        ),
                        "required": false,
                        "sku": "",
                        "title": "",
                        "type": ""
                    })
                ),
                "category_links": (
                    json!({
                        "category_id": "",
                        "extension_attributes": json!({}),
                        "position": 0
                    })
                ),
                "configurable_product_links": (),
                "configurable_product_options": (
                    json!({
                        "attribute_id": "",
                        "extension_attributes": json!({}),
                        "id": 0,
                        "is_use_default": false,
                        "label": "",
                        "position": 0,
                        "product_id": 0,
                        "values": (
                            json!({
                                "extension_attributes": json!({}),
                                "value_index": 0
                            })
                        )
                    })
                ),
                "downloadable_product_links": (
                    json!({
                        "extension_attributes": json!({}),
                        "id": 0,
                        "is_shareable": 0,
                        "link_file": "",
                        "link_file_content": json!({
                            "extension_attributes": json!({}),
                            "file_data": "",
                            "name": ""
                        }),
                        "link_type": "",
                        "link_url": "",
                        "number_of_downloads": 0,
                        "price": "",
                        "sample_file": "",
                        "sample_file_content": json!({}),
                        "sample_type": "",
                        "sample_url": "",
                        "sort_order": 0,
                        "title": ""
                    })
                ),
                "downloadable_product_samples": (
                    json!({
                        "extension_attributes": json!({}),
                        "id": 0,
                        "sample_file": "",
                        "sample_file_content": json!({}),
                        "sample_type": "",
                        "sample_url": "",
                        "sort_order": 0,
                        "title": ""
                    })
                ),
                "giftcard_amounts": (
                    json!({
                        "attribute_id": 0,
                        "extension_attributes": json!({}),
                        "value": "",
                        "website_id": 0,
                        "website_value": ""
                    })
                ),
                "stock_item": json!({
                    "backorders": 0,
                    "enable_qty_increments": false,
                    "extension_attributes": json!({}),
                    "is_decimal_divided": false,
                    "is_in_stock": false,
                    "is_qty_decimal": false,
                    "item_id": 0,
                    "low_stock_date": "",
                    "manage_stock": false,
                    "max_sale_qty": "",
                    "min_qty": "",
                    "min_sale_qty": "",
                    "notify_stock_qty": "",
                    "product_id": 0,
                    "qty": "",
                    "qty_increments": "",
                    "show_default_notification_message": false,
                    "stock_id": 0,
                    "stock_status_changed_auto": 0,
                    "use_config_backorders": false,
                    "use_config_enable_qty_inc": false,
                    "use_config_manage_stock": false,
                    "use_config_max_sale_qty": false,
                    "use_config_min_qty": false,
                    "use_config_min_sale_qty": 0,
                    "use_config_notify_stock_qty": false,
                    "use_config_qty_increments": false
                }),
                "website_ids": ()
            }),
            "id": 0,
            "media_gallery_entries": (
                json!({
                    "content": json!({
                        "base64_encoded_data": "",
                        "name": "",
                        "type": ""
                    }),
                    "disabled": false,
                    "extension_attributes": json!({"video_content": json!({
                            "media_type": "",
                            "video_description": "",
                            "video_metadata": "",
                            "video_provider": "",
                            "video_title": "",
                            "video_url": ""
                        })}),
                    "file": "",
                    "id": 0,
                    "label": "",
                    "media_type": "",
                    "position": 0,
                    "types": ()
                })
            ),
            "name": "",
            "options": (
                json!({
                    "extension_attributes": json!({"vertex_flex_field": ""}),
                    "file_extension": "",
                    "image_size_x": 0,
                    "image_size_y": 0,
                    "is_require": false,
                    "max_characters": 0,
                    "option_id": 0,
                    "price": "",
                    "price_type": "",
                    "product_sku": "",
                    "sku": "",
                    "sort_order": 0,
                    "title": "",
                    "type": "",
                    "values": (
                        json!({
                            "option_type_id": 0,
                            "price": "",
                            "price_type": "",
                            "sku": "",
                            "sort_order": 0,
                            "title": ""
                        })
                    )
                })
            ),
            "price": "",
            "product_links": (
                json!({
                    "extension_attributes": json!({"qty": ""}),
                    "link_type": "",
                    "linked_product_sku": "",
                    "linked_product_type": "",
                    "position": 0,
                    "sku": ""
                })
            ),
            "sku": "",
            "status": 0,
            "tier_prices": (
                json!({
                    "customer_group_id": 0,
                    "extension_attributes": json!({
                        "percentage_value": "",
                        "website_id": 0
                    }),
                    "qty": "",
                    "value": ""
                })
            ),
            "type_id": "",
            "updated_at": "",
            "visibility": 0,
            "weight": ""
        }),
        "saveOptions": false
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products \
  --header 'content-type: application/json' \
  --data '{
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {
          "attribute_id": "",
          "extension_attributes": {},
          "id": 0,
          "is_use_default": false,
          "label": "",
          "position": 0,
          "product_id": 0,
          "values": [
            {
              "extension_attributes": {},
              "value_index": 0
            }
          ]
        }
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  },
  "saveOptions": false
}'
echo '{
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {
          "attribute_id": "",
          "extension_attributes": {},
          "id": 0,
          "is_use_default": false,
          "label": "",
          "position": 0,
          "product_id": 0,
          "values": [
            {
              "extension_attributes": {},
              "value_index": 0
            }
          ]
        }
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  },
  "saveOptions": false
}' |  \
  http POST {{baseUrl}}/V1/products \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "product": {\n    "attribute_set_id": 0,\n    "created_at": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "extension_attributes": {\n      "bundle_product_options": [\n        {\n          "extension_attributes": {},\n          "option_id": 0,\n          "position": 0,\n          "product_links": [\n            {\n              "can_change_quantity": 0,\n              "extension_attributes": {},\n              "id": "",\n              "is_default": false,\n              "option_id": 0,\n              "position": 0,\n              "price": "",\n              "price_type": 0,\n              "qty": "",\n              "sku": ""\n            }\n          ],\n          "required": false,\n          "sku": "",\n          "title": "",\n          "type": ""\n        }\n      ],\n      "category_links": [\n        {\n          "category_id": "",\n          "extension_attributes": {},\n          "position": 0\n        }\n      ],\n      "configurable_product_links": [],\n      "configurable_product_options": [\n        {\n          "attribute_id": "",\n          "extension_attributes": {},\n          "id": 0,\n          "is_use_default": false,\n          "label": "",\n          "position": 0,\n          "product_id": 0,\n          "values": [\n            {\n              "extension_attributes": {},\n              "value_index": 0\n            }\n          ]\n        }\n      ],\n      "downloadable_product_links": [\n        {\n          "extension_attributes": {},\n          "id": 0,\n          "is_shareable": 0,\n          "link_file": "",\n          "link_file_content": {\n            "extension_attributes": {},\n            "file_data": "",\n            "name": ""\n          },\n          "link_type": "",\n          "link_url": "",\n          "number_of_downloads": 0,\n          "price": "",\n          "sample_file": "",\n          "sample_file_content": {},\n          "sample_type": "",\n          "sample_url": "",\n          "sort_order": 0,\n          "title": ""\n        }\n      ],\n      "downloadable_product_samples": [\n        {\n          "extension_attributes": {},\n          "id": 0,\n          "sample_file": "",\n          "sample_file_content": {},\n          "sample_type": "",\n          "sample_url": "",\n          "sort_order": 0,\n          "title": ""\n        }\n      ],\n      "giftcard_amounts": [\n        {\n          "attribute_id": 0,\n          "extension_attributes": {},\n          "value": "",\n          "website_id": 0,\n          "website_value": ""\n        }\n      ],\n      "stock_item": {\n        "backorders": 0,\n        "enable_qty_increments": false,\n        "extension_attributes": {},\n        "is_decimal_divided": false,\n        "is_in_stock": false,\n        "is_qty_decimal": false,\n        "item_id": 0,\n        "low_stock_date": "",\n        "manage_stock": false,\n        "max_sale_qty": "",\n        "min_qty": "",\n        "min_sale_qty": "",\n        "notify_stock_qty": "",\n        "product_id": 0,\n        "qty": "",\n        "qty_increments": "",\n        "show_default_notification_message": false,\n        "stock_id": 0,\n        "stock_status_changed_auto": 0,\n        "use_config_backorders": false,\n        "use_config_enable_qty_inc": false,\n        "use_config_manage_stock": false,\n        "use_config_max_sale_qty": false,\n        "use_config_min_qty": false,\n        "use_config_min_sale_qty": 0,\n        "use_config_notify_stock_qty": false,\n        "use_config_qty_increments": false\n      },\n      "website_ids": []\n    },\n    "id": 0,\n    "media_gallery_entries": [\n      {\n        "content": {\n          "base64_encoded_data": "",\n          "name": "",\n          "type": ""\n        },\n        "disabled": false,\n        "extension_attributes": {\n          "video_content": {\n            "media_type": "",\n            "video_description": "",\n            "video_metadata": "",\n            "video_provider": "",\n            "video_title": "",\n            "video_url": ""\n          }\n        },\n        "file": "",\n        "id": 0,\n        "label": "",\n        "media_type": "",\n        "position": 0,\n        "types": []\n      }\n    ],\n    "name": "",\n    "options": [\n      {\n        "extension_attributes": {\n          "vertex_flex_field": ""\n        },\n        "file_extension": "",\n        "image_size_x": 0,\n        "image_size_y": 0,\n        "is_require": false,\n        "max_characters": 0,\n        "option_id": 0,\n        "price": "",\n        "price_type": "",\n        "product_sku": "",\n        "sku": "",\n        "sort_order": 0,\n        "title": "",\n        "type": "",\n        "values": [\n          {\n            "option_type_id": 0,\n            "price": "",\n            "price_type": "",\n            "sku": "",\n            "sort_order": 0,\n            "title": ""\n          }\n        ]\n      }\n    ],\n    "price": "",\n    "product_links": [\n      {\n        "extension_attributes": {\n          "qty": ""\n        },\n        "link_type": "",\n        "linked_product_sku": "",\n        "linked_product_type": "",\n        "position": 0,\n        "sku": ""\n      }\n    ],\n    "sku": "",\n    "status": 0,\n    "tier_prices": [\n      {\n        "customer_group_id": 0,\n        "extension_attributes": {\n          "percentage_value": "",\n          "website_id": 0\n        },\n        "qty": "",\n        "value": ""\n      }\n    ],\n    "type_id": "",\n    "updated_at": "",\n    "visibility": 0,\n    "weight": ""\n  },\n  "saveOptions": false\n}' \
  --output-document \
  - {{baseUrl}}/V1/products
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "product": [
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "extension_attributes": [
      "bundle_product_options": [
        [
          "extension_attributes": [],
          "option_id": 0,
          "position": 0,
          "product_links": [
            [
              "can_change_quantity": 0,
              "extension_attributes": [],
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            ]
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        ]
      ],
      "category_links": [
        [
          "category_id": "",
          "extension_attributes": [],
          "position": 0
        ]
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        [
          "attribute_id": "",
          "extension_attributes": [],
          "id": 0,
          "is_use_default": false,
          "label": "",
          "position": 0,
          "product_id": 0,
          "values": [
            [
              "extension_attributes": [],
              "value_index": 0
            ]
          ]
        ]
      ],
      "downloadable_product_links": [
        [
          "extension_attributes": [],
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": [
            "extension_attributes": [],
            "file_data": "",
            "name": ""
          ],
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": [],
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        ]
      ],
      "downloadable_product_samples": [
        [
          "extension_attributes": [],
          "id": 0,
          "sample_file": "",
          "sample_file_content": [],
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        ]
      ],
      "giftcard_amounts": [
        [
          "attribute_id": 0,
          "extension_attributes": [],
          "value": "",
          "website_id": 0,
          "website_value": ""
        ]
      ],
      "stock_item": [
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": [],
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      ],
      "website_ids": []
    ],
    "id": 0,
    "media_gallery_entries": [
      [
        "content": [
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        ],
        "disabled": false,
        "extension_attributes": ["video_content": [
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          ]],
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      ]
    ],
    "name": "",
    "options": [
      [
        "extension_attributes": ["vertex_flex_field": ""],
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          [
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          ]
        ]
      ]
    ],
    "price": "",
    "product_links": [
      [
        "extension_attributes": ["qty": ""],
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      ]
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      [
        "customer_group_id": 0,
        "extension_attributes": [
          "percentage_value": "",
          "website_id": 0
        ],
        "qty": "",
        "value": ""
      ]
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  ],
  "saveOptions": false
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET products
{{baseUrl}}/V1/products
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products")
require "http/client"

url = "{{baseUrl}}/V1/products"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/products'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/products'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/products'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products
http GET {{baseUrl}}/V1/products
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT products-{productSku}-stockItems-{itemId}
{{baseUrl}}/V1/products/:productSku/stockItems/:itemId
QUERY PARAMS

productSku
itemId
BODY json

{
  "stockItem": {
    "backorders": 0,
    "enable_qty_increments": false,
    "extension_attributes": {},
    "is_decimal_divided": false,
    "is_in_stock": false,
    "is_qty_decimal": false,
    "item_id": 0,
    "low_stock_date": "",
    "manage_stock": false,
    "max_sale_qty": "",
    "min_qty": "",
    "min_sale_qty": "",
    "notify_stock_qty": "",
    "product_id": 0,
    "qty": "",
    "qty_increments": "",
    "show_default_notification_message": false,
    "stock_id": 0,
    "stock_status_changed_auto": 0,
    "use_config_backorders": false,
    "use_config_enable_qty_inc": false,
    "use_config_manage_stock": false,
    "use_config_max_sale_qty": false,
    "use_config_min_qty": false,
    "use_config_min_sale_qty": 0,
    "use_config_notify_stock_qty": false,
    "use_config_qty_increments": false
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:productSku/stockItems/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"stockItem\": {\n    \"backorders\": 0,\n    \"enable_qty_increments\": false,\n    \"extension_attributes\": {},\n    \"is_decimal_divided\": false,\n    \"is_in_stock\": false,\n    \"is_qty_decimal\": false,\n    \"item_id\": 0,\n    \"low_stock_date\": \"\",\n    \"manage_stock\": false,\n    \"max_sale_qty\": \"\",\n    \"min_qty\": \"\",\n    \"min_sale_qty\": \"\",\n    \"notify_stock_qty\": \"\",\n    \"product_id\": 0,\n    \"qty\": \"\",\n    \"qty_increments\": \"\",\n    \"show_default_notification_message\": false,\n    \"stock_id\": 0,\n    \"stock_status_changed_auto\": 0,\n    \"use_config_backorders\": false,\n    \"use_config_enable_qty_inc\": false,\n    \"use_config_manage_stock\": false,\n    \"use_config_max_sale_qty\": false,\n    \"use_config_min_qty\": false,\n    \"use_config_min_sale_qty\": 0,\n    \"use_config_notify_stock_qty\": false,\n    \"use_config_qty_increments\": false\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/products/:productSku/stockItems/:itemId" {:content-type :json
                                                                                      :form-params {:stockItem {:backorders 0
                                                                                                                :enable_qty_increments false
                                                                                                                :extension_attributes {}
                                                                                                                :is_decimal_divided false
                                                                                                                :is_in_stock false
                                                                                                                :is_qty_decimal false
                                                                                                                :item_id 0
                                                                                                                :low_stock_date ""
                                                                                                                :manage_stock false
                                                                                                                :max_sale_qty ""
                                                                                                                :min_qty ""
                                                                                                                :min_sale_qty ""
                                                                                                                :notify_stock_qty ""
                                                                                                                :product_id 0
                                                                                                                :qty ""
                                                                                                                :qty_increments ""
                                                                                                                :show_default_notification_message false
                                                                                                                :stock_id 0
                                                                                                                :stock_status_changed_auto 0
                                                                                                                :use_config_backorders false
                                                                                                                :use_config_enable_qty_inc false
                                                                                                                :use_config_manage_stock false
                                                                                                                :use_config_max_sale_qty false
                                                                                                                :use_config_min_qty false
                                                                                                                :use_config_min_sale_qty 0
                                                                                                                :use_config_notify_stock_qty false
                                                                                                                :use_config_qty_increments false}}})
require "http/client"

url = "{{baseUrl}}/V1/products/:productSku/stockItems/:itemId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"stockItem\": {\n    \"backorders\": 0,\n    \"enable_qty_increments\": false,\n    \"extension_attributes\": {},\n    \"is_decimal_divided\": false,\n    \"is_in_stock\": false,\n    \"is_qty_decimal\": false,\n    \"item_id\": 0,\n    \"low_stock_date\": \"\",\n    \"manage_stock\": false,\n    \"max_sale_qty\": \"\",\n    \"min_qty\": \"\",\n    \"min_sale_qty\": \"\",\n    \"notify_stock_qty\": \"\",\n    \"product_id\": 0,\n    \"qty\": \"\",\n    \"qty_increments\": \"\",\n    \"show_default_notification_message\": false,\n    \"stock_id\": 0,\n    \"stock_status_changed_auto\": 0,\n    \"use_config_backorders\": false,\n    \"use_config_enable_qty_inc\": false,\n    \"use_config_manage_stock\": false,\n    \"use_config_max_sale_qty\": false,\n    \"use_config_min_qty\": false,\n    \"use_config_min_sale_qty\": 0,\n    \"use_config_notify_stock_qty\": false,\n    \"use_config_qty_increments\": false\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}}/V1/products/:productSku/stockItems/:itemId"),
    Content = new StringContent("{\n  \"stockItem\": {\n    \"backorders\": 0,\n    \"enable_qty_increments\": false,\n    \"extension_attributes\": {},\n    \"is_decimal_divided\": false,\n    \"is_in_stock\": false,\n    \"is_qty_decimal\": false,\n    \"item_id\": 0,\n    \"low_stock_date\": \"\",\n    \"manage_stock\": false,\n    \"max_sale_qty\": \"\",\n    \"min_qty\": \"\",\n    \"min_sale_qty\": \"\",\n    \"notify_stock_qty\": \"\",\n    \"product_id\": 0,\n    \"qty\": \"\",\n    \"qty_increments\": \"\",\n    \"show_default_notification_message\": false,\n    \"stock_id\": 0,\n    \"stock_status_changed_auto\": 0,\n    \"use_config_backorders\": false,\n    \"use_config_enable_qty_inc\": false,\n    \"use_config_manage_stock\": false,\n    \"use_config_max_sale_qty\": false,\n    \"use_config_min_qty\": false,\n    \"use_config_min_sale_qty\": 0,\n    \"use_config_notify_stock_qty\": false,\n    \"use_config_qty_increments\": false\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}}/V1/products/:productSku/stockItems/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"stockItem\": {\n    \"backorders\": 0,\n    \"enable_qty_increments\": false,\n    \"extension_attributes\": {},\n    \"is_decimal_divided\": false,\n    \"is_in_stock\": false,\n    \"is_qty_decimal\": false,\n    \"item_id\": 0,\n    \"low_stock_date\": \"\",\n    \"manage_stock\": false,\n    \"max_sale_qty\": \"\",\n    \"min_qty\": \"\",\n    \"min_sale_qty\": \"\",\n    \"notify_stock_qty\": \"\",\n    \"product_id\": 0,\n    \"qty\": \"\",\n    \"qty_increments\": \"\",\n    \"show_default_notification_message\": false,\n    \"stock_id\": 0,\n    \"stock_status_changed_auto\": 0,\n    \"use_config_backorders\": false,\n    \"use_config_enable_qty_inc\": false,\n    \"use_config_manage_stock\": false,\n    \"use_config_max_sale_qty\": false,\n    \"use_config_min_qty\": false,\n    \"use_config_min_sale_qty\": 0,\n    \"use_config_notify_stock_qty\": false,\n    \"use_config_qty_increments\": false\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:productSku/stockItems/:itemId"

	payload := strings.NewReader("{\n  \"stockItem\": {\n    \"backorders\": 0,\n    \"enable_qty_increments\": false,\n    \"extension_attributes\": {},\n    \"is_decimal_divided\": false,\n    \"is_in_stock\": false,\n    \"is_qty_decimal\": false,\n    \"item_id\": 0,\n    \"low_stock_date\": \"\",\n    \"manage_stock\": false,\n    \"max_sale_qty\": \"\",\n    \"min_qty\": \"\",\n    \"min_sale_qty\": \"\",\n    \"notify_stock_qty\": \"\",\n    \"product_id\": 0,\n    \"qty\": \"\",\n    \"qty_increments\": \"\",\n    \"show_default_notification_message\": false,\n    \"stock_id\": 0,\n    \"stock_status_changed_auto\": 0,\n    \"use_config_backorders\": false,\n    \"use_config_enable_qty_inc\": false,\n    \"use_config_manage_stock\": false,\n    \"use_config_max_sale_qty\": false,\n    \"use_config_min_qty\": false,\n    \"use_config_min_sale_qty\": 0,\n    \"use_config_notify_stock_qty\": false,\n    \"use_config_qty_increments\": false\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/products/:productSku/stockItems/:itemId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 832

{
  "stockItem": {
    "backorders": 0,
    "enable_qty_increments": false,
    "extension_attributes": {},
    "is_decimal_divided": false,
    "is_in_stock": false,
    "is_qty_decimal": false,
    "item_id": 0,
    "low_stock_date": "",
    "manage_stock": false,
    "max_sale_qty": "",
    "min_qty": "",
    "min_sale_qty": "",
    "notify_stock_qty": "",
    "product_id": 0,
    "qty": "",
    "qty_increments": "",
    "show_default_notification_message": false,
    "stock_id": 0,
    "stock_status_changed_auto": 0,
    "use_config_backorders": false,
    "use_config_enable_qty_inc": false,
    "use_config_manage_stock": false,
    "use_config_max_sale_qty": false,
    "use_config_min_qty": false,
    "use_config_min_sale_qty": 0,
    "use_config_notify_stock_qty": false,
    "use_config_qty_increments": false
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/products/:productSku/stockItems/:itemId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"stockItem\": {\n    \"backorders\": 0,\n    \"enable_qty_increments\": false,\n    \"extension_attributes\": {},\n    \"is_decimal_divided\": false,\n    \"is_in_stock\": false,\n    \"is_qty_decimal\": false,\n    \"item_id\": 0,\n    \"low_stock_date\": \"\",\n    \"manage_stock\": false,\n    \"max_sale_qty\": \"\",\n    \"min_qty\": \"\",\n    \"min_sale_qty\": \"\",\n    \"notify_stock_qty\": \"\",\n    \"product_id\": 0,\n    \"qty\": \"\",\n    \"qty_increments\": \"\",\n    \"show_default_notification_message\": false,\n    \"stock_id\": 0,\n    \"stock_status_changed_auto\": 0,\n    \"use_config_backorders\": false,\n    \"use_config_enable_qty_inc\": false,\n    \"use_config_manage_stock\": false,\n    \"use_config_max_sale_qty\": false,\n    \"use_config_min_qty\": false,\n    \"use_config_min_sale_qty\": 0,\n    \"use_config_notify_stock_qty\": false,\n    \"use_config_qty_increments\": false\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:productSku/stockItems/:itemId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"stockItem\": {\n    \"backorders\": 0,\n    \"enable_qty_increments\": false,\n    \"extension_attributes\": {},\n    \"is_decimal_divided\": false,\n    \"is_in_stock\": false,\n    \"is_qty_decimal\": false,\n    \"item_id\": 0,\n    \"low_stock_date\": \"\",\n    \"manage_stock\": false,\n    \"max_sale_qty\": \"\",\n    \"min_qty\": \"\",\n    \"min_sale_qty\": \"\",\n    \"notify_stock_qty\": \"\",\n    \"product_id\": 0,\n    \"qty\": \"\",\n    \"qty_increments\": \"\",\n    \"show_default_notification_message\": false,\n    \"stock_id\": 0,\n    \"stock_status_changed_auto\": 0,\n    \"use_config_backorders\": false,\n    \"use_config_enable_qty_inc\": false,\n    \"use_config_manage_stock\": false,\n    \"use_config_max_sale_qty\": false,\n    \"use_config_min_qty\": false,\n    \"use_config_min_sale_qty\": 0,\n    \"use_config_notify_stock_qty\": false,\n    \"use_config_qty_increments\": false\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  \"stockItem\": {\n    \"backorders\": 0,\n    \"enable_qty_increments\": false,\n    \"extension_attributes\": {},\n    \"is_decimal_divided\": false,\n    \"is_in_stock\": false,\n    \"is_qty_decimal\": false,\n    \"item_id\": 0,\n    \"low_stock_date\": \"\",\n    \"manage_stock\": false,\n    \"max_sale_qty\": \"\",\n    \"min_qty\": \"\",\n    \"min_sale_qty\": \"\",\n    \"notify_stock_qty\": \"\",\n    \"product_id\": 0,\n    \"qty\": \"\",\n    \"qty_increments\": \"\",\n    \"show_default_notification_message\": false,\n    \"stock_id\": 0,\n    \"stock_status_changed_auto\": 0,\n    \"use_config_backorders\": false,\n    \"use_config_enable_qty_inc\": false,\n    \"use_config_manage_stock\": false,\n    \"use_config_max_sale_qty\": false,\n    \"use_config_min_qty\": false,\n    \"use_config_min_sale_qty\": 0,\n    \"use_config_notify_stock_qty\": false,\n    \"use_config_qty_increments\": false\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:productSku/stockItems/:itemId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/products/:productSku/stockItems/:itemId")
  .header("content-type", "application/json")
  .body("{\n  \"stockItem\": {\n    \"backorders\": 0,\n    \"enable_qty_increments\": false,\n    \"extension_attributes\": {},\n    \"is_decimal_divided\": false,\n    \"is_in_stock\": false,\n    \"is_qty_decimal\": false,\n    \"item_id\": 0,\n    \"low_stock_date\": \"\",\n    \"manage_stock\": false,\n    \"max_sale_qty\": \"\",\n    \"min_qty\": \"\",\n    \"min_sale_qty\": \"\",\n    \"notify_stock_qty\": \"\",\n    \"product_id\": 0,\n    \"qty\": \"\",\n    \"qty_increments\": \"\",\n    \"show_default_notification_message\": false,\n    \"stock_id\": 0,\n    \"stock_status_changed_auto\": 0,\n    \"use_config_backorders\": false,\n    \"use_config_enable_qty_inc\": false,\n    \"use_config_manage_stock\": false,\n    \"use_config_max_sale_qty\": false,\n    \"use_config_min_qty\": false,\n    \"use_config_min_sale_qty\": 0,\n    \"use_config_notify_stock_qty\": false,\n    \"use_config_qty_increments\": false\n  }\n}")
  .asString();
const data = JSON.stringify({
  stockItem: {
    backorders: 0,
    enable_qty_increments: false,
    extension_attributes: {},
    is_decimal_divided: false,
    is_in_stock: false,
    is_qty_decimal: false,
    item_id: 0,
    low_stock_date: '',
    manage_stock: false,
    max_sale_qty: '',
    min_qty: '',
    min_sale_qty: '',
    notify_stock_qty: '',
    product_id: 0,
    qty: '',
    qty_increments: '',
    show_default_notification_message: false,
    stock_id: 0,
    stock_status_changed_auto: 0,
    use_config_backorders: false,
    use_config_enable_qty_inc: false,
    use_config_manage_stock: false,
    use_config_max_sale_qty: false,
    use_config_min_qty: false,
    use_config_min_sale_qty: 0,
    use_config_notify_stock_qty: false,
    use_config_qty_increments: 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}}/V1/products/:productSku/stockItems/:itemId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/:productSku/stockItems/:itemId',
  headers: {'content-type': 'application/json'},
  data: {
    stockItem: {
      backorders: 0,
      enable_qty_increments: false,
      extension_attributes: {},
      is_decimal_divided: false,
      is_in_stock: false,
      is_qty_decimal: false,
      item_id: 0,
      low_stock_date: '',
      manage_stock: false,
      max_sale_qty: '',
      min_qty: '',
      min_sale_qty: '',
      notify_stock_qty: '',
      product_id: 0,
      qty: '',
      qty_increments: '',
      show_default_notification_message: false,
      stock_id: 0,
      stock_status_changed_auto: 0,
      use_config_backorders: false,
      use_config_enable_qty_inc: false,
      use_config_manage_stock: false,
      use_config_max_sale_qty: false,
      use_config_min_qty: false,
      use_config_min_sale_qty: 0,
      use_config_notify_stock_qty: false,
      use_config_qty_increments: false
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:productSku/stockItems/:itemId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"stockItem":{"backorders":0,"enable_qty_increments":false,"extension_attributes":{},"is_decimal_divided":false,"is_in_stock":false,"is_qty_decimal":false,"item_id":0,"low_stock_date":"","manage_stock":false,"max_sale_qty":"","min_qty":"","min_sale_qty":"","notify_stock_qty":"","product_id":0,"qty":"","qty_increments":"","show_default_notification_message":false,"stock_id":0,"stock_status_changed_auto":0,"use_config_backorders":false,"use_config_enable_qty_inc":false,"use_config_manage_stock":false,"use_config_max_sale_qty":false,"use_config_min_qty":false,"use_config_min_sale_qty":0,"use_config_notify_stock_qty":false,"use_config_qty_increments":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}}/V1/products/:productSku/stockItems/:itemId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "stockItem": {\n    "backorders": 0,\n    "enable_qty_increments": false,\n    "extension_attributes": {},\n    "is_decimal_divided": false,\n    "is_in_stock": false,\n    "is_qty_decimal": false,\n    "item_id": 0,\n    "low_stock_date": "",\n    "manage_stock": false,\n    "max_sale_qty": "",\n    "min_qty": "",\n    "min_sale_qty": "",\n    "notify_stock_qty": "",\n    "product_id": 0,\n    "qty": "",\n    "qty_increments": "",\n    "show_default_notification_message": false,\n    "stock_id": 0,\n    "stock_status_changed_auto": 0,\n    "use_config_backorders": false,\n    "use_config_enable_qty_inc": false,\n    "use_config_manage_stock": false,\n    "use_config_max_sale_qty": false,\n    "use_config_min_qty": false,\n    "use_config_min_sale_qty": 0,\n    "use_config_notify_stock_qty": false,\n    "use_config_qty_increments": false\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  \"stockItem\": {\n    \"backorders\": 0,\n    \"enable_qty_increments\": false,\n    \"extension_attributes\": {},\n    \"is_decimal_divided\": false,\n    \"is_in_stock\": false,\n    \"is_qty_decimal\": false,\n    \"item_id\": 0,\n    \"low_stock_date\": \"\",\n    \"manage_stock\": false,\n    \"max_sale_qty\": \"\",\n    \"min_qty\": \"\",\n    \"min_sale_qty\": \"\",\n    \"notify_stock_qty\": \"\",\n    \"product_id\": 0,\n    \"qty\": \"\",\n    \"qty_increments\": \"\",\n    \"show_default_notification_message\": false,\n    \"stock_id\": 0,\n    \"stock_status_changed_auto\": 0,\n    \"use_config_backorders\": false,\n    \"use_config_enable_qty_inc\": false,\n    \"use_config_manage_stock\": false,\n    \"use_config_max_sale_qty\": false,\n    \"use_config_min_qty\": false,\n    \"use_config_min_sale_qty\": 0,\n    \"use_config_notify_stock_qty\": false,\n    \"use_config_qty_increments\": false\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:productSku/stockItems/:itemId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:productSku/stockItems/:itemId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  stockItem: {
    backorders: 0,
    enable_qty_increments: false,
    extension_attributes: {},
    is_decimal_divided: false,
    is_in_stock: false,
    is_qty_decimal: false,
    item_id: 0,
    low_stock_date: '',
    manage_stock: false,
    max_sale_qty: '',
    min_qty: '',
    min_sale_qty: '',
    notify_stock_qty: '',
    product_id: 0,
    qty: '',
    qty_increments: '',
    show_default_notification_message: false,
    stock_id: 0,
    stock_status_changed_auto: 0,
    use_config_backorders: false,
    use_config_enable_qty_inc: false,
    use_config_manage_stock: false,
    use_config_max_sale_qty: false,
    use_config_min_qty: false,
    use_config_min_sale_qty: 0,
    use_config_notify_stock_qty: false,
    use_config_qty_increments: false
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/:productSku/stockItems/:itemId',
  headers: {'content-type': 'application/json'},
  body: {
    stockItem: {
      backorders: 0,
      enable_qty_increments: false,
      extension_attributes: {},
      is_decimal_divided: false,
      is_in_stock: false,
      is_qty_decimal: false,
      item_id: 0,
      low_stock_date: '',
      manage_stock: false,
      max_sale_qty: '',
      min_qty: '',
      min_sale_qty: '',
      notify_stock_qty: '',
      product_id: 0,
      qty: '',
      qty_increments: '',
      show_default_notification_message: false,
      stock_id: 0,
      stock_status_changed_auto: 0,
      use_config_backorders: false,
      use_config_enable_qty_inc: false,
      use_config_manage_stock: false,
      use_config_max_sale_qty: false,
      use_config_min_qty: false,
      use_config_min_sale_qty: 0,
      use_config_notify_stock_qty: false,
      use_config_qty_increments: 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}}/V1/products/:productSku/stockItems/:itemId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  stockItem: {
    backorders: 0,
    enable_qty_increments: false,
    extension_attributes: {},
    is_decimal_divided: false,
    is_in_stock: false,
    is_qty_decimal: false,
    item_id: 0,
    low_stock_date: '',
    manage_stock: false,
    max_sale_qty: '',
    min_qty: '',
    min_sale_qty: '',
    notify_stock_qty: '',
    product_id: 0,
    qty: '',
    qty_increments: '',
    show_default_notification_message: false,
    stock_id: 0,
    stock_status_changed_auto: 0,
    use_config_backorders: false,
    use_config_enable_qty_inc: false,
    use_config_manage_stock: false,
    use_config_max_sale_qty: false,
    use_config_min_qty: false,
    use_config_min_sale_qty: 0,
    use_config_notify_stock_qty: false,
    use_config_qty_increments: 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}}/V1/products/:productSku/stockItems/:itemId',
  headers: {'content-type': 'application/json'},
  data: {
    stockItem: {
      backorders: 0,
      enable_qty_increments: false,
      extension_attributes: {},
      is_decimal_divided: false,
      is_in_stock: false,
      is_qty_decimal: false,
      item_id: 0,
      low_stock_date: '',
      manage_stock: false,
      max_sale_qty: '',
      min_qty: '',
      min_sale_qty: '',
      notify_stock_qty: '',
      product_id: 0,
      qty: '',
      qty_increments: '',
      show_default_notification_message: false,
      stock_id: 0,
      stock_status_changed_auto: 0,
      use_config_backorders: false,
      use_config_enable_qty_inc: false,
      use_config_manage_stock: false,
      use_config_max_sale_qty: false,
      use_config_min_qty: false,
      use_config_min_sale_qty: 0,
      use_config_notify_stock_qty: false,
      use_config_qty_increments: false
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:productSku/stockItems/:itemId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"stockItem":{"backorders":0,"enable_qty_increments":false,"extension_attributes":{},"is_decimal_divided":false,"is_in_stock":false,"is_qty_decimal":false,"item_id":0,"low_stock_date":"","manage_stock":false,"max_sale_qty":"","min_qty":"","min_sale_qty":"","notify_stock_qty":"","product_id":0,"qty":"","qty_increments":"","show_default_notification_message":false,"stock_id":0,"stock_status_changed_auto":0,"use_config_backorders":false,"use_config_enable_qty_inc":false,"use_config_manage_stock":false,"use_config_max_sale_qty":false,"use_config_min_qty":false,"use_config_min_sale_qty":0,"use_config_notify_stock_qty":false,"use_config_qty_increments":false}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"stockItem": @{ @"backorders": @0, @"enable_qty_increments": @NO, @"extension_attributes": @{  }, @"is_decimal_divided": @NO, @"is_in_stock": @NO, @"is_qty_decimal": @NO, @"item_id": @0, @"low_stock_date": @"", @"manage_stock": @NO, @"max_sale_qty": @"", @"min_qty": @"", @"min_sale_qty": @"", @"notify_stock_qty": @"", @"product_id": @0, @"qty": @"", @"qty_increments": @"", @"show_default_notification_message": @NO, @"stock_id": @0, @"stock_status_changed_auto": @0, @"use_config_backorders": @NO, @"use_config_enable_qty_inc": @NO, @"use_config_manage_stock": @NO, @"use_config_max_sale_qty": @NO, @"use_config_min_qty": @NO, @"use_config_min_sale_qty": @0, @"use_config_notify_stock_qty": @NO, @"use_config_qty_increments": @NO } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:productSku/stockItems/: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}}/V1/products/:productSku/stockItems/:itemId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"stockItem\": {\n    \"backorders\": 0,\n    \"enable_qty_increments\": false,\n    \"extension_attributes\": {},\n    \"is_decimal_divided\": false,\n    \"is_in_stock\": false,\n    \"is_qty_decimal\": false,\n    \"item_id\": 0,\n    \"low_stock_date\": \"\",\n    \"manage_stock\": false,\n    \"max_sale_qty\": \"\",\n    \"min_qty\": \"\",\n    \"min_sale_qty\": \"\",\n    \"notify_stock_qty\": \"\",\n    \"product_id\": 0,\n    \"qty\": \"\",\n    \"qty_increments\": \"\",\n    \"show_default_notification_message\": false,\n    \"stock_id\": 0,\n    \"stock_status_changed_auto\": 0,\n    \"use_config_backorders\": false,\n    \"use_config_enable_qty_inc\": false,\n    \"use_config_manage_stock\": false,\n    \"use_config_max_sale_qty\": false,\n    \"use_config_min_qty\": false,\n    \"use_config_min_sale_qty\": 0,\n    \"use_config_notify_stock_qty\": false,\n    \"use_config_qty_increments\": false\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:productSku/stockItems/: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([
    'stockItem' => [
        'backorders' => 0,
        'enable_qty_increments' => null,
        'extension_attributes' => [
                
        ],
        'is_decimal_divided' => null,
        'is_in_stock' => null,
        'is_qty_decimal' => null,
        'item_id' => 0,
        'low_stock_date' => '',
        'manage_stock' => null,
        'max_sale_qty' => '',
        'min_qty' => '',
        'min_sale_qty' => '',
        'notify_stock_qty' => '',
        'product_id' => 0,
        'qty' => '',
        'qty_increments' => '',
        'show_default_notification_message' => null,
        'stock_id' => 0,
        'stock_status_changed_auto' => 0,
        'use_config_backorders' => null,
        'use_config_enable_qty_inc' => null,
        'use_config_manage_stock' => null,
        'use_config_max_sale_qty' => null,
        'use_config_min_qty' => null,
        'use_config_min_sale_qty' => 0,
        'use_config_notify_stock_qty' => null,
        'use_config_qty_increments' => null
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/products/:productSku/stockItems/:itemId', [
  'body' => '{
  "stockItem": {
    "backorders": 0,
    "enable_qty_increments": false,
    "extension_attributes": {},
    "is_decimal_divided": false,
    "is_in_stock": false,
    "is_qty_decimal": false,
    "item_id": 0,
    "low_stock_date": "",
    "manage_stock": false,
    "max_sale_qty": "",
    "min_qty": "",
    "min_sale_qty": "",
    "notify_stock_qty": "",
    "product_id": 0,
    "qty": "",
    "qty_increments": "",
    "show_default_notification_message": false,
    "stock_id": 0,
    "stock_status_changed_auto": 0,
    "use_config_backorders": false,
    "use_config_enable_qty_inc": false,
    "use_config_manage_stock": false,
    "use_config_max_sale_qty": false,
    "use_config_min_qty": false,
    "use_config_min_sale_qty": 0,
    "use_config_notify_stock_qty": false,
    "use_config_qty_increments": false
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:productSku/stockItems/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'stockItem' => [
    'backorders' => 0,
    'enable_qty_increments' => null,
    'extension_attributes' => [
        
    ],
    'is_decimal_divided' => null,
    'is_in_stock' => null,
    'is_qty_decimal' => null,
    'item_id' => 0,
    'low_stock_date' => '',
    'manage_stock' => null,
    'max_sale_qty' => '',
    'min_qty' => '',
    'min_sale_qty' => '',
    'notify_stock_qty' => '',
    'product_id' => 0,
    'qty' => '',
    'qty_increments' => '',
    'show_default_notification_message' => null,
    'stock_id' => 0,
    'stock_status_changed_auto' => 0,
    'use_config_backorders' => null,
    'use_config_enable_qty_inc' => null,
    'use_config_manage_stock' => null,
    'use_config_max_sale_qty' => null,
    'use_config_min_qty' => null,
    'use_config_min_sale_qty' => 0,
    'use_config_notify_stock_qty' => null,
    'use_config_qty_increments' => null
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'stockItem' => [
    'backorders' => 0,
    'enable_qty_increments' => null,
    'extension_attributes' => [
        
    ],
    'is_decimal_divided' => null,
    'is_in_stock' => null,
    'is_qty_decimal' => null,
    'item_id' => 0,
    'low_stock_date' => '',
    'manage_stock' => null,
    'max_sale_qty' => '',
    'min_qty' => '',
    'min_sale_qty' => '',
    'notify_stock_qty' => '',
    'product_id' => 0,
    'qty' => '',
    'qty_increments' => '',
    'show_default_notification_message' => null,
    'stock_id' => 0,
    'stock_status_changed_auto' => 0,
    'use_config_backorders' => null,
    'use_config_enable_qty_inc' => null,
    'use_config_manage_stock' => null,
    'use_config_max_sale_qty' => null,
    'use_config_min_qty' => null,
    'use_config_min_sale_qty' => 0,
    'use_config_notify_stock_qty' => null,
    'use_config_qty_increments' => null
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/:productSku/stockItems/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:productSku/stockItems/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "stockItem": {
    "backorders": 0,
    "enable_qty_increments": false,
    "extension_attributes": {},
    "is_decimal_divided": false,
    "is_in_stock": false,
    "is_qty_decimal": false,
    "item_id": 0,
    "low_stock_date": "",
    "manage_stock": false,
    "max_sale_qty": "",
    "min_qty": "",
    "min_sale_qty": "",
    "notify_stock_qty": "",
    "product_id": 0,
    "qty": "",
    "qty_increments": "",
    "show_default_notification_message": false,
    "stock_id": 0,
    "stock_status_changed_auto": 0,
    "use_config_backorders": false,
    "use_config_enable_qty_inc": false,
    "use_config_manage_stock": false,
    "use_config_max_sale_qty": false,
    "use_config_min_qty": false,
    "use_config_min_sale_qty": 0,
    "use_config_notify_stock_qty": false,
    "use_config_qty_increments": false
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:productSku/stockItems/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "stockItem": {
    "backorders": 0,
    "enable_qty_increments": false,
    "extension_attributes": {},
    "is_decimal_divided": false,
    "is_in_stock": false,
    "is_qty_decimal": false,
    "item_id": 0,
    "low_stock_date": "",
    "manage_stock": false,
    "max_sale_qty": "",
    "min_qty": "",
    "min_sale_qty": "",
    "notify_stock_qty": "",
    "product_id": 0,
    "qty": "",
    "qty_increments": "",
    "show_default_notification_message": false,
    "stock_id": 0,
    "stock_status_changed_auto": 0,
    "use_config_backorders": false,
    "use_config_enable_qty_inc": false,
    "use_config_manage_stock": false,
    "use_config_max_sale_qty": false,
    "use_config_min_qty": false,
    "use_config_min_sale_qty": 0,
    "use_config_notify_stock_qty": false,
    "use_config_qty_increments": false
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"stockItem\": {\n    \"backorders\": 0,\n    \"enable_qty_increments\": false,\n    \"extension_attributes\": {},\n    \"is_decimal_divided\": false,\n    \"is_in_stock\": false,\n    \"is_qty_decimal\": false,\n    \"item_id\": 0,\n    \"low_stock_date\": \"\",\n    \"manage_stock\": false,\n    \"max_sale_qty\": \"\",\n    \"min_qty\": \"\",\n    \"min_sale_qty\": \"\",\n    \"notify_stock_qty\": \"\",\n    \"product_id\": 0,\n    \"qty\": \"\",\n    \"qty_increments\": \"\",\n    \"show_default_notification_message\": false,\n    \"stock_id\": 0,\n    \"stock_status_changed_auto\": 0,\n    \"use_config_backorders\": false,\n    \"use_config_enable_qty_inc\": false,\n    \"use_config_manage_stock\": false,\n    \"use_config_max_sale_qty\": false,\n    \"use_config_min_qty\": false,\n    \"use_config_min_sale_qty\": 0,\n    \"use_config_notify_stock_qty\": false,\n    \"use_config_qty_increments\": false\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/products/:productSku/stockItems/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:productSku/stockItems/:itemId"

payload = { "stockItem": {
        "backorders": 0,
        "enable_qty_increments": False,
        "extension_attributes": {},
        "is_decimal_divided": False,
        "is_in_stock": False,
        "is_qty_decimal": False,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": False,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": False,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": False,
        "use_config_enable_qty_inc": False,
        "use_config_manage_stock": False,
        "use_config_max_sale_qty": False,
        "use_config_min_qty": False,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": False,
        "use_config_qty_increments": False
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:productSku/stockItems/:itemId"

payload <- "{\n  \"stockItem\": {\n    \"backorders\": 0,\n    \"enable_qty_increments\": false,\n    \"extension_attributes\": {},\n    \"is_decimal_divided\": false,\n    \"is_in_stock\": false,\n    \"is_qty_decimal\": false,\n    \"item_id\": 0,\n    \"low_stock_date\": \"\",\n    \"manage_stock\": false,\n    \"max_sale_qty\": \"\",\n    \"min_qty\": \"\",\n    \"min_sale_qty\": \"\",\n    \"notify_stock_qty\": \"\",\n    \"product_id\": 0,\n    \"qty\": \"\",\n    \"qty_increments\": \"\",\n    \"show_default_notification_message\": false,\n    \"stock_id\": 0,\n    \"stock_status_changed_auto\": 0,\n    \"use_config_backorders\": false,\n    \"use_config_enable_qty_inc\": false,\n    \"use_config_manage_stock\": false,\n    \"use_config_max_sale_qty\": false,\n    \"use_config_min_qty\": false,\n    \"use_config_min_sale_qty\": 0,\n    \"use_config_notify_stock_qty\": false,\n    \"use_config_qty_increments\": false\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:productSku/stockItems/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"stockItem\": {\n    \"backorders\": 0,\n    \"enable_qty_increments\": false,\n    \"extension_attributes\": {},\n    \"is_decimal_divided\": false,\n    \"is_in_stock\": false,\n    \"is_qty_decimal\": false,\n    \"item_id\": 0,\n    \"low_stock_date\": \"\",\n    \"manage_stock\": false,\n    \"max_sale_qty\": \"\",\n    \"min_qty\": \"\",\n    \"min_sale_qty\": \"\",\n    \"notify_stock_qty\": \"\",\n    \"product_id\": 0,\n    \"qty\": \"\",\n    \"qty_increments\": \"\",\n    \"show_default_notification_message\": false,\n    \"stock_id\": 0,\n    \"stock_status_changed_auto\": 0,\n    \"use_config_backorders\": false,\n    \"use_config_enable_qty_inc\": false,\n    \"use_config_manage_stock\": false,\n    \"use_config_max_sale_qty\": false,\n    \"use_config_min_qty\": false,\n    \"use_config_min_sale_qty\": 0,\n    \"use_config_notify_stock_qty\": false,\n    \"use_config_qty_increments\": false\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/V1/products/:productSku/stockItems/:itemId') do |req|
  req.body = "{\n  \"stockItem\": {\n    \"backorders\": 0,\n    \"enable_qty_increments\": false,\n    \"extension_attributes\": {},\n    \"is_decimal_divided\": false,\n    \"is_in_stock\": false,\n    \"is_qty_decimal\": false,\n    \"item_id\": 0,\n    \"low_stock_date\": \"\",\n    \"manage_stock\": false,\n    \"max_sale_qty\": \"\",\n    \"min_qty\": \"\",\n    \"min_sale_qty\": \"\",\n    \"notify_stock_qty\": \"\",\n    \"product_id\": 0,\n    \"qty\": \"\",\n    \"qty_increments\": \"\",\n    \"show_default_notification_message\": false,\n    \"stock_id\": 0,\n    \"stock_status_changed_auto\": 0,\n    \"use_config_backorders\": false,\n    \"use_config_enable_qty_inc\": false,\n    \"use_config_manage_stock\": false,\n    \"use_config_max_sale_qty\": false,\n    \"use_config_min_qty\": false,\n    \"use_config_min_sale_qty\": 0,\n    \"use_config_notify_stock_qty\": false,\n    \"use_config_qty_increments\": false\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}}/V1/products/:productSku/stockItems/:itemId";

    let payload = json!({"stockItem": json!({
            "backorders": 0,
            "enable_qty_increments": false,
            "extension_attributes": json!({}),
            "is_decimal_divided": false,
            "is_in_stock": false,
            "is_qty_decimal": false,
            "item_id": 0,
            "low_stock_date": "",
            "manage_stock": false,
            "max_sale_qty": "",
            "min_qty": "",
            "min_sale_qty": "",
            "notify_stock_qty": "",
            "product_id": 0,
            "qty": "",
            "qty_increments": "",
            "show_default_notification_message": false,
            "stock_id": 0,
            "stock_status_changed_auto": 0,
            "use_config_backorders": false,
            "use_config_enable_qty_inc": false,
            "use_config_manage_stock": false,
            "use_config_max_sale_qty": false,
            "use_config_min_qty": false,
            "use_config_min_sale_qty": 0,
            "use_config_notify_stock_qty": false,
            "use_config_qty_increments": false
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/products/:productSku/stockItems/:itemId \
  --header 'content-type: application/json' \
  --data '{
  "stockItem": {
    "backorders": 0,
    "enable_qty_increments": false,
    "extension_attributes": {},
    "is_decimal_divided": false,
    "is_in_stock": false,
    "is_qty_decimal": false,
    "item_id": 0,
    "low_stock_date": "",
    "manage_stock": false,
    "max_sale_qty": "",
    "min_qty": "",
    "min_sale_qty": "",
    "notify_stock_qty": "",
    "product_id": 0,
    "qty": "",
    "qty_increments": "",
    "show_default_notification_message": false,
    "stock_id": 0,
    "stock_status_changed_auto": 0,
    "use_config_backorders": false,
    "use_config_enable_qty_inc": false,
    "use_config_manage_stock": false,
    "use_config_max_sale_qty": false,
    "use_config_min_qty": false,
    "use_config_min_sale_qty": 0,
    "use_config_notify_stock_qty": false,
    "use_config_qty_increments": false
  }
}'
echo '{
  "stockItem": {
    "backorders": 0,
    "enable_qty_increments": false,
    "extension_attributes": {},
    "is_decimal_divided": false,
    "is_in_stock": false,
    "is_qty_decimal": false,
    "item_id": 0,
    "low_stock_date": "",
    "manage_stock": false,
    "max_sale_qty": "",
    "min_qty": "",
    "min_sale_qty": "",
    "notify_stock_qty": "",
    "product_id": 0,
    "qty": "",
    "qty_increments": "",
    "show_default_notification_message": false,
    "stock_id": 0,
    "stock_status_changed_auto": 0,
    "use_config_backorders": false,
    "use_config_enable_qty_inc": false,
    "use_config_manage_stock": false,
    "use_config_max_sale_qty": false,
    "use_config_min_qty": false,
    "use_config_min_sale_qty": 0,
    "use_config_notify_stock_qty": false,
    "use_config_qty_increments": false
  }
}' |  \
  http PUT {{baseUrl}}/V1/products/:productSku/stockItems/:itemId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "stockItem": {\n    "backorders": 0,\n    "enable_qty_increments": false,\n    "extension_attributes": {},\n    "is_decimal_divided": false,\n    "is_in_stock": false,\n    "is_qty_decimal": false,\n    "item_id": 0,\n    "low_stock_date": "",\n    "manage_stock": false,\n    "max_sale_qty": "",\n    "min_qty": "",\n    "min_sale_qty": "",\n    "notify_stock_qty": "",\n    "product_id": 0,\n    "qty": "",\n    "qty_increments": "",\n    "show_default_notification_message": false,\n    "stock_id": 0,\n    "stock_status_changed_auto": 0,\n    "use_config_backorders": false,\n    "use_config_enable_qty_inc": false,\n    "use_config_manage_stock": false,\n    "use_config_max_sale_qty": false,\n    "use_config_min_qty": false,\n    "use_config_min_sale_qty": 0,\n    "use_config_notify_stock_qty": false,\n    "use_config_qty_increments": false\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/:productSku/stockItems/:itemId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["stockItem": [
    "backorders": 0,
    "enable_qty_increments": false,
    "extension_attributes": [],
    "is_decimal_divided": false,
    "is_in_stock": false,
    "is_qty_decimal": false,
    "item_id": 0,
    "low_stock_date": "",
    "manage_stock": false,
    "max_sale_qty": "",
    "min_qty": "",
    "min_sale_qty": "",
    "notify_stock_qty": "",
    "product_id": 0,
    "qty": "",
    "qty_increments": "",
    "show_default_notification_message": false,
    "stock_id": 0,
    "stock_status_changed_auto": 0,
    "use_config_backorders": false,
    "use_config_enable_qty_inc": false,
    "use_config_manage_stock": false,
    "use_config_max_sale_qty": false,
    "use_config_min_qty": false,
    "use_config_min_sale_qty": 0,
    "use_config_notify_stock_qty": false,
    "use_config_qty_increments": false
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:productSku/stockItems/: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 products-{sku} (GET)
{{baseUrl}}/V1/products/:sku
QUERY PARAMS

sku
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/:sku")
require "http/client"

url = "{{baseUrl}}/V1/products/:sku"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/:sku"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/:sku");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/:sku HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/:sku")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/:sku")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/:sku');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/:sku'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/:sku'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/:sku');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/:sku'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/:sku');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/:sku');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/:sku")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/:sku') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/:sku
http GET {{baseUrl}}/V1/products/:sku
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/:sku
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT products-{sku} (PUT)
{{baseUrl}}/V1/products/:sku
QUERY PARAMS

sku
BODY json

{
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {
          "attribute_id": "",
          "extension_attributes": {},
          "id": 0,
          "is_use_default": false,
          "label": "",
          "position": 0,
          "product_id": 0,
          "values": [
            {
              "extension_attributes": {},
              "value_index": 0
            }
          ]
        }
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  },
  "saveOptions": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/products/:sku" {:content-type :json
                                                            :form-params {:product {:attribute_set_id 0
                                                                                    :created_at ""
                                                                                    :custom_attributes [{:attribute_code ""
                                                                                                         :value ""}]
                                                                                    :extension_attributes {:bundle_product_options [{:extension_attributes {}
                                                                                                                                     :option_id 0
                                                                                                                                     :position 0
                                                                                                                                     :product_links [{:can_change_quantity 0
                                                                                                                                                      :extension_attributes {}
                                                                                                                                                      :id ""
                                                                                                                                                      :is_default false
                                                                                                                                                      :option_id 0
                                                                                                                                                      :position 0
                                                                                                                                                      :price ""
                                                                                                                                                      :price_type 0
                                                                                                                                                      :qty ""
                                                                                                                                                      :sku ""}]
                                                                                                                                     :required false
                                                                                                                                     :sku ""
                                                                                                                                     :title ""
                                                                                                                                     :type ""}]
                                                                                                           :category_links [{:category_id ""
                                                                                                                             :extension_attributes {}
                                                                                                                             :position 0}]
                                                                                                           :configurable_product_links []
                                                                                                           :configurable_product_options [{:attribute_id ""
                                                                                                                                           :extension_attributes {}
                                                                                                                                           :id 0
                                                                                                                                           :is_use_default false
                                                                                                                                           :label ""
                                                                                                                                           :position 0
                                                                                                                                           :product_id 0
                                                                                                                                           :values [{:extension_attributes {}
                                                                                                                                                     :value_index 0}]}]
                                                                                                           :downloadable_product_links [{:extension_attributes {}
                                                                                                                                         :id 0
                                                                                                                                         :is_shareable 0
                                                                                                                                         :link_file ""
                                                                                                                                         :link_file_content {:extension_attributes {}
                                                                                                                                                             :file_data ""
                                                                                                                                                             :name ""}
                                                                                                                                         :link_type ""
                                                                                                                                         :link_url ""
                                                                                                                                         :number_of_downloads 0
                                                                                                                                         :price ""
                                                                                                                                         :sample_file ""
                                                                                                                                         :sample_file_content {}
                                                                                                                                         :sample_type ""
                                                                                                                                         :sample_url ""
                                                                                                                                         :sort_order 0
                                                                                                                                         :title ""}]
                                                                                                           :downloadable_product_samples [{:extension_attributes {}
                                                                                                                                           :id 0
                                                                                                                                           :sample_file ""
                                                                                                                                           :sample_file_content {}
                                                                                                                                           :sample_type ""
                                                                                                                                           :sample_url ""
                                                                                                                                           :sort_order 0
                                                                                                                                           :title ""}]
                                                                                                           :giftcard_amounts [{:attribute_id 0
                                                                                                                               :extension_attributes {}
                                                                                                                               :value ""
                                                                                                                               :website_id 0
                                                                                                                               :website_value ""}]
                                                                                                           :stock_item {:backorders 0
                                                                                                                        :enable_qty_increments false
                                                                                                                        :extension_attributes {}
                                                                                                                        :is_decimal_divided false
                                                                                                                        :is_in_stock false
                                                                                                                        :is_qty_decimal false
                                                                                                                        :item_id 0
                                                                                                                        :low_stock_date ""
                                                                                                                        :manage_stock false
                                                                                                                        :max_sale_qty ""
                                                                                                                        :min_qty ""
                                                                                                                        :min_sale_qty ""
                                                                                                                        :notify_stock_qty ""
                                                                                                                        :product_id 0
                                                                                                                        :qty ""
                                                                                                                        :qty_increments ""
                                                                                                                        :show_default_notification_message false
                                                                                                                        :stock_id 0
                                                                                                                        :stock_status_changed_auto 0
                                                                                                                        :use_config_backorders false
                                                                                                                        :use_config_enable_qty_inc false
                                                                                                                        :use_config_manage_stock false
                                                                                                                        :use_config_max_sale_qty false
                                                                                                                        :use_config_min_qty false
                                                                                                                        :use_config_min_sale_qty 0
                                                                                                                        :use_config_notify_stock_qty false
                                                                                                                        :use_config_qty_increments false}
                                                                                                           :website_ids []}
                                                                                    :id 0
                                                                                    :media_gallery_entries [{:content {:base64_encoded_data ""
                                                                                                                       :name ""
                                                                                                                       :type ""}
                                                                                                             :disabled false
                                                                                                             :extension_attributes {:video_content {:media_type ""
                                                                                                                                                    :video_description ""
                                                                                                                                                    :video_metadata ""
                                                                                                                                                    :video_provider ""
                                                                                                                                                    :video_title ""
                                                                                                                                                    :video_url ""}}
                                                                                                             :file ""
                                                                                                             :id 0
                                                                                                             :label ""
                                                                                                             :media_type ""
                                                                                                             :position 0
                                                                                                             :types []}]
                                                                                    :name ""
                                                                                    :options [{:extension_attributes {:vertex_flex_field ""}
                                                                                               :file_extension ""
                                                                                               :image_size_x 0
                                                                                               :image_size_y 0
                                                                                               :is_require false
                                                                                               :max_characters 0
                                                                                               :option_id 0
                                                                                               :price ""
                                                                                               :price_type ""
                                                                                               :product_sku ""
                                                                                               :sku ""
                                                                                               :sort_order 0
                                                                                               :title ""
                                                                                               :type ""
                                                                                               :values [{:option_type_id 0
                                                                                                         :price ""
                                                                                                         :price_type ""
                                                                                                         :sku ""
                                                                                                         :sort_order 0
                                                                                                         :title ""}]}]
                                                                                    :price ""
                                                                                    :product_links [{:extension_attributes {:qty ""}
                                                                                                     :link_type ""
                                                                                                     :linked_product_sku ""
                                                                                                     :linked_product_type ""
                                                                                                     :position 0
                                                                                                     :sku ""}]
                                                                                    :sku ""
                                                                                    :status 0
                                                                                    :tier_prices [{:customer_group_id 0
                                                                                                   :extension_attributes {:percentage_value ""
                                                                                                                          :website_id 0}
                                                                                                   :qty ""
                                                                                                   :value ""}]
                                                                                    :type_id ""
                                                                                    :updated_at ""
                                                                                    :visibility 0
                                                                                    :weight ""}
                                                                          :saveOptions false}})
require "http/client"

url = "{{baseUrl}}/V1/products/:sku"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": 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}}/V1/products/:sku"),
    Content = new StringContent("{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": 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}}/V1/products/:sku");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku"

	payload := strings.NewReader("{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/products/:sku HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 5402

{
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {
          "attribute_id": "",
          "extension_attributes": {},
          "id": 0,
          "is_use_default": false,
          "label": "",
          "position": 0,
          "product_id": 0,
          "values": [
            {
              "extension_attributes": {},
              "value_index": 0
            }
          ]
        }
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  },
  "saveOptions": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/products/:sku")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": 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  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/products/:sku")
  .header("content-type", "application/json")
  .body("{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}")
  .asString();
const data = JSON.stringify({
  product: {
    attribute_set_id: 0,
    created_at: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    extension_attributes: {
      bundle_product_options: [
        {
          extension_attributes: {},
          option_id: 0,
          position: 0,
          product_links: [
            {
              can_change_quantity: 0,
              extension_attributes: {},
              id: '',
              is_default: false,
              option_id: 0,
              position: 0,
              price: '',
              price_type: 0,
              qty: '',
              sku: ''
            }
          ],
          required: false,
          sku: '',
          title: '',
          type: ''
        }
      ],
      category_links: [
        {
          category_id: '',
          extension_attributes: {},
          position: 0
        }
      ],
      configurable_product_links: [],
      configurable_product_options: [
        {
          attribute_id: '',
          extension_attributes: {},
          id: 0,
          is_use_default: false,
          label: '',
          position: 0,
          product_id: 0,
          values: [
            {
              extension_attributes: {},
              value_index: 0
            }
          ]
        }
      ],
      downloadable_product_links: [
        {
          extension_attributes: {},
          id: 0,
          is_shareable: 0,
          link_file: '',
          link_file_content: {
            extension_attributes: {},
            file_data: '',
            name: ''
          },
          link_type: '',
          link_url: '',
          number_of_downloads: 0,
          price: '',
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      downloadable_product_samples: [
        {
          extension_attributes: {},
          id: 0,
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      giftcard_amounts: [
        {
          attribute_id: 0,
          extension_attributes: {},
          value: '',
          website_id: 0,
          website_value: ''
        }
      ],
      stock_item: {
        backorders: 0,
        enable_qty_increments: false,
        extension_attributes: {},
        is_decimal_divided: false,
        is_in_stock: false,
        is_qty_decimal: false,
        item_id: 0,
        low_stock_date: '',
        manage_stock: false,
        max_sale_qty: '',
        min_qty: '',
        min_sale_qty: '',
        notify_stock_qty: '',
        product_id: 0,
        qty: '',
        qty_increments: '',
        show_default_notification_message: false,
        stock_id: 0,
        stock_status_changed_auto: 0,
        use_config_backorders: false,
        use_config_enable_qty_inc: false,
        use_config_manage_stock: false,
        use_config_max_sale_qty: false,
        use_config_min_qty: false,
        use_config_min_sale_qty: 0,
        use_config_notify_stock_qty: false,
        use_config_qty_increments: false
      },
      website_ids: []
    },
    id: 0,
    media_gallery_entries: [
      {
        content: {
          base64_encoded_data: '',
          name: '',
          type: ''
        },
        disabled: false,
        extension_attributes: {
          video_content: {
            media_type: '',
            video_description: '',
            video_metadata: '',
            video_provider: '',
            video_title: '',
            video_url: ''
          }
        },
        file: '',
        id: 0,
        label: '',
        media_type: '',
        position: 0,
        types: []
      }
    ],
    name: '',
    options: [
      {
        extension_attributes: {
          vertex_flex_field: ''
        },
        file_extension: '',
        image_size_x: 0,
        image_size_y: 0,
        is_require: false,
        max_characters: 0,
        option_id: 0,
        price: '',
        price_type: '',
        product_sku: '',
        sku: '',
        sort_order: 0,
        title: '',
        type: '',
        values: [
          {
            option_type_id: 0,
            price: '',
            price_type: '',
            sku: '',
            sort_order: 0,
            title: ''
          }
        ]
      }
    ],
    price: '',
    product_links: [
      {
        extension_attributes: {
          qty: ''
        },
        link_type: '',
        linked_product_sku: '',
        linked_product_type: '',
        position: 0,
        sku: ''
      }
    ],
    sku: '',
    status: 0,
    tier_prices: [
      {
        customer_group_id: 0,
        extension_attributes: {
          percentage_value: '',
          website_id: 0
        },
        qty: '',
        value: ''
      }
    ],
    type_id: '',
    updated_at: '',
    visibility: 0,
    weight: ''
  },
  saveOptions: 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}}/V1/products/:sku');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/:sku',
  headers: {'content-type': 'application/json'},
  data: {
    product: {
      attribute_set_id: 0,
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {
        bundle_product_options: [
          {
            extension_attributes: {},
            option_id: 0,
            position: 0,
            product_links: [
              {
                can_change_quantity: 0,
                extension_attributes: {},
                id: '',
                is_default: false,
                option_id: 0,
                position: 0,
                price: '',
                price_type: 0,
                qty: '',
                sku: ''
              }
            ],
            required: false,
            sku: '',
            title: '',
            type: ''
          }
        ],
        category_links: [{category_id: '', extension_attributes: {}, position: 0}],
        configurable_product_links: [],
        configurable_product_options: [
          {
            attribute_id: '',
            extension_attributes: {},
            id: 0,
            is_use_default: false,
            label: '',
            position: 0,
            product_id: 0,
            values: [{extension_attributes: {}, value_index: 0}]
          }
        ],
        downloadable_product_links: [
          {
            extension_attributes: {},
            id: 0,
            is_shareable: 0,
            link_file: '',
            link_file_content: {extension_attributes: {}, file_data: '', name: ''},
            link_type: '',
            link_url: '',
            number_of_downloads: 0,
            price: '',
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        downloadable_product_samples: [
          {
            extension_attributes: {},
            id: 0,
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        giftcard_amounts: [
          {
            attribute_id: 0,
            extension_attributes: {},
            value: '',
            website_id: 0,
            website_value: ''
          }
        ],
        stock_item: {
          backorders: 0,
          enable_qty_increments: false,
          extension_attributes: {},
          is_decimal_divided: false,
          is_in_stock: false,
          is_qty_decimal: false,
          item_id: 0,
          low_stock_date: '',
          manage_stock: false,
          max_sale_qty: '',
          min_qty: '',
          min_sale_qty: '',
          notify_stock_qty: '',
          product_id: 0,
          qty: '',
          qty_increments: '',
          show_default_notification_message: false,
          stock_id: 0,
          stock_status_changed_auto: 0,
          use_config_backorders: false,
          use_config_enable_qty_inc: false,
          use_config_manage_stock: false,
          use_config_max_sale_qty: false,
          use_config_min_qty: false,
          use_config_min_sale_qty: 0,
          use_config_notify_stock_qty: false,
          use_config_qty_increments: false
        },
        website_ids: []
      },
      id: 0,
      media_gallery_entries: [
        {
          content: {base64_encoded_data: '', name: '', type: ''},
          disabled: false,
          extension_attributes: {
            video_content: {
              media_type: '',
              video_description: '',
              video_metadata: '',
              video_provider: '',
              video_title: '',
              video_url: ''
            }
          },
          file: '',
          id: 0,
          label: '',
          media_type: '',
          position: 0,
          types: []
        }
      ],
      name: '',
      options: [
        {
          extension_attributes: {vertex_flex_field: ''},
          file_extension: '',
          image_size_x: 0,
          image_size_y: 0,
          is_require: false,
          max_characters: 0,
          option_id: 0,
          price: '',
          price_type: '',
          product_sku: '',
          sku: '',
          sort_order: 0,
          title: '',
          type: '',
          values: [
            {
              option_type_id: 0,
              price: '',
              price_type: '',
              sku: '',
              sort_order: 0,
              title: ''
            }
          ]
        }
      ],
      price: '',
      product_links: [
        {
          extension_attributes: {qty: ''},
          link_type: '',
          linked_product_sku: '',
          linked_product_type: '',
          position: 0,
          sku: ''
        }
      ],
      sku: '',
      status: 0,
      tier_prices: [
        {
          customer_group_id: 0,
          extension_attributes: {percentage_value: '', website_id: 0},
          qty: '',
          value: ''
        }
      ],
      type_id: '',
      updated_at: '',
      visibility: 0,
      weight: ''
    },
    saveOptions: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"product":{"attribute_set_id":0,"created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{"bundle_product_options":[{"extension_attributes":{},"option_id":0,"position":0,"product_links":[{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}],"required":false,"sku":"","title":"","type":""}],"category_links":[{"category_id":"","extension_attributes":{},"position":0}],"configurable_product_links":[],"configurable_product_options":[{"attribute_id":"","extension_attributes":{},"id":0,"is_use_default":false,"label":"","position":0,"product_id":0,"values":[{"extension_attributes":{},"value_index":0}]}],"downloadable_product_links":[{"extension_attributes":{},"id":0,"is_shareable":0,"link_file":"","link_file_content":{"extension_attributes":{},"file_data":"","name":""},"link_type":"","link_url":"","number_of_downloads":0,"price":"","sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"downloadable_product_samples":[{"extension_attributes":{},"id":0,"sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"giftcard_amounts":[{"attribute_id":0,"extension_attributes":{},"value":"","website_id":0,"website_value":""}],"stock_item":{"backorders":0,"enable_qty_increments":false,"extension_attributes":{},"is_decimal_divided":false,"is_in_stock":false,"is_qty_decimal":false,"item_id":0,"low_stock_date":"","manage_stock":false,"max_sale_qty":"","min_qty":"","min_sale_qty":"","notify_stock_qty":"","product_id":0,"qty":"","qty_increments":"","show_default_notification_message":false,"stock_id":0,"stock_status_changed_auto":0,"use_config_backorders":false,"use_config_enable_qty_inc":false,"use_config_manage_stock":false,"use_config_max_sale_qty":false,"use_config_min_qty":false,"use_config_min_sale_qty":0,"use_config_notify_stock_qty":false,"use_config_qty_increments":false},"website_ids":[]},"id":0,"media_gallery_entries":[{"content":{"base64_encoded_data":"","name":"","type":""},"disabled":false,"extension_attributes":{"video_content":{"media_type":"","video_description":"","video_metadata":"","video_provider":"","video_title":"","video_url":""}},"file":"","id":0,"label":"","media_type":"","position":0,"types":[]}],"name":"","options":[{"extension_attributes":{"vertex_flex_field":""},"file_extension":"","image_size_x":0,"image_size_y":0,"is_require":false,"max_characters":0,"option_id":0,"price":"","price_type":"","product_sku":"","sku":"","sort_order":0,"title":"","type":"","values":[{"option_type_id":0,"price":"","price_type":"","sku":"","sort_order":0,"title":""}]}],"price":"","product_links":[{"extension_attributes":{"qty":""},"link_type":"","linked_product_sku":"","linked_product_type":"","position":0,"sku":""}],"sku":"","status":0,"tier_prices":[{"customer_group_id":0,"extension_attributes":{"percentage_value":"","website_id":0},"qty":"","value":""}],"type_id":"","updated_at":"","visibility":0,"weight":""},"saveOptions":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}}/V1/products/:sku',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "product": {\n    "attribute_set_id": 0,\n    "created_at": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "extension_attributes": {\n      "bundle_product_options": [\n        {\n          "extension_attributes": {},\n          "option_id": 0,\n          "position": 0,\n          "product_links": [\n            {\n              "can_change_quantity": 0,\n              "extension_attributes": {},\n              "id": "",\n              "is_default": false,\n              "option_id": 0,\n              "position": 0,\n              "price": "",\n              "price_type": 0,\n              "qty": "",\n              "sku": ""\n            }\n          ],\n          "required": false,\n          "sku": "",\n          "title": "",\n          "type": ""\n        }\n      ],\n      "category_links": [\n        {\n          "category_id": "",\n          "extension_attributes": {},\n          "position": 0\n        }\n      ],\n      "configurable_product_links": [],\n      "configurable_product_options": [\n        {\n          "attribute_id": "",\n          "extension_attributes": {},\n          "id": 0,\n          "is_use_default": false,\n          "label": "",\n          "position": 0,\n          "product_id": 0,\n          "values": [\n            {\n              "extension_attributes": {},\n              "value_index": 0\n            }\n          ]\n        }\n      ],\n      "downloadable_product_links": [\n        {\n          "extension_attributes": {},\n          "id": 0,\n          "is_shareable": 0,\n          "link_file": "",\n          "link_file_content": {\n            "extension_attributes": {},\n            "file_data": "",\n            "name": ""\n          },\n          "link_type": "",\n          "link_url": "",\n          "number_of_downloads": 0,\n          "price": "",\n          "sample_file": "",\n          "sample_file_content": {},\n          "sample_type": "",\n          "sample_url": "",\n          "sort_order": 0,\n          "title": ""\n        }\n      ],\n      "downloadable_product_samples": [\n        {\n          "extension_attributes": {},\n          "id": 0,\n          "sample_file": "",\n          "sample_file_content": {},\n          "sample_type": "",\n          "sample_url": "",\n          "sort_order": 0,\n          "title": ""\n        }\n      ],\n      "giftcard_amounts": [\n        {\n          "attribute_id": 0,\n          "extension_attributes": {},\n          "value": "",\n          "website_id": 0,\n          "website_value": ""\n        }\n      ],\n      "stock_item": {\n        "backorders": 0,\n        "enable_qty_increments": false,\n        "extension_attributes": {},\n        "is_decimal_divided": false,\n        "is_in_stock": false,\n        "is_qty_decimal": false,\n        "item_id": 0,\n        "low_stock_date": "",\n        "manage_stock": false,\n        "max_sale_qty": "",\n        "min_qty": "",\n        "min_sale_qty": "",\n        "notify_stock_qty": "",\n        "product_id": 0,\n        "qty": "",\n        "qty_increments": "",\n        "show_default_notification_message": false,\n        "stock_id": 0,\n        "stock_status_changed_auto": 0,\n        "use_config_backorders": false,\n        "use_config_enable_qty_inc": false,\n        "use_config_manage_stock": false,\n        "use_config_max_sale_qty": false,\n        "use_config_min_qty": false,\n        "use_config_min_sale_qty": 0,\n        "use_config_notify_stock_qty": false,\n        "use_config_qty_increments": false\n      },\n      "website_ids": []\n    },\n    "id": 0,\n    "media_gallery_entries": [\n      {\n        "content": {\n          "base64_encoded_data": "",\n          "name": "",\n          "type": ""\n        },\n        "disabled": false,\n        "extension_attributes": {\n          "video_content": {\n            "media_type": "",\n            "video_description": "",\n            "video_metadata": "",\n            "video_provider": "",\n            "video_title": "",\n            "video_url": ""\n          }\n        },\n        "file": "",\n        "id": 0,\n        "label": "",\n        "media_type": "",\n        "position": 0,\n        "types": []\n      }\n    ],\n    "name": "",\n    "options": [\n      {\n        "extension_attributes": {\n          "vertex_flex_field": ""\n        },\n        "file_extension": "",\n        "image_size_x": 0,\n        "image_size_y": 0,\n        "is_require": false,\n        "max_characters": 0,\n        "option_id": 0,\n        "price": "",\n        "price_type": "",\n        "product_sku": "",\n        "sku": "",\n        "sort_order": 0,\n        "title": "",\n        "type": "",\n        "values": [\n          {\n            "option_type_id": 0,\n            "price": "",\n            "price_type": "",\n            "sku": "",\n            "sort_order": 0,\n            "title": ""\n          }\n        ]\n      }\n    ],\n    "price": "",\n    "product_links": [\n      {\n        "extension_attributes": {\n          "qty": ""\n        },\n        "link_type": "",\n        "linked_product_sku": "",\n        "linked_product_type": "",\n        "position": 0,\n        "sku": ""\n      }\n    ],\n    "sku": "",\n    "status": 0,\n    "tier_prices": [\n      {\n        "customer_group_id": 0,\n        "extension_attributes": {\n          "percentage_value": "",\n          "website_id": 0\n        },\n        "qty": "",\n        "value": ""\n      }\n    ],\n    "type_id": "",\n    "updated_at": "",\n    "visibility": 0,\n    "weight": ""\n  },\n  "saveOptions": 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  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  product: {
    attribute_set_id: 0,
    created_at: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    extension_attributes: {
      bundle_product_options: [
        {
          extension_attributes: {},
          option_id: 0,
          position: 0,
          product_links: [
            {
              can_change_quantity: 0,
              extension_attributes: {},
              id: '',
              is_default: false,
              option_id: 0,
              position: 0,
              price: '',
              price_type: 0,
              qty: '',
              sku: ''
            }
          ],
          required: false,
          sku: '',
          title: '',
          type: ''
        }
      ],
      category_links: [{category_id: '', extension_attributes: {}, position: 0}],
      configurable_product_links: [],
      configurable_product_options: [
        {
          attribute_id: '',
          extension_attributes: {},
          id: 0,
          is_use_default: false,
          label: '',
          position: 0,
          product_id: 0,
          values: [{extension_attributes: {}, value_index: 0}]
        }
      ],
      downloadable_product_links: [
        {
          extension_attributes: {},
          id: 0,
          is_shareable: 0,
          link_file: '',
          link_file_content: {extension_attributes: {}, file_data: '', name: ''},
          link_type: '',
          link_url: '',
          number_of_downloads: 0,
          price: '',
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      downloadable_product_samples: [
        {
          extension_attributes: {},
          id: 0,
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      giftcard_amounts: [
        {
          attribute_id: 0,
          extension_attributes: {},
          value: '',
          website_id: 0,
          website_value: ''
        }
      ],
      stock_item: {
        backorders: 0,
        enable_qty_increments: false,
        extension_attributes: {},
        is_decimal_divided: false,
        is_in_stock: false,
        is_qty_decimal: false,
        item_id: 0,
        low_stock_date: '',
        manage_stock: false,
        max_sale_qty: '',
        min_qty: '',
        min_sale_qty: '',
        notify_stock_qty: '',
        product_id: 0,
        qty: '',
        qty_increments: '',
        show_default_notification_message: false,
        stock_id: 0,
        stock_status_changed_auto: 0,
        use_config_backorders: false,
        use_config_enable_qty_inc: false,
        use_config_manage_stock: false,
        use_config_max_sale_qty: false,
        use_config_min_qty: false,
        use_config_min_sale_qty: 0,
        use_config_notify_stock_qty: false,
        use_config_qty_increments: false
      },
      website_ids: []
    },
    id: 0,
    media_gallery_entries: [
      {
        content: {base64_encoded_data: '', name: '', type: ''},
        disabled: false,
        extension_attributes: {
          video_content: {
            media_type: '',
            video_description: '',
            video_metadata: '',
            video_provider: '',
            video_title: '',
            video_url: ''
          }
        },
        file: '',
        id: 0,
        label: '',
        media_type: '',
        position: 0,
        types: []
      }
    ],
    name: '',
    options: [
      {
        extension_attributes: {vertex_flex_field: ''},
        file_extension: '',
        image_size_x: 0,
        image_size_y: 0,
        is_require: false,
        max_characters: 0,
        option_id: 0,
        price: '',
        price_type: '',
        product_sku: '',
        sku: '',
        sort_order: 0,
        title: '',
        type: '',
        values: [
          {
            option_type_id: 0,
            price: '',
            price_type: '',
            sku: '',
            sort_order: 0,
            title: ''
          }
        ]
      }
    ],
    price: '',
    product_links: [
      {
        extension_attributes: {qty: ''},
        link_type: '',
        linked_product_sku: '',
        linked_product_type: '',
        position: 0,
        sku: ''
      }
    ],
    sku: '',
    status: 0,
    tier_prices: [
      {
        customer_group_id: 0,
        extension_attributes: {percentage_value: '', website_id: 0},
        qty: '',
        value: ''
      }
    ],
    type_id: '',
    updated_at: '',
    visibility: 0,
    weight: ''
  },
  saveOptions: false
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/:sku',
  headers: {'content-type': 'application/json'},
  body: {
    product: {
      attribute_set_id: 0,
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {
        bundle_product_options: [
          {
            extension_attributes: {},
            option_id: 0,
            position: 0,
            product_links: [
              {
                can_change_quantity: 0,
                extension_attributes: {},
                id: '',
                is_default: false,
                option_id: 0,
                position: 0,
                price: '',
                price_type: 0,
                qty: '',
                sku: ''
              }
            ],
            required: false,
            sku: '',
            title: '',
            type: ''
          }
        ],
        category_links: [{category_id: '', extension_attributes: {}, position: 0}],
        configurable_product_links: [],
        configurable_product_options: [
          {
            attribute_id: '',
            extension_attributes: {},
            id: 0,
            is_use_default: false,
            label: '',
            position: 0,
            product_id: 0,
            values: [{extension_attributes: {}, value_index: 0}]
          }
        ],
        downloadable_product_links: [
          {
            extension_attributes: {},
            id: 0,
            is_shareable: 0,
            link_file: '',
            link_file_content: {extension_attributes: {}, file_data: '', name: ''},
            link_type: '',
            link_url: '',
            number_of_downloads: 0,
            price: '',
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        downloadable_product_samples: [
          {
            extension_attributes: {},
            id: 0,
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        giftcard_amounts: [
          {
            attribute_id: 0,
            extension_attributes: {},
            value: '',
            website_id: 0,
            website_value: ''
          }
        ],
        stock_item: {
          backorders: 0,
          enable_qty_increments: false,
          extension_attributes: {},
          is_decimal_divided: false,
          is_in_stock: false,
          is_qty_decimal: false,
          item_id: 0,
          low_stock_date: '',
          manage_stock: false,
          max_sale_qty: '',
          min_qty: '',
          min_sale_qty: '',
          notify_stock_qty: '',
          product_id: 0,
          qty: '',
          qty_increments: '',
          show_default_notification_message: false,
          stock_id: 0,
          stock_status_changed_auto: 0,
          use_config_backorders: false,
          use_config_enable_qty_inc: false,
          use_config_manage_stock: false,
          use_config_max_sale_qty: false,
          use_config_min_qty: false,
          use_config_min_sale_qty: 0,
          use_config_notify_stock_qty: false,
          use_config_qty_increments: false
        },
        website_ids: []
      },
      id: 0,
      media_gallery_entries: [
        {
          content: {base64_encoded_data: '', name: '', type: ''},
          disabled: false,
          extension_attributes: {
            video_content: {
              media_type: '',
              video_description: '',
              video_metadata: '',
              video_provider: '',
              video_title: '',
              video_url: ''
            }
          },
          file: '',
          id: 0,
          label: '',
          media_type: '',
          position: 0,
          types: []
        }
      ],
      name: '',
      options: [
        {
          extension_attributes: {vertex_flex_field: ''},
          file_extension: '',
          image_size_x: 0,
          image_size_y: 0,
          is_require: false,
          max_characters: 0,
          option_id: 0,
          price: '',
          price_type: '',
          product_sku: '',
          sku: '',
          sort_order: 0,
          title: '',
          type: '',
          values: [
            {
              option_type_id: 0,
              price: '',
              price_type: '',
              sku: '',
              sort_order: 0,
              title: ''
            }
          ]
        }
      ],
      price: '',
      product_links: [
        {
          extension_attributes: {qty: ''},
          link_type: '',
          linked_product_sku: '',
          linked_product_type: '',
          position: 0,
          sku: ''
        }
      ],
      sku: '',
      status: 0,
      tier_prices: [
        {
          customer_group_id: 0,
          extension_attributes: {percentage_value: '', website_id: 0},
          qty: '',
          value: ''
        }
      ],
      type_id: '',
      updated_at: '',
      visibility: 0,
      weight: ''
    },
    saveOptions: 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}}/V1/products/:sku');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  product: {
    attribute_set_id: 0,
    created_at: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    extension_attributes: {
      bundle_product_options: [
        {
          extension_attributes: {},
          option_id: 0,
          position: 0,
          product_links: [
            {
              can_change_quantity: 0,
              extension_attributes: {},
              id: '',
              is_default: false,
              option_id: 0,
              position: 0,
              price: '',
              price_type: 0,
              qty: '',
              sku: ''
            }
          ],
          required: false,
          sku: '',
          title: '',
          type: ''
        }
      ],
      category_links: [
        {
          category_id: '',
          extension_attributes: {},
          position: 0
        }
      ],
      configurable_product_links: [],
      configurable_product_options: [
        {
          attribute_id: '',
          extension_attributes: {},
          id: 0,
          is_use_default: false,
          label: '',
          position: 0,
          product_id: 0,
          values: [
            {
              extension_attributes: {},
              value_index: 0
            }
          ]
        }
      ],
      downloadable_product_links: [
        {
          extension_attributes: {},
          id: 0,
          is_shareable: 0,
          link_file: '',
          link_file_content: {
            extension_attributes: {},
            file_data: '',
            name: ''
          },
          link_type: '',
          link_url: '',
          number_of_downloads: 0,
          price: '',
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      downloadable_product_samples: [
        {
          extension_attributes: {},
          id: 0,
          sample_file: '',
          sample_file_content: {},
          sample_type: '',
          sample_url: '',
          sort_order: 0,
          title: ''
        }
      ],
      giftcard_amounts: [
        {
          attribute_id: 0,
          extension_attributes: {},
          value: '',
          website_id: 0,
          website_value: ''
        }
      ],
      stock_item: {
        backorders: 0,
        enable_qty_increments: false,
        extension_attributes: {},
        is_decimal_divided: false,
        is_in_stock: false,
        is_qty_decimal: false,
        item_id: 0,
        low_stock_date: '',
        manage_stock: false,
        max_sale_qty: '',
        min_qty: '',
        min_sale_qty: '',
        notify_stock_qty: '',
        product_id: 0,
        qty: '',
        qty_increments: '',
        show_default_notification_message: false,
        stock_id: 0,
        stock_status_changed_auto: 0,
        use_config_backorders: false,
        use_config_enable_qty_inc: false,
        use_config_manage_stock: false,
        use_config_max_sale_qty: false,
        use_config_min_qty: false,
        use_config_min_sale_qty: 0,
        use_config_notify_stock_qty: false,
        use_config_qty_increments: false
      },
      website_ids: []
    },
    id: 0,
    media_gallery_entries: [
      {
        content: {
          base64_encoded_data: '',
          name: '',
          type: ''
        },
        disabled: false,
        extension_attributes: {
          video_content: {
            media_type: '',
            video_description: '',
            video_metadata: '',
            video_provider: '',
            video_title: '',
            video_url: ''
          }
        },
        file: '',
        id: 0,
        label: '',
        media_type: '',
        position: 0,
        types: []
      }
    ],
    name: '',
    options: [
      {
        extension_attributes: {
          vertex_flex_field: ''
        },
        file_extension: '',
        image_size_x: 0,
        image_size_y: 0,
        is_require: false,
        max_characters: 0,
        option_id: 0,
        price: '',
        price_type: '',
        product_sku: '',
        sku: '',
        sort_order: 0,
        title: '',
        type: '',
        values: [
          {
            option_type_id: 0,
            price: '',
            price_type: '',
            sku: '',
            sort_order: 0,
            title: ''
          }
        ]
      }
    ],
    price: '',
    product_links: [
      {
        extension_attributes: {
          qty: ''
        },
        link_type: '',
        linked_product_sku: '',
        linked_product_type: '',
        position: 0,
        sku: ''
      }
    ],
    sku: '',
    status: 0,
    tier_prices: [
      {
        customer_group_id: 0,
        extension_attributes: {
          percentage_value: '',
          website_id: 0
        },
        qty: '',
        value: ''
      }
    ],
    type_id: '',
    updated_at: '',
    visibility: 0,
    weight: ''
  },
  saveOptions: 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}}/V1/products/:sku',
  headers: {'content-type': 'application/json'},
  data: {
    product: {
      attribute_set_id: 0,
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {
        bundle_product_options: [
          {
            extension_attributes: {},
            option_id: 0,
            position: 0,
            product_links: [
              {
                can_change_quantity: 0,
                extension_attributes: {},
                id: '',
                is_default: false,
                option_id: 0,
                position: 0,
                price: '',
                price_type: 0,
                qty: '',
                sku: ''
              }
            ],
            required: false,
            sku: '',
            title: '',
            type: ''
          }
        ],
        category_links: [{category_id: '', extension_attributes: {}, position: 0}],
        configurable_product_links: [],
        configurable_product_options: [
          {
            attribute_id: '',
            extension_attributes: {},
            id: 0,
            is_use_default: false,
            label: '',
            position: 0,
            product_id: 0,
            values: [{extension_attributes: {}, value_index: 0}]
          }
        ],
        downloadable_product_links: [
          {
            extension_attributes: {},
            id: 0,
            is_shareable: 0,
            link_file: '',
            link_file_content: {extension_attributes: {}, file_data: '', name: ''},
            link_type: '',
            link_url: '',
            number_of_downloads: 0,
            price: '',
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        downloadable_product_samples: [
          {
            extension_attributes: {},
            id: 0,
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        giftcard_amounts: [
          {
            attribute_id: 0,
            extension_attributes: {},
            value: '',
            website_id: 0,
            website_value: ''
          }
        ],
        stock_item: {
          backorders: 0,
          enable_qty_increments: false,
          extension_attributes: {},
          is_decimal_divided: false,
          is_in_stock: false,
          is_qty_decimal: false,
          item_id: 0,
          low_stock_date: '',
          manage_stock: false,
          max_sale_qty: '',
          min_qty: '',
          min_sale_qty: '',
          notify_stock_qty: '',
          product_id: 0,
          qty: '',
          qty_increments: '',
          show_default_notification_message: false,
          stock_id: 0,
          stock_status_changed_auto: 0,
          use_config_backorders: false,
          use_config_enable_qty_inc: false,
          use_config_manage_stock: false,
          use_config_max_sale_qty: false,
          use_config_min_qty: false,
          use_config_min_sale_qty: 0,
          use_config_notify_stock_qty: false,
          use_config_qty_increments: false
        },
        website_ids: []
      },
      id: 0,
      media_gallery_entries: [
        {
          content: {base64_encoded_data: '', name: '', type: ''},
          disabled: false,
          extension_attributes: {
            video_content: {
              media_type: '',
              video_description: '',
              video_metadata: '',
              video_provider: '',
              video_title: '',
              video_url: ''
            }
          },
          file: '',
          id: 0,
          label: '',
          media_type: '',
          position: 0,
          types: []
        }
      ],
      name: '',
      options: [
        {
          extension_attributes: {vertex_flex_field: ''},
          file_extension: '',
          image_size_x: 0,
          image_size_y: 0,
          is_require: false,
          max_characters: 0,
          option_id: 0,
          price: '',
          price_type: '',
          product_sku: '',
          sku: '',
          sort_order: 0,
          title: '',
          type: '',
          values: [
            {
              option_type_id: 0,
              price: '',
              price_type: '',
              sku: '',
              sort_order: 0,
              title: ''
            }
          ]
        }
      ],
      price: '',
      product_links: [
        {
          extension_attributes: {qty: ''},
          link_type: '',
          linked_product_sku: '',
          linked_product_type: '',
          position: 0,
          sku: ''
        }
      ],
      sku: '',
      status: 0,
      tier_prices: [
        {
          customer_group_id: 0,
          extension_attributes: {percentage_value: '', website_id: 0},
          qty: '',
          value: ''
        }
      ],
      type_id: '',
      updated_at: '',
      visibility: 0,
      weight: ''
    },
    saveOptions: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"product":{"attribute_set_id":0,"created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{"bundle_product_options":[{"extension_attributes":{},"option_id":0,"position":0,"product_links":[{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}],"required":false,"sku":"","title":"","type":""}],"category_links":[{"category_id":"","extension_attributes":{},"position":0}],"configurable_product_links":[],"configurable_product_options":[{"attribute_id":"","extension_attributes":{},"id":0,"is_use_default":false,"label":"","position":0,"product_id":0,"values":[{"extension_attributes":{},"value_index":0}]}],"downloadable_product_links":[{"extension_attributes":{},"id":0,"is_shareable":0,"link_file":"","link_file_content":{"extension_attributes":{},"file_data":"","name":""},"link_type":"","link_url":"","number_of_downloads":0,"price":"","sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"downloadable_product_samples":[{"extension_attributes":{},"id":0,"sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"giftcard_amounts":[{"attribute_id":0,"extension_attributes":{},"value":"","website_id":0,"website_value":""}],"stock_item":{"backorders":0,"enable_qty_increments":false,"extension_attributes":{},"is_decimal_divided":false,"is_in_stock":false,"is_qty_decimal":false,"item_id":0,"low_stock_date":"","manage_stock":false,"max_sale_qty":"","min_qty":"","min_sale_qty":"","notify_stock_qty":"","product_id":0,"qty":"","qty_increments":"","show_default_notification_message":false,"stock_id":0,"stock_status_changed_auto":0,"use_config_backorders":false,"use_config_enable_qty_inc":false,"use_config_manage_stock":false,"use_config_max_sale_qty":false,"use_config_min_qty":false,"use_config_min_sale_qty":0,"use_config_notify_stock_qty":false,"use_config_qty_increments":false},"website_ids":[]},"id":0,"media_gallery_entries":[{"content":{"base64_encoded_data":"","name":"","type":""},"disabled":false,"extension_attributes":{"video_content":{"media_type":"","video_description":"","video_metadata":"","video_provider":"","video_title":"","video_url":""}},"file":"","id":0,"label":"","media_type":"","position":0,"types":[]}],"name":"","options":[{"extension_attributes":{"vertex_flex_field":""},"file_extension":"","image_size_x":0,"image_size_y":0,"is_require":false,"max_characters":0,"option_id":0,"price":"","price_type":"","product_sku":"","sku":"","sort_order":0,"title":"","type":"","values":[{"option_type_id":0,"price":"","price_type":"","sku":"","sort_order":0,"title":""}]}],"price":"","product_links":[{"extension_attributes":{"qty":""},"link_type":"","linked_product_sku":"","linked_product_type":"","position":0,"sku":""}],"sku":"","status":0,"tier_prices":[{"customer_group_id":0,"extension_attributes":{"percentage_value":"","website_id":0},"qty":"","value":""}],"type_id":"","updated_at":"","visibility":0,"weight":""},"saveOptions":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"product": @{ @"attribute_set_id": @0, @"created_at": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"extension_attributes": @{ @"bundle_product_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @0, @"position": @0, @"product_links": @[ @{ @"can_change_quantity": @0, @"extension_attributes": @{  }, @"id": @"", @"is_default": @NO, @"option_id": @0, @"position": @0, @"price": @"", @"price_type": @0, @"qty": @"", @"sku": @"" } ], @"required": @NO, @"sku": @"", @"title": @"", @"type": @"" } ], @"category_links": @[ @{ @"category_id": @"", @"extension_attributes": @{  }, @"position": @0 } ], @"configurable_product_links": @[  ], @"configurable_product_options": @[ @{ @"attribute_id": @"", @"extension_attributes": @{  }, @"id": @0, @"is_use_default": @NO, @"label": @"", @"position": @0, @"product_id": @0, @"values": @[ @{ @"extension_attributes": @{  }, @"value_index": @0 } ] } ], @"downloadable_product_links": @[ @{ @"extension_attributes": @{  }, @"id": @0, @"is_shareable": @0, @"link_file": @"", @"link_file_content": @{ @"extension_attributes": @{  }, @"file_data": @"", @"name": @"" }, @"link_type": @"", @"link_url": @"", @"number_of_downloads": @0, @"price": @"", @"sample_file": @"", @"sample_file_content": @{  }, @"sample_type": @"", @"sample_url": @"", @"sort_order": @0, @"title": @"" } ], @"downloadable_product_samples": @[ @{ @"extension_attributes": @{  }, @"id": @0, @"sample_file": @"", @"sample_file_content": @{  }, @"sample_type": @"", @"sample_url": @"", @"sort_order": @0, @"title": @"" } ], @"giftcard_amounts": @[ @{ @"attribute_id": @0, @"extension_attributes": @{  }, @"value": @"", @"website_id": @0, @"website_value": @"" } ], @"stock_item": @{ @"backorders": @0, @"enable_qty_increments": @NO, @"extension_attributes": @{  }, @"is_decimal_divided": @NO, @"is_in_stock": @NO, @"is_qty_decimal": @NO, @"item_id": @0, @"low_stock_date": @"", @"manage_stock": @NO, @"max_sale_qty": @"", @"min_qty": @"", @"min_sale_qty": @"", @"notify_stock_qty": @"", @"product_id": @0, @"qty": @"", @"qty_increments": @"", @"show_default_notification_message": @NO, @"stock_id": @0, @"stock_status_changed_auto": @0, @"use_config_backorders": @NO, @"use_config_enable_qty_inc": @NO, @"use_config_manage_stock": @NO, @"use_config_max_sale_qty": @NO, @"use_config_min_qty": @NO, @"use_config_min_sale_qty": @0, @"use_config_notify_stock_qty": @NO, @"use_config_qty_increments": @NO }, @"website_ids": @[  ] }, @"id": @0, @"media_gallery_entries": @[ @{ @"content": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" }, @"disabled": @NO, @"extension_attributes": @{ @"video_content": @{ @"media_type": @"", @"video_description": @"", @"video_metadata": @"", @"video_provider": @"", @"video_title": @"", @"video_url": @"" } }, @"file": @"", @"id": @0, @"label": @"", @"media_type": @"", @"position": @0, @"types": @[  ] } ], @"name": @"", @"options": @[ @{ @"extension_attributes": @{ @"vertex_flex_field": @"" }, @"file_extension": @"", @"image_size_x": @0, @"image_size_y": @0, @"is_require": @NO, @"max_characters": @0, @"option_id": @0, @"price": @"", @"price_type": @"", @"product_sku": @"", @"sku": @"", @"sort_order": @0, @"title": @"", @"type": @"", @"values": @[ @{ @"option_type_id": @0, @"price": @"", @"price_type": @"", @"sku": @"", @"sort_order": @0, @"title": @"" } ] } ], @"price": @"", @"product_links": @[ @{ @"extension_attributes": @{ @"qty": @"" }, @"link_type": @"", @"linked_product_sku": @"", @"linked_product_type": @"", @"position": @0, @"sku": @"" } ], @"sku": @"", @"status": @0, @"tier_prices": @[ @{ @"customer_group_id": @0, @"extension_attributes": @{ @"percentage_value": @"", @"website_id": @0 }, @"qty": @"", @"value": @"" } ], @"type_id": @"", @"updated_at": @"", @"visibility": @0, @"weight": @"" },
                              @"saveOptions": @NO };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku"]
                                                       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}}/V1/products/:sku" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku",
  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([
    'product' => [
        'attribute_set_id' => 0,
        'created_at' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'extension_attributes' => [
                'bundle_product_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'position' => 0,
                                                                'product_links' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'can_change_quantity' => 0,
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'id' => '',
                                                                                                                                                                                                                                                                'is_default' => null,
                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                'position' => 0,
                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                'price_type' => 0,
                                                                                                                                                                                                                                                                'qty' => '',
                                                                                                                                                                                                                                                                'sku' => ''
                                                                                                                                ]
                                                                ],
                                                                'required' => null,
                                                                'sku' => '',
                                                                'title' => '',
                                                                'type' => ''
                                ]
                ],
                'category_links' => [
                                [
                                                                'category_id' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'position' => 0
                                ]
                ],
                'configurable_product_links' => [
                                
                ],
                'configurable_product_options' => [
                                [
                                                                'attribute_id' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'is_use_default' => null,
                                                                'label' => '',
                                                                'position' => 0,
                                                                'product_id' => 0,
                                                                'values' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'value_index' => 0
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'downloadable_product_links' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'is_shareable' => 0,
                                                                'link_file' => '',
                                                                'link_file_content' => [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'file_data' => '',
                                                                                                                                'name' => ''
                                                                ],
                                                                'link_type' => '',
                                                                'link_url' => '',
                                                                'number_of_downloads' => 0,
                                                                'price' => '',
                                                                'sample_file' => '',
                                                                'sample_file_content' => [
                                                                                                                                
                                                                ],
                                                                'sample_type' => '',
                                                                'sample_url' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ],
                'downloadable_product_samples' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'sample_file' => '',
                                                                'sample_file_content' => [
                                                                                                                                
                                                                ],
                                                                'sample_type' => '',
                                                                'sample_url' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ],
                'giftcard_amounts' => [
                                [
                                                                'attribute_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'value' => '',
                                                                'website_id' => 0,
                                                                'website_value' => ''
                                ]
                ],
                'stock_item' => [
                                'backorders' => 0,
                                'enable_qty_increments' => null,
                                'extension_attributes' => [
                                                                
                                ],
                                'is_decimal_divided' => null,
                                'is_in_stock' => null,
                                'is_qty_decimal' => null,
                                'item_id' => 0,
                                'low_stock_date' => '',
                                'manage_stock' => null,
                                'max_sale_qty' => '',
                                'min_qty' => '',
                                'min_sale_qty' => '',
                                'notify_stock_qty' => '',
                                'product_id' => 0,
                                'qty' => '',
                                'qty_increments' => '',
                                'show_default_notification_message' => null,
                                'stock_id' => 0,
                                'stock_status_changed_auto' => 0,
                                'use_config_backorders' => null,
                                'use_config_enable_qty_inc' => null,
                                'use_config_manage_stock' => null,
                                'use_config_max_sale_qty' => null,
                                'use_config_min_qty' => null,
                                'use_config_min_sale_qty' => 0,
                                'use_config_notify_stock_qty' => null,
                                'use_config_qty_increments' => null
                ],
                'website_ids' => [
                                
                ]
        ],
        'id' => 0,
        'media_gallery_entries' => [
                [
                                'content' => [
                                                                'base64_encoded_data' => '',
                                                                'name' => '',
                                                                'type' => ''
                                ],
                                'disabled' => null,
                                'extension_attributes' => [
                                                                'video_content' => [
                                                                                                                                'media_type' => '',
                                                                                                                                'video_description' => '',
                                                                                                                                'video_metadata' => '',
                                                                                                                                'video_provider' => '',
                                                                                                                                'video_title' => '',
                                                                                                                                'video_url' => ''
                                                                ]
                                ],
                                'file' => '',
                                'id' => 0,
                                'label' => '',
                                'media_type' => '',
                                'position' => 0,
                                'types' => [
                                                                
                                ]
                ]
        ],
        'name' => '',
        'options' => [
                [
                                'extension_attributes' => [
                                                                'vertex_flex_field' => ''
                                ],
                                'file_extension' => '',
                                'image_size_x' => 0,
                                'image_size_y' => 0,
                                'is_require' => null,
                                'max_characters' => 0,
                                'option_id' => 0,
                                'price' => '',
                                'price_type' => '',
                                'product_sku' => '',
                                'sku' => '',
                                'sort_order' => 0,
                                'title' => '',
                                'type' => '',
                                'values' => [
                                                                [
                                                                                                                                'option_type_id' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'price_type' => '',
                                                                                                                                'sku' => '',
                                                                                                                                'sort_order' => 0,
                                                                                                                                'title' => ''
                                                                ]
                                ]
                ]
        ],
        'price' => '',
        'product_links' => [
                [
                                'extension_attributes' => [
                                                                'qty' => ''
                                ],
                                'link_type' => '',
                                'linked_product_sku' => '',
                                'linked_product_type' => '',
                                'position' => 0,
                                'sku' => ''
                ]
        ],
        'sku' => '',
        'status' => 0,
        'tier_prices' => [
                [
                                'customer_group_id' => 0,
                                'extension_attributes' => [
                                                                'percentage_value' => '',
                                                                'website_id' => 0
                                ],
                                'qty' => '',
                                'value' => ''
                ]
        ],
        'type_id' => '',
        'updated_at' => '',
        'visibility' => 0,
        'weight' => ''
    ],
    'saveOptions' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/products/:sku', [
  'body' => '{
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {
          "attribute_id": "",
          "extension_attributes": {},
          "id": 0,
          "is_use_default": false,
          "label": "",
          "position": 0,
          "product_id": 0,
          "values": [
            {
              "extension_attributes": {},
              "value_index": 0
            }
          ]
        }
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  },
  "saveOptions": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'product' => [
    'attribute_set_id' => 0,
    'created_at' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'extension_attributes' => [
        'bundle_product_options' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'option_id' => 0,
                                'position' => 0,
                                'product_links' => [
                                                                [
                                                                                                                                'can_change_quantity' => 0,
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => '',
                                                                                                                                'is_default' => null,
                                                                                                                                'option_id' => 0,
                                                                                                                                'position' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'price_type' => 0,
                                                                                                                                'qty' => '',
                                                                                                                                'sku' => ''
                                                                ]
                                ],
                                'required' => null,
                                'sku' => '',
                                'title' => '',
                                'type' => ''
                ]
        ],
        'category_links' => [
                [
                                'category_id' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'position' => 0
                ]
        ],
        'configurable_product_links' => [
                
        ],
        'configurable_product_options' => [
                [
                                'attribute_id' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => 0,
                                'is_use_default' => null,
                                'label' => '',
                                'position' => 0,
                                'product_id' => 0,
                                'values' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'value_index' => 0
                                                                ]
                                ]
                ]
        ],
        'downloadable_product_links' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => 0,
                                'is_shareable' => 0,
                                'link_file' => '',
                                'link_file_content' => [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'file_data' => '',
                                                                'name' => ''
                                ],
                                'link_type' => '',
                                'link_url' => '',
                                'number_of_downloads' => 0,
                                'price' => '',
                                'sample_file' => '',
                                'sample_file_content' => [
                                                                
                                ],
                                'sample_type' => '',
                                'sample_url' => '',
                                'sort_order' => 0,
                                'title' => ''
                ]
        ],
        'downloadable_product_samples' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => 0,
                                'sample_file' => '',
                                'sample_file_content' => [
                                                                
                                ],
                                'sample_type' => '',
                                'sample_url' => '',
                                'sort_order' => 0,
                                'title' => ''
                ]
        ],
        'giftcard_amounts' => [
                [
                                'attribute_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'value' => '',
                                'website_id' => 0,
                                'website_value' => ''
                ]
        ],
        'stock_item' => [
                'backorders' => 0,
                'enable_qty_increments' => null,
                'extension_attributes' => [
                                
                ],
                'is_decimal_divided' => null,
                'is_in_stock' => null,
                'is_qty_decimal' => null,
                'item_id' => 0,
                'low_stock_date' => '',
                'manage_stock' => null,
                'max_sale_qty' => '',
                'min_qty' => '',
                'min_sale_qty' => '',
                'notify_stock_qty' => '',
                'product_id' => 0,
                'qty' => '',
                'qty_increments' => '',
                'show_default_notification_message' => null,
                'stock_id' => 0,
                'stock_status_changed_auto' => 0,
                'use_config_backorders' => null,
                'use_config_enable_qty_inc' => null,
                'use_config_manage_stock' => null,
                'use_config_max_sale_qty' => null,
                'use_config_min_qty' => null,
                'use_config_min_sale_qty' => 0,
                'use_config_notify_stock_qty' => null,
                'use_config_qty_increments' => null
        ],
        'website_ids' => [
                
        ]
    ],
    'id' => 0,
    'media_gallery_entries' => [
        [
                'content' => [
                                'base64_encoded_data' => '',
                                'name' => '',
                                'type' => ''
                ],
                'disabled' => null,
                'extension_attributes' => [
                                'video_content' => [
                                                                'media_type' => '',
                                                                'video_description' => '',
                                                                'video_metadata' => '',
                                                                'video_provider' => '',
                                                                'video_title' => '',
                                                                'video_url' => ''
                                ]
                ],
                'file' => '',
                'id' => 0,
                'label' => '',
                'media_type' => '',
                'position' => 0,
                'types' => [
                                
                ]
        ]
    ],
    'name' => '',
    'options' => [
        [
                'extension_attributes' => [
                                'vertex_flex_field' => ''
                ],
                'file_extension' => '',
                'image_size_x' => 0,
                'image_size_y' => 0,
                'is_require' => null,
                'max_characters' => 0,
                'option_id' => 0,
                'price' => '',
                'price_type' => '',
                'product_sku' => '',
                'sku' => '',
                'sort_order' => 0,
                'title' => '',
                'type' => '',
                'values' => [
                                [
                                                                'option_type_id' => 0,
                                                                'price' => '',
                                                                'price_type' => '',
                                                                'sku' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ]
        ]
    ],
    'price' => '',
    'product_links' => [
        [
                'extension_attributes' => [
                                'qty' => ''
                ],
                'link_type' => '',
                'linked_product_sku' => '',
                'linked_product_type' => '',
                'position' => 0,
                'sku' => ''
        ]
    ],
    'sku' => '',
    'status' => 0,
    'tier_prices' => [
        [
                'customer_group_id' => 0,
                'extension_attributes' => [
                                'percentage_value' => '',
                                'website_id' => 0
                ],
                'qty' => '',
                'value' => ''
        ]
    ],
    'type_id' => '',
    'updated_at' => '',
    'visibility' => 0,
    'weight' => ''
  ],
  'saveOptions' => null
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'product' => [
    'attribute_set_id' => 0,
    'created_at' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'extension_attributes' => [
        'bundle_product_options' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'option_id' => 0,
                                'position' => 0,
                                'product_links' => [
                                                                [
                                                                                                                                'can_change_quantity' => 0,
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => '',
                                                                                                                                'is_default' => null,
                                                                                                                                'option_id' => 0,
                                                                                                                                'position' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'price_type' => 0,
                                                                                                                                'qty' => '',
                                                                                                                                'sku' => ''
                                                                ]
                                ],
                                'required' => null,
                                'sku' => '',
                                'title' => '',
                                'type' => ''
                ]
        ],
        'category_links' => [
                [
                                'category_id' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'position' => 0
                ]
        ],
        'configurable_product_links' => [
                
        ],
        'configurable_product_options' => [
                [
                                'attribute_id' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => 0,
                                'is_use_default' => null,
                                'label' => '',
                                'position' => 0,
                                'product_id' => 0,
                                'values' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'value_index' => 0
                                                                ]
                                ]
                ]
        ],
        'downloadable_product_links' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => 0,
                                'is_shareable' => 0,
                                'link_file' => '',
                                'link_file_content' => [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'file_data' => '',
                                                                'name' => ''
                                ],
                                'link_type' => '',
                                'link_url' => '',
                                'number_of_downloads' => 0,
                                'price' => '',
                                'sample_file' => '',
                                'sample_file_content' => [
                                                                
                                ],
                                'sample_type' => '',
                                'sample_url' => '',
                                'sort_order' => 0,
                                'title' => ''
                ]
        ],
        'downloadable_product_samples' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => 0,
                                'sample_file' => '',
                                'sample_file_content' => [
                                                                
                                ],
                                'sample_type' => '',
                                'sample_url' => '',
                                'sort_order' => 0,
                                'title' => ''
                ]
        ],
        'giftcard_amounts' => [
                [
                                'attribute_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'value' => '',
                                'website_id' => 0,
                                'website_value' => ''
                ]
        ],
        'stock_item' => [
                'backorders' => 0,
                'enable_qty_increments' => null,
                'extension_attributes' => [
                                
                ],
                'is_decimal_divided' => null,
                'is_in_stock' => null,
                'is_qty_decimal' => null,
                'item_id' => 0,
                'low_stock_date' => '',
                'manage_stock' => null,
                'max_sale_qty' => '',
                'min_qty' => '',
                'min_sale_qty' => '',
                'notify_stock_qty' => '',
                'product_id' => 0,
                'qty' => '',
                'qty_increments' => '',
                'show_default_notification_message' => null,
                'stock_id' => 0,
                'stock_status_changed_auto' => 0,
                'use_config_backorders' => null,
                'use_config_enable_qty_inc' => null,
                'use_config_manage_stock' => null,
                'use_config_max_sale_qty' => null,
                'use_config_min_qty' => null,
                'use_config_min_sale_qty' => 0,
                'use_config_notify_stock_qty' => null,
                'use_config_qty_increments' => null
        ],
        'website_ids' => [
                
        ]
    ],
    'id' => 0,
    'media_gallery_entries' => [
        [
                'content' => [
                                'base64_encoded_data' => '',
                                'name' => '',
                                'type' => ''
                ],
                'disabled' => null,
                'extension_attributes' => [
                                'video_content' => [
                                                                'media_type' => '',
                                                                'video_description' => '',
                                                                'video_metadata' => '',
                                                                'video_provider' => '',
                                                                'video_title' => '',
                                                                'video_url' => ''
                                ]
                ],
                'file' => '',
                'id' => 0,
                'label' => '',
                'media_type' => '',
                'position' => 0,
                'types' => [
                                
                ]
        ]
    ],
    'name' => '',
    'options' => [
        [
                'extension_attributes' => [
                                'vertex_flex_field' => ''
                ],
                'file_extension' => '',
                'image_size_x' => 0,
                'image_size_y' => 0,
                'is_require' => null,
                'max_characters' => 0,
                'option_id' => 0,
                'price' => '',
                'price_type' => '',
                'product_sku' => '',
                'sku' => '',
                'sort_order' => 0,
                'title' => '',
                'type' => '',
                'values' => [
                                [
                                                                'option_type_id' => 0,
                                                                'price' => '',
                                                                'price_type' => '',
                                                                'sku' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ]
        ]
    ],
    'price' => '',
    'product_links' => [
        [
                'extension_attributes' => [
                                'qty' => ''
                ],
                'link_type' => '',
                'linked_product_sku' => '',
                'linked_product_type' => '',
                'position' => 0,
                'sku' => ''
        ]
    ],
    'sku' => '',
    'status' => 0,
    'tier_prices' => [
        [
                'customer_group_id' => 0,
                'extension_attributes' => [
                                'percentage_value' => '',
                                'website_id' => 0
                ],
                'qty' => '',
                'value' => ''
        ]
    ],
    'type_id' => '',
    'updated_at' => '',
    'visibility' => 0,
    'weight' => ''
  ],
  'saveOptions' => null
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/:sku');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {
          "attribute_id": "",
          "extension_attributes": {},
          "id": 0,
          "is_use_default": false,
          "label": "",
          "position": 0,
          "product_id": 0,
          "values": [
            {
              "extension_attributes": {},
              "value_index": 0
            }
          ]
        }
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  },
  "saveOptions": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {
          "attribute_id": "",
          "extension_attributes": {},
          "id": 0,
          "is_use_default": false,
          "label": "",
          "position": 0,
          "product_id": 0,
          "values": [
            {
              "extension_attributes": {},
              "value_index": 0
            }
          ]
        }
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  },
  "saveOptions": false
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/products/:sku", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku"

payload = {
    "product": {
        "attribute_set_id": 0,
        "created_at": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "extension_attributes": {
            "bundle_product_options": [
                {
                    "extension_attributes": {},
                    "option_id": 0,
                    "position": 0,
                    "product_links": [
                        {
                            "can_change_quantity": 0,
                            "extension_attributes": {},
                            "id": "",
                            "is_default": False,
                            "option_id": 0,
                            "position": 0,
                            "price": "",
                            "price_type": 0,
                            "qty": "",
                            "sku": ""
                        }
                    ],
                    "required": False,
                    "sku": "",
                    "title": "",
                    "type": ""
                }
            ],
            "category_links": [
                {
                    "category_id": "",
                    "extension_attributes": {},
                    "position": 0
                }
            ],
            "configurable_product_links": [],
            "configurable_product_options": [
                {
                    "attribute_id": "",
                    "extension_attributes": {},
                    "id": 0,
                    "is_use_default": False,
                    "label": "",
                    "position": 0,
                    "product_id": 0,
                    "values": [
                        {
                            "extension_attributes": {},
                            "value_index": 0
                        }
                    ]
                }
            ],
            "downloadable_product_links": [
                {
                    "extension_attributes": {},
                    "id": 0,
                    "is_shareable": 0,
                    "link_file": "",
                    "link_file_content": {
                        "extension_attributes": {},
                        "file_data": "",
                        "name": ""
                    },
                    "link_type": "",
                    "link_url": "",
                    "number_of_downloads": 0,
                    "price": "",
                    "sample_file": "",
                    "sample_file_content": {},
                    "sample_type": "",
                    "sample_url": "",
                    "sort_order": 0,
                    "title": ""
                }
            ],
            "downloadable_product_samples": [
                {
                    "extension_attributes": {},
                    "id": 0,
                    "sample_file": "",
                    "sample_file_content": {},
                    "sample_type": "",
                    "sample_url": "",
                    "sort_order": 0,
                    "title": ""
                }
            ],
            "giftcard_amounts": [
                {
                    "attribute_id": 0,
                    "extension_attributes": {},
                    "value": "",
                    "website_id": 0,
                    "website_value": ""
                }
            ],
            "stock_item": {
                "backorders": 0,
                "enable_qty_increments": False,
                "extension_attributes": {},
                "is_decimal_divided": False,
                "is_in_stock": False,
                "is_qty_decimal": False,
                "item_id": 0,
                "low_stock_date": "",
                "manage_stock": False,
                "max_sale_qty": "",
                "min_qty": "",
                "min_sale_qty": "",
                "notify_stock_qty": "",
                "product_id": 0,
                "qty": "",
                "qty_increments": "",
                "show_default_notification_message": False,
                "stock_id": 0,
                "stock_status_changed_auto": 0,
                "use_config_backorders": False,
                "use_config_enable_qty_inc": False,
                "use_config_manage_stock": False,
                "use_config_max_sale_qty": False,
                "use_config_min_qty": False,
                "use_config_min_sale_qty": 0,
                "use_config_notify_stock_qty": False,
                "use_config_qty_increments": False
            },
            "website_ids": []
        },
        "id": 0,
        "media_gallery_entries": [
            {
                "content": {
                    "base64_encoded_data": "",
                    "name": "",
                    "type": ""
                },
                "disabled": False,
                "extension_attributes": { "video_content": {
                        "media_type": "",
                        "video_description": "",
                        "video_metadata": "",
                        "video_provider": "",
                        "video_title": "",
                        "video_url": ""
                    } },
                "file": "",
                "id": 0,
                "label": "",
                "media_type": "",
                "position": 0,
                "types": []
            }
        ],
        "name": "",
        "options": [
            {
                "extension_attributes": { "vertex_flex_field": "" },
                "file_extension": "",
                "image_size_x": 0,
                "image_size_y": 0,
                "is_require": False,
                "max_characters": 0,
                "option_id": 0,
                "price": "",
                "price_type": "",
                "product_sku": "",
                "sku": "",
                "sort_order": 0,
                "title": "",
                "type": "",
                "values": [
                    {
                        "option_type_id": 0,
                        "price": "",
                        "price_type": "",
                        "sku": "",
                        "sort_order": 0,
                        "title": ""
                    }
                ]
            }
        ],
        "price": "",
        "product_links": [
            {
                "extension_attributes": { "qty": "" },
                "link_type": "",
                "linked_product_sku": "",
                "linked_product_type": "",
                "position": 0,
                "sku": ""
            }
        ],
        "sku": "",
        "status": 0,
        "tier_prices": [
            {
                "customer_group_id": 0,
                "extension_attributes": {
                    "percentage_value": "",
                    "website_id": 0
                },
                "qty": "",
                "value": ""
            }
        ],
        "type_id": "",
        "updated_at": "",
        "visibility": 0,
        "weight": ""
    },
    "saveOptions": False
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku"

payload <- "{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": false\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": 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/V1/products/:sku') do |req|
  req.body = "{\n  \"product\": {\n    \"attribute_set_id\": 0,\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"extension_attributes\": {\n      \"bundle_product_options\": [\n        {\n          \"extension_attributes\": {},\n          \"option_id\": 0,\n          \"position\": 0,\n          \"product_links\": [\n            {\n              \"can_change_quantity\": 0,\n              \"extension_attributes\": {},\n              \"id\": \"\",\n              \"is_default\": false,\n              \"option_id\": 0,\n              \"position\": 0,\n              \"price\": \"\",\n              \"price_type\": 0,\n              \"qty\": \"\",\n              \"sku\": \"\"\n            }\n          ],\n          \"required\": false,\n          \"sku\": \"\",\n          \"title\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"category_links\": [\n        {\n          \"category_id\": \"\",\n          \"extension_attributes\": {},\n          \"position\": 0\n        }\n      ],\n      \"configurable_product_links\": [],\n      \"configurable_product_options\": [\n        {\n          \"attribute_id\": \"\",\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_use_default\": false,\n          \"label\": \"\",\n          \"position\": 0,\n          \"product_id\": 0,\n          \"values\": [\n            {\n              \"extension_attributes\": {},\n              \"value_index\": 0\n            }\n          ]\n        }\n      ],\n      \"downloadable_product_links\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"is_shareable\": 0,\n          \"link_file\": \"\",\n          \"link_file_content\": {\n            \"extension_attributes\": {},\n            \"file_data\": \"\",\n            \"name\": \"\"\n          },\n          \"link_type\": \"\",\n          \"link_url\": \"\",\n          \"number_of_downloads\": 0,\n          \"price\": \"\",\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"downloadable_product_samples\": [\n        {\n          \"extension_attributes\": {},\n          \"id\": 0,\n          \"sample_file\": \"\",\n          \"sample_file_content\": {},\n          \"sample_type\": \"\",\n          \"sample_url\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\"\n        }\n      ],\n      \"giftcard_amounts\": [\n        {\n          \"attribute_id\": 0,\n          \"extension_attributes\": {},\n          \"value\": \"\",\n          \"website_id\": 0,\n          \"website_value\": \"\"\n        }\n      ],\n      \"stock_item\": {\n        \"backorders\": 0,\n        \"enable_qty_increments\": false,\n        \"extension_attributes\": {},\n        \"is_decimal_divided\": false,\n        \"is_in_stock\": false,\n        \"is_qty_decimal\": false,\n        \"item_id\": 0,\n        \"low_stock_date\": \"\",\n        \"manage_stock\": false,\n        \"max_sale_qty\": \"\",\n        \"min_qty\": \"\",\n        \"min_sale_qty\": \"\",\n        \"notify_stock_qty\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"qty_increments\": \"\",\n        \"show_default_notification_message\": false,\n        \"stock_id\": 0,\n        \"stock_status_changed_auto\": 0,\n        \"use_config_backorders\": false,\n        \"use_config_enable_qty_inc\": false,\n        \"use_config_manage_stock\": false,\n        \"use_config_max_sale_qty\": false,\n        \"use_config_min_qty\": false,\n        \"use_config_min_sale_qty\": 0,\n        \"use_config_notify_stock_qty\": false,\n        \"use_config_qty_increments\": false\n      },\n      \"website_ids\": []\n    },\n    \"id\": 0,\n    \"media_gallery_entries\": [\n      {\n        \"content\": {\n          \"base64_encoded_data\": \"\",\n          \"name\": \"\",\n          \"type\": \"\"\n        },\n        \"disabled\": false,\n        \"extension_attributes\": {\n          \"video_content\": {\n            \"media_type\": \"\",\n            \"video_description\": \"\",\n            \"video_metadata\": \"\",\n            \"video_provider\": \"\",\n            \"video_title\": \"\",\n            \"video_url\": \"\"\n          }\n        },\n        \"file\": \"\",\n        \"id\": 0,\n        \"label\": \"\",\n        \"media_type\": \"\",\n        \"position\": 0,\n        \"types\": []\n      }\n    ],\n    \"name\": \"\",\n    \"options\": [\n      {\n        \"extension_attributes\": {\n          \"vertex_flex_field\": \"\"\n        },\n        \"file_extension\": \"\",\n        \"image_size_x\": 0,\n        \"image_size_y\": 0,\n        \"is_require\": false,\n        \"max_characters\": 0,\n        \"option_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"product_sku\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\",\n        \"type\": \"\",\n        \"values\": [\n          {\n            \"option_type_id\": 0,\n            \"price\": \"\",\n            \"price_type\": \"\",\n            \"sku\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ]\n      }\n    ],\n    \"price\": \"\",\n    \"product_links\": [\n      {\n        \"extension_attributes\": {\n          \"qty\": \"\"\n        },\n        \"link_type\": \"\",\n        \"linked_product_sku\": \"\",\n        \"linked_product_type\": \"\",\n        \"position\": 0,\n        \"sku\": \"\"\n      }\n    ],\n    \"sku\": \"\",\n    \"status\": 0,\n    \"tier_prices\": [\n      {\n        \"customer_group_id\": 0,\n        \"extension_attributes\": {\n          \"percentage_value\": \"\",\n          \"website_id\": 0\n        },\n        \"qty\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"type_id\": \"\",\n    \"updated_at\": \"\",\n    \"visibility\": 0,\n    \"weight\": \"\"\n  },\n  \"saveOptions\": 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}}/V1/products/:sku";

    let payload = json!({
        "product": json!({
            "attribute_set_id": 0,
            "created_at": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "extension_attributes": json!({
                "bundle_product_options": (
                    json!({
                        "extension_attributes": json!({}),
                        "option_id": 0,
                        "position": 0,
                        "product_links": (
                            json!({
                                "can_change_quantity": 0,
                                "extension_attributes": json!({}),
                                "id": "",
                                "is_default": false,
                                "option_id": 0,
                                "position": 0,
                                "price": "",
                                "price_type": 0,
                                "qty": "",
                                "sku": ""
                            })
                        ),
                        "required": false,
                        "sku": "",
                        "title": "",
                        "type": ""
                    })
                ),
                "category_links": (
                    json!({
                        "category_id": "",
                        "extension_attributes": json!({}),
                        "position": 0
                    })
                ),
                "configurable_product_links": (),
                "configurable_product_options": (
                    json!({
                        "attribute_id": "",
                        "extension_attributes": json!({}),
                        "id": 0,
                        "is_use_default": false,
                        "label": "",
                        "position": 0,
                        "product_id": 0,
                        "values": (
                            json!({
                                "extension_attributes": json!({}),
                                "value_index": 0
                            })
                        )
                    })
                ),
                "downloadable_product_links": (
                    json!({
                        "extension_attributes": json!({}),
                        "id": 0,
                        "is_shareable": 0,
                        "link_file": "",
                        "link_file_content": json!({
                            "extension_attributes": json!({}),
                            "file_data": "",
                            "name": ""
                        }),
                        "link_type": "",
                        "link_url": "",
                        "number_of_downloads": 0,
                        "price": "",
                        "sample_file": "",
                        "sample_file_content": json!({}),
                        "sample_type": "",
                        "sample_url": "",
                        "sort_order": 0,
                        "title": ""
                    })
                ),
                "downloadable_product_samples": (
                    json!({
                        "extension_attributes": json!({}),
                        "id": 0,
                        "sample_file": "",
                        "sample_file_content": json!({}),
                        "sample_type": "",
                        "sample_url": "",
                        "sort_order": 0,
                        "title": ""
                    })
                ),
                "giftcard_amounts": (
                    json!({
                        "attribute_id": 0,
                        "extension_attributes": json!({}),
                        "value": "",
                        "website_id": 0,
                        "website_value": ""
                    })
                ),
                "stock_item": json!({
                    "backorders": 0,
                    "enable_qty_increments": false,
                    "extension_attributes": json!({}),
                    "is_decimal_divided": false,
                    "is_in_stock": false,
                    "is_qty_decimal": false,
                    "item_id": 0,
                    "low_stock_date": "",
                    "manage_stock": false,
                    "max_sale_qty": "",
                    "min_qty": "",
                    "min_sale_qty": "",
                    "notify_stock_qty": "",
                    "product_id": 0,
                    "qty": "",
                    "qty_increments": "",
                    "show_default_notification_message": false,
                    "stock_id": 0,
                    "stock_status_changed_auto": 0,
                    "use_config_backorders": false,
                    "use_config_enable_qty_inc": false,
                    "use_config_manage_stock": false,
                    "use_config_max_sale_qty": false,
                    "use_config_min_qty": false,
                    "use_config_min_sale_qty": 0,
                    "use_config_notify_stock_qty": false,
                    "use_config_qty_increments": false
                }),
                "website_ids": ()
            }),
            "id": 0,
            "media_gallery_entries": (
                json!({
                    "content": json!({
                        "base64_encoded_data": "",
                        "name": "",
                        "type": ""
                    }),
                    "disabled": false,
                    "extension_attributes": json!({"video_content": json!({
                            "media_type": "",
                            "video_description": "",
                            "video_metadata": "",
                            "video_provider": "",
                            "video_title": "",
                            "video_url": ""
                        })}),
                    "file": "",
                    "id": 0,
                    "label": "",
                    "media_type": "",
                    "position": 0,
                    "types": ()
                })
            ),
            "name": "",
            "options": (
                json!({
                    "extension_attributes": json!({"vertex_flex_field": ""}),
                    "file_extension": "",
                    "image_size_x": 0,
                    "image_size_y": 0,
                    "is_require": false,
                    "max_characters": 0,
                    "option_id": 0,
                    "price": "",
                    "price_type": "",
                    "product_sku": "",
                    "sku": "",
                    "sort_order": 0,
                    "title": "",
                    "type": "",
                    "values": (
                        json!({
                            "option_type_id": 0,
                            "price": "",
                            "price_type": "",
                            "sku": "",
                            "sort_order": 0,
                            "title": ""
                        })
                    )
                })
            ),
            "price": "",
            "product_links": (
                json!({
                    "extension_attributes": json!({"qty": ""}),
                    "link_type": "",
                    "linked_product_sku": "",
                    "linked_product_type": "",
                    "position": 0,
                    "sku": ""
                })
            ),
            "sku": "",
            "status": 0,
            "tier_prices": (
                json!({
                    "customer_group_id": 0,
                    "extension_attributes": json!({
                        "percentage_value": "",
                        "website_id": 0
                    }),
                    "qty": "",
                    "value": ""
                })
            ),
            "type_id": "",
            "updated_at": "",
            "visibility": 0,
            "weight": ""
        }),
        "saveOptions": false
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/products/:sku \
  --header 'content-type: application/json' \
  --data '{
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {
          "attribute_id": "",
          "extension_attributes": {},
          "id": 0,
          "is_use_default": false,
          "label": "",
          "position": 0,
          "product_id": 0,
          "values": [
            {
              "extension_attributes": {},
              "value_index": 0
            }
          ]
        }
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  },
  "saveOptions": false
}'
echo '{
  "product": {
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "extension_attributes": {
      "bundle_product_options": [
        {
          "extension_attributes": {},
          "option_id": 0,
          "position": 0,
          "product_links": [
            {
              "can_change_quantity": 0,
              "extension_attributes": {},
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            }
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        }
      ],
      "category_links": [
        {
          "category_id": "",
          "extension_attributes": {},
          "position": 0
        }
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        {
          "attribute_id": "",
          "extension_attributes": {},
          "id": 0,
          "is_use_default": false,
          "label": "",
          "position": 0,
          "product_id": 0,
          "values": [
            {
              "extension_attributes": {},
              "value_index": 0
            }
          ]
        }
      ],
      "downloadable_product_links": [
        {
          "extension_attributes": {},
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
          },
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "downloadable_product_samples": [
        {
          "extension_attributes": {},
          "id": 0,
          "sample_file": "",
          "sample_file_content": {},
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        }
      ],
      "giftcard_amounts": [
        {
          "attribute_id": 0,
          "extension_attributes": {},
          "value": "",
          "website_id": 0,
          "website_value": ""
        }
      ],
      "stock_item": {
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": {},
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      },
      "website_ids": []
    },
    "id": 0,
    "media_gallery_entries": [
      {
        "content": {
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        },
        "disabled": false,
        "extension_attributes": {
          "video_content": {
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          }
        },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      }
    ],
    "name": "",
    "options": [
      {
        "extension_attributes": {
          "vertex_flex_field": ""
        },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          {
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          }
        ]
      }
    ],
    "price": "",
    "product_links": [
      {
        "extension_attributes": {
          "qty": ""
        },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      }
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      {
        "customer_group_id": 0,
        "extension_attributes": {
          "percentage_value": "",
          "website_id": 0
        },
        "qty": "",
        "value": ""
      }
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  },
  "saveOptions": false
}' |  \
  http PUT {{baseUrl}}/V1/products/:sku \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "product": {\n    "attribute_set_id": 0,\n    "created_at": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "extension_attributes": {\n      "bundle_product_options": [\n        {\n          "extension_attributes": {},\n          "option_id": 0,\n          "position": 0,\n          "product_links": [\n            {\n              "can_change_quantity": 0,\n              "extension_attributes": {},\n              "id": "",\n              "is_default": false,\n              "option_id": 0,\n              "position": 0,\n              "price": "",\n              "price_type": 0,\n              "qty": "",\n              "sku": ""\n            }\n          ],\n          "required": false,\n          "sku": "",\n          "title": "",\n          "type": ""\n        }\n      ],\n      "category_links": [\n        {\n          "category_id": "",\n          "extension_attributes": {},\n          "position": 0\n        }\n      ],\n      "configurable_product_links": [],\n      "configurable_product_options": [\n        {\n          "attribute_id": "",\n          "extension_attributes": {},\n          "id": 0,\n          "is_use_default": false,\n          "label": "",\n          "position": 0,\n          "product_id": 0,\n          "values": [\n            {\n              "extension_attributes": {},\n              "value_index": 0\n            }\n          ]\n        }\n      ],\n      "downloadable_product_links": [\n        {\n          "extension_attributes": {},\n          "id": 0,\n          "is_shareable": 0,\n          "link_file": "",\n          "link_file_content": {\n            "extension_attributes": {},\n            "file_data": "",\n            "name": ""\n          },\n          "link_type": "",\n          "link_url": "",\n          "number_of_downloads": 0,\n          "price": "",\n          "sample_file": "",\n          "sample_file_content": {},\n          "sample_type": "",\n          "sample_url": "",\n          "sort_order": 0,\n          "title": ""\n        }\n      ],\n      "downloadable_product_samples": [\n        {\n          "extension_attributes": {},\n          "id": 0,\n          "sample_file": "",\n          "sample_file_content": {},\n          "sample_type": "",\n          "sample_url": "",\n          "sort_order": 0,\n          "title": ""\n        }\n      ],\n      "giftcard_amounts": [\n        {\n          "attribute_id": 0,\n          "extension_attributes": {},\n          "value": "",\n          "website_id": 0,\n          "website_value": ""\n        }\n      ],\n      "stock_item": {\n        "backorders": 0,\n        "enable_qty_increments": false,\n        "extension_attributes": {},\n        "is_decimal_divided": false,\n        "is_in_stock": false,\n        "is_qty_decimal": false,\n        "item_id": 0,\n        "low_stock_date": "",\n        "manage_stock": false,\n        "max_sale_qty": "",\n        "min_qty": "",\n        "min_sale_qty": "",\n        "notify_stock_qty": "",\n        "product_id": 0,\n        "qty": "",\n        "qty_increments": "",\n        "show_default_notification_message": false,\n        "stock_id": 0,\n        "stock_status_changed_auto": 0,\n        "use_config_backorders": false,\n        "use_config_enable_qty_inc": false,\n        "use_config_manage_stock": false,\n        "use_config_max_sale_qty": false,\n        "use_config_min_qty": false,\n        "use_config_min_sale_qty": 0,\n        "use_config_notify_stock_qty": false,\n        "use_config_qty_increments": false\n      },\n      "website_ids": []\n    },\n    "id": 0,\n    "media_gallery_entries": [\n      {\n        "content": {\n          "base64_encoded_data": "",\n          "name": "",\n          "type": ""\n        },\n        "disabled": false,\n        "extension_attributes": {\n          "video_content": {\n            "media_type": "",\n            "video_description": "",\n            "video_metadata": "",\n            "video_provider": "",\n            "video_title": "",\n            "video_url": ""\n          }\n        },\n        "file": "",\n        "id": 0,\n        "label": "",\n        "media_type": "",\n        "position": 0,\n        "types": []\n      }\n    ],\n    "name": "",\n    "options": [\n      {\n        "extension_attributes": {\n          "vertex_flex_field": ""\n        },\n        "file_extension": "",\n        "image_size_x": 0,\n        "image_size_y": 0,\n        "is_require": false,\n        "max_characters": 0,\n        "option_id": 0,\n        "price": "",\n        "price_type": "",\n        "product_sku": "",\n        "sku": "",\n        "sort_order": 0,\n        "title": "",\n        "type": "",\n        "values": [\n          {\n            "option_type_id": 0,\n            "price": "",\n            "price_type": "",\n            "sku": "",\n            "sort_order": 0,\n            "title": ""\n          }\n        ]\n      }\n    ],\n    "price": "",\n    "product_links": [\n      {\n        "extension_attributes": {\n          "qty": ""\n        },\n        "link_type": "",\n        "linked_product_sku": "",\n        "linked_product_type": "",\n        "position": 0,\n        "sku": ""\n      }\n    ],\n    "sku": "",\n    "status": 0,\n    "tier_prices": [\n      {\n        "customer_group_id": 0,\n        "extension_attributes": {\n          "percentage_value": "",\n          "website_id": 0\n        },\n        "qty": "",\n        "value": ""\n      }\n    ],\n    "type_id": "",\n    "updated_at": "",\n    "visibility": 0,\n    "weight": ""\n  },\n  "saveOptions": false\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/:sku
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "product": [
    "attribute_set_id": 0,
    "created_at": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "extension_attributes": [
      "bundle_product_options": [
        [
          "extension_attributes": [],
          "option_id": 0,
          "position": 0,
          "product_links": [
            [
              "can_change_quantity": 0,
              "extension_attributes": [],
              "id": "",
              "is_default": false,
              "option_id": 0,
              "position": 0,
              "price": "",
              "price_type": 0,
              "qty": "",
              "sku": ""
            ]
          ],
          "required": false,
          "sku": "",
          "title": "",
          "type": ""
        ]
      ],
      "category_links": [
        [
          "category_id": "",
          "extension_attributes": [],
          "position": 0
        ]
      ],
      "configurable_product_links": [],
      "configurable_product_options": [
        [
          "attribute_id": "",
          "extension_attributes": [],
          "id": 0,
          "is_use_default": false,
          "label": "",
          "position": 0,
          "product_id": 0,
          "values": [
            [
              "extension_attributes": [],
              "value_index": 0
            ]
          ]
        ]
      ],
      "downloadable_product_links": [
        [
          "extension_attributes": [],
          "id": 0,
          "is_shareable": 0,
          "link_file": "",
          "link_file_content": [
            "extension_attributes": [],
            "file_data": "",
            "name": ""
          ],
          "link_type": "",
          "link_url": "",
          "number_of_downloads": 0,
          "price": "",
          "sample_file": "",
          "sample_file_content": [],
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        ]
      ],
      "downloadable_product_samples": [
        [
          "extension_attributes": [],
          "id": 0,
          "sample_file": "",
          "sample_file_content": [],
          "sample_type": "",
          "sample_url": "",
          "sort_order": 0,
          "title": ""
        ]
      ],
      "giftcard_amounts": [
        [
          "attribute_id": 0,
          "extension_attributes": [],
          "value": "",
          "website_id": 0,
          "website_value": ""
        ]
      ],
      "stock_item": [
        "backorders": 0,
        "enable_qty_increments": false,
        "extension_attributes": [],
        "is_decimal_divided": false,
        "is_in_stock": false,
        "is_qty_decimal": false,
        "item_id": 0,
        "low_stock_date": "",
        "manage_stock": false,
        "max_sale_qty": "",
        "min_qty": "",
        "min_sale_qty": "",
        "notify_stock_qty": "",
        "product_id": 0,
        "qty": "",
        "qty_increments": "",
        "show_default_notification_message": false,
        "stock_id": 0,
        "stock_status_changed_auto": 0,
        "use_config_backorders": false,
        "use_config_enable_qty_inc": false,
        "use_config_manage_stock": false,
        "use_config_max_sale_qty": false,
        "use_config_min_qty": false,
        "use_config_min_sale_qty": 0,
        "use_config_notify_stock_qty": false,
        "use_config_qty_increments": false
      ],
      "website_ids": []
    ],
    "id": 0,
    "media_gallery_entries": [
      [
        "content": [
          "base64_encoded_data": "",
          "name": "",
          "type": ""
        ],
        "disabled": false,
        "extension_attributes": ["video_content": [
            "media_type": "",
            "video_description": "",
            "video_metadata": "",
            "video_provider": "",
            "video_title": "",
            "video_url": ""
          ]],
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
      ]
    ],
    "name": "",
    "options": [
      [
        "extension_attributes": ["vertex_flex_field": ""],
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": false,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
          [
            "option_type_id": 0,
            "price": "",
            "price_type": "",
            "sku": "",
            "sort_order": 0,
            "title": ""
          ]
        ]
      ]
    ],
    "price": "",
    "product_links": [
      [
        "extension_attributes": ["qty": ""],
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
      ]
    ],
    "sku": "",
    "status": 0,
    "tier_prices": [
      [
        "customer_group_id": 0,
        "extension_attributes": [
          "percentage_value": "",
          "website_id": 0
        ],
        "qty": "",
        "value": ""
      ]
    ],
    "type_id": "",
    "updated_at": "",
    "visibility": 0,
    "weight": ""
  ],
  "saveOptions": false
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku")! 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()
DELETE products-{sku}
{{baseUrl}}/V1/products/:sku
QUERY PARAMS

sku
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/products/:sku")
require "http/client"

url = "{{baseUrl}}/V1/products/:sku"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/products/:sku"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/:sku");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/products/:sku HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/products/:sku")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku"))
    .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}}/V1/products/:sku")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/products/:sku")
  .asString();
const 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}}/V1/products/:sku');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/products/:sku'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/products/:sku'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/products/:sku');

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}}/V1/products/:sku'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/products/:sku');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/:sku');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/products/:sku")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/products/:sku') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/products/:sku
http DELETE {{baseUrl}}/V1/products/:sku
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/products/:sku
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST products-{sku}-downloadable-links (POST)
{{baseUrl}}/V1/products/:sku/downloadable-links
QUERY PARAMS

sku
BODY json

{
  "isGlobalScopeContent": false,
  "link": {
    "extension_attributes": {},
    "id": 0,
    "is_shareable": 0,
    "link_file": "",
    "link_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "link_type": "",
    "link_url": "",
    "number_of_downloads": 0,
    "price": "",
    "sample_file": "",
    "sample_file_content": {},
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/downloadable-links");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/:sku/downloadable-links" {:content-type :json
                                                                                :form-params {:isGlobalScopeContent false
                                                                                              :link {:extension_attributes {}
                                                                                                     :id 0
                                                                                                     :is_shareable 0
                                                                                                     :link_file ""
                                                                                                     :link_file_content {:extension_attributes {}
                                                                                                                         :file_data ""
                                                                                                                         :name ""}
                                                                                                     :link_type ""
                                                                                                     :link_url ""
                                                                                                     :number_of_downloads 0
                                                                                                     :price ""
                                                                                                     :sample_file ""
                                                                                                     :sample_file_content {}
                                                                                                     :sample_type ""
                                                                                                     :sample_url ""
                                                                                                     :sort_order 0
                                                                                                     :title ""}}})
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/downloadable-links"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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}}/V1/products/:sku/downloadable-links"),
    Content = new StringContent("{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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}}/V1/products/:sku/downloadable-links");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/downloadable-links"

	payload := strings.NewReader("{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/:sku/downloadable-links HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 473

{
  "isGlobalScopeContent": false,
  "link": {
    "extension_attributes": {},
    "id": 0,
    "is_shareable": 0,
    "link_file": "",
    "link_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "link_type": "",
    "link_url": "",
    "number_of_downloads": 0,
    "price": "",
    "sample_file": "",
    "sample_file_content": {},
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/:sku/downloadable-links")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/downloadable-links"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/downloadable-links")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/:sku/downloadable-links")
  .header("content-type", "application/json")
  .body("{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  isGlobalScopeContent: false,
  link: {
    extension_attributes: {},
    id: 0,
    is_shareable: 0,
    link_file: '',
    link_file_content: {
      extension_attributes: {},
      file_data: '',
      name: ''
    },
    link_type: '',
    link_url: '',
    number_of_downloads: 0,
    price: '',
    sample_file: '',
    sample_file_content: {},
    sample_type: '',
    sample_url: '',
    sort_order: 0,
    title: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/products/:sku/downloadable-links');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links',
  headers: {'content-type': 'application/json'},
  data: {
    isGlobalScopeContent: false,
    link: {
      extension_attributes: {},
      id: 0,
      is_shareable: 0,
      link_file: '',
      link_file_content: {extension_attributes: {}, file_data: '', name: ''},
      link_type: '',
      link_url: '',
      number_of_downloads: 0,
      price: '',
      sample_file: '',
      sample_file_content: {},
      sample_type: '',
      sample_url: '',
      sort_order: 0,
      title: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/downloadable-links';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"isGlobalScopeContent":false,"link":{"extension_attributes":{},"id":0,"is_shareable":0,"link_file":"","link_file_content":{"extension_attributes":{},"file_data":"","name":""},"link_type":"","link_url":"","number_of_downloads":0,"price":"","sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "isGlobalScopeContent": false,\n  "link": {\n    "extension_attributes": {},\n    "id": 0,\n    "is_shareable": 0,\n    "link_file": "",\n    "link_file_content": {\n      "extension_attributes": {},\n      "file_data": "",\n      "name": ""\n    },\n    "link_type": "",\n    "link_url": "",\n    "number_of_downloads": 0,\n    "price": "",\n    "sample_file": "",\n    "sample_file_content": {},\n    "sample_type": "",\n    "sample_url": "",\n    "sort_order": 0,\n    "title": ""\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  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/downloadable-links")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/downloadable-links',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  isGlobalScopeContent: false,
  link: {
    extension_attributes: {},
    id: 0,
    is_shareable: 0,
    link_file: '',
    link_file_content: {extension_attributes: {}, file_data: '', name: ''},
    link_type: '',
    link_url: '',
    number_of_downloads: 0,
    price: '',
    sample_file: '',
    sample_file_content: {},
    sample_type: '',
    sample_url: '',
    sort_order: 0,
    title: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links',
  headers: {'content-type': 'application/json'},
  body: {
    isGlobalScopeContent: false,
    link: {
      extension_attributes: {},
      id: 0,
      is_shareable: 0,
      link_file: '',
      link_file_content: {extension_attributes: {}, file_data: '', name: ''},
      link_type: '',
      link_url: '',
      number_of_downloads: 0,
      price: '',
      sample_file: '',
      sample_file_content: {},
      sample_type: '',
      sample_url: '',
      sort_order: 0,
      title: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/products/:sku/downloadable-links');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  isGlobalScopeContent: false,
  link: {
    extension_attributes: {},
    id: 0,
    is_shareable: 0,
    link_file: '',
    link_file_content: {
      extension_attributes: {},
      file_data: '',
      name: ''
    },
    link_type: '',
    link_url: '',
    number_of_downloads: 0,
    price: '',
    sample_file: '',
    sample_file_content: {},
    sample_type: '',
    sample_url: '',
    sort_order: 0,
    title: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links',
  headers: {'content-type': 'application/json'},
  data: {
    isGlobalScopeContent: false,
    link: {
      extension_attributes: {},
      id: 0,
      is_shareable: 0,
      link_file: '',
      link_file_content: {extension_attributes: {}, file_data: '', name: ''},
      link_type: '',
      link_url: '',
      number_of_downloads: 0,
      price: '',
      sample_file: '',
      sample_file_content: {},
      sample_type: '',
      sample_url: '',
      sort_order: 0,
      title: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/downloadable-links';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"isGlobalScopeContent":false,"link":{"extension_attributes":{},"id":0,"is_shareable":0,"link_file":"","link_file_content":{"extension_attributes":{},"file_data":"","name":""},"link_type":"","link_url":"","number_of_downloads":0,"price":"","sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"isGlobalScopeContent": @NO,
                              @"link": @{ @"extension_attributes": @{  }, @"id": @0, @"is_shareable": @0, @"link_file": @"", @"link_file_content": @{ @"extension_attributes": @{  }, @"file_data": @"", @"name": @"" }, @"link_type": @"", @"link_url": @"", @"number_of_downloads": @0, @"price": @"", @"sample_file": @"", @"sample_file_content": @{  }, @"sample_type": @"", @"sample_url": @"", @"sort_order": @0, @"title": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/downloadable-links"]
                                                       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}}/V1/products/:sku/downloadable-links" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/downloadable-links",
  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([
    'isGlobalScopeContent' => null,
    'link' => [
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'is_shareable' => 0,
        'link_file' => '',
        'link_file_content' => [
                'extension_attributes' => [
                                
                ],
                'file_data' => '',
                'name' => ''
        ],
        'link_type' => '',
        'link_url' => '',
        'number_of_downloads' => 0,
        'price' => '',
        'sample_file' => '',
        'sample_file_content' => [
                
        ],
        'sample_type' => '',
        'sample_url' => '',
        'sort_order' => 0,
        'title' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/:sku/downloadable-links', [
  'body' => '{
  "isGlobalScopeContent": false,
  "link": {
    "extension_attributes": {},
    "id": 0,
    "is_shareable": 0,
    "link_file": "",
    "link_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "link_type": "",
    "link_url": "",
    "number_of_downloads": 0,
    "price": "",
    "sample_file": "",
    "sample_file_content": {},
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/downloadable-links');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'isGlobalScopeContent' => null,
  'link' => [
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'is_shareable' => 0,
    'link_file' => '',
    'link_file_content' => [
        'extension_attributes' => [
                
        ],
        'file_data' => '',
        'name' => ''
    ],
    'link_type' => '',
    'link_url' => '',
    'number_of_downloads' => 0,
    'price' => '',
    'sample_file' => '',
    'sample_file_content' => [
        
    ],
    'sample_type' => '',
    'sample_url' => '',
    'sort_order' => 0,
    'title' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'isGlobalScopeContent' => null,
  'link' => [
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'is_shareable' => 0,
    'link_file' => '',
    'link_file_content' => [
        'extension_attributes' => [
                
        ],
        'file_data' => '',
        'name' => ''
    ],
    'link_type' => '',
    'link_url' => '',
    'number_of_downloads' => 0,
    'price' => '',
    'sample_file' => '',
    'sample_file_content' => [
        
    ],
    'sample_type' => '',
    'sample_url' => '',
    'sort_order' => 0,
    'title' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/:sku/downloadable-links');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/downloadable-links' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "isGlobalScopeContent": false,
  "link": {
    "extension_attributes": {},
    "id": 0,
    "is_shareable": 0,
    "link_file": "",
    "link_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "link_type": "",
    "link_url": "",
    "number_of_downloads": 0,
    "price": "",
    "sample_file": "",
    "sample_file_content": {},
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/downloadable-links' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "isGlobalScopeContent": false,
  "link": {
    "extension_attributes": {},
    "id": 0,
    "is_shareable": 0,
    "link_file": "",
    "link_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "link_type": "",
    "link_url": "",
    "number_of_downloads": 0,
    "price": "",
    "sample_file": "",
    "sample_file_content": {},
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/:sku/downloadable-links", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/downloadable-links"

payload = {
    "isGlobalScopeContent": False,
    "link": {
        "extension_attributes": {},
        "id": 0,
        "is_shareable": 0,
        "link_file": "",
        "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
        },
        "link_type": "",
        "link_url": "",
        "number_of_downloads": 0,
        "price": "",
        "sample_file": "",
        "sample_file_content": {},
        "sample_type": "",
        "sample_url": "",
        "sort_order": 0,
        "title": ""
    }
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/downloadable-links"

payload <- "{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/downloadable-links")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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/V1/products/:sku/downloadable-links') do |req|
  req.body = "{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/downloadable-links";

    let payload = json!({
        "isGlobalScopeContent": false,
        "link": json!({
            "extension_attributes": json!({}),
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": json!({
                "extension_attributes": json!({}),
                "file_data": "",
                "name": ""
            }),
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": json!({}),
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/:sku/downloadable-links \
  --header 'content-type: application/json' \
  --data '{
  "isGlobalScopeContent": false,
  "link": {
    "extension_attributes": {},
    "id": 0,
    "is_shareable": 0,
    "link_file": "",
    "link_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "link_type": "",
    "link_url": "",
    "number_of_downloads": 0,
    "price": "",
    "sample_file": "",
    "sample_file_content": {},
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}'
echo '{
  "isGlobalScopeContent": false,
  "link": {
    "extension_attributes": {},
    "id": 0,
    "is_shareable": 0,
    "link_file": "",
    "link_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "link_type": "",
    "link_url": "",
    "number_of_downloads": 0,
    "price": "",
    "sample_file": "",
    "sample_file_content": {},
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/products/:sku/downloadable-links \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "isGlobalScopeContent": false,\n  "link": {\n    "extension_attributes": {},\n    "id": 0,\n    "is_shareable": 0,\n    "link_file": "",\n    "link_file_content": {\n      "extension_attributes": {},\n      "file_data": "",\n      "name": ""\n    },\n    "link_type": "",\n    "link_url": "",\n    "number_of_downloads": 0,\n    "price": "",\n    "sample_file": "",\n    "sample_file_content": {},\n    "sample_type": "",\n    "sample_url": "",\n    "sort_order": 0,\n    "title": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/downloadable-links
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "isGlobalScopeContent": false,
  "link": [
    "extension_attributes": [],
    "id": 0,
    "is_shareable": 0,
    "link_file": "",
    "link_file_content": [
      "extension_attributes": [],
      "file_data": "",
      "name": ""
    ],
    "link_type": "",
    "link_url": "",
    "number_of_downloads": 0,
    "price": "",
    "sample_file": "",
    "sample_file_content": [],
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/downloadable-links")! 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}}/V1/products/:sku/downloadable-links");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/:sku/downloadable-links")
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/downloadable-links"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/:sku/downloadable-links"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/:sku/downloadable-links");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/downloadable-links"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/:sku/downloadable-links HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/:sku/downloadable-links")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/downloadable-links"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/downloadable-links")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/:sku/downloadable-links")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/:sku/downloadable-links');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/downloadable-links';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/downloadable-links")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/downloadable-links',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/:sku/downloadable-links');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/downloadable-links';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/downloadable-links"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku/downloadable-links" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/downloadable-links",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/:sku/downloadable-links');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/downloadable-links');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/:sku/downloadable-links');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/downloadable-links' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/downloadable-links' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/:sku/downloadable-links")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/downloadable-links"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/downloadable-links"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/downloadable-links")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/:sku/downloadable-links') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/downloadable-links";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/:sku/downloadable-links
http GET {{baseUrl}}/V1/products/:sku/downloadable-links
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/downloadable-links
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/downloadable-links")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/downloadable-links/:id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/products/:sku/downloadable-links/:id" {:content-type :json
                                                                                   :form-params {:isGlobalScopeContent false
                                                                                                 :link {:extension_attributes {}
                                                                                                        :id 0
                                                                                                        :is_shareable 0
                                                                                                        :link_file ""
                                                                                                        :link_file_content {:extension_attributes {}
                                                                                                                            :file_data ""
                                                                                                                            :name ""}
                                                                                                        :link_type ""
                                                                                                        :link_url ""
                                                                                                        :number_of_downloads 0
                                                                                                        :price ""
                                                                                                        :sample_file ""
                                                                                                        :sample_file_content {}
                                                                                                        :sample_type ""
                                                                                                        :sample_url ""
                                                                                                        :sort_order 0
                                                                                                        :title ""}}})
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/downloadable-links/:id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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}}/V1/products/:sku/downloadable-links/:id"),
    Content = new StringContent("{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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}}/V1/products/:sku/downloadable-links/:id");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/downloadable-links/:id"

	payload := strings.NewReader("{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/products/:sku/downloadable-links/:id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 473

{
  "isGlobalScopeContent": false,
  "link": {
    "extension_attributes": {},
    "id": 0,
    "is_shareable": 0,
    "link_file": "",
    "link_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "link_type": "",
    "link_url": "",
    "number_of_downloads": 0,
    "price": "",
    "sample_file": "",
    "sample_file_content": {},
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/products/:sku/downloadable-links/:id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/downloadable-links/:id"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/downloadable-links/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/products/:sku/downloadable-links/:id")
  .header("content-type", "application/json")
  .body("{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  isGlobalScopeContent: false,
  link: {
    extension_attributes: {},
    id: 0,
    is_shareable: 0,
    link_file: '',
    link_file_content: {
      extension_attributes: {},
      file_data: '',
      name: ''
    },
    link_type: '',
    link_url: '',
    number_of_downloads: 0,
    price: '',
    sample_file: '',
    sample_file_content: {},
    sample_type: '',
    sample_url: '',
    sort_order: 0,
    title: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/products/:sku/downloadable-links/:id');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links/:id',
  headers: {'content-type': 'application/json'},
  data: {
    isGlobalScopeContent: false,
    link: {
      extension_attributes: {},
      id: 0,
      is_shareable: 0,
      link_file: '',
      link_file_content: {extension_attributes: {}, file_data: '', name: ''},
      link_type: '',
      link_url: '',
      number_of_downloads: 0,
      price: '',
      sample_file: '',
      sample_file_content: {},
      sample_type: '',
      sample_url: '',
      sort_order: 0,
      title: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/downloadable-links/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"isGlobalScopeContent":false,"link":{"extension_attributes":{},"id":0,"is_shareable":0,"link_file":"","link_file_content":{"extension_attributes":{},"file_data":"","name":""},"link_type":"","link_url":"","number_of_downloads":0,"price":"","sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links/:id',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "isGlobalScopeContent": false,\n  "link": {\n    "extension_attributes": {},\n    "id": 0,\n    "is_shareable": 0,\n    "link_file": "",\n    "link_file_content": {\n      "extension_attributes": {},\n      "file_data": "",\n      "name": ""\n    },\n    "link_type": "",\n    "link_url": "",\n    "number_of_downloads": 0,\n    "price": "",\n    "sample_file": "",\n    "sample_file_content": {},\n    "sample_type": "",\n    "sample_url": "",\n    "sort_order": 0,\n    "title": ""\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  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/downloadable-links/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/downloadable-links/:id',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  isGlobalScopeContent: false,
  link: {
    extension_attributes: {},
    id: 0,
    is_shareable: 0,
    link_file: '',
    link_file_content: {extension_attributes: {}, file_data: '', name: ''},
    link_type: '',
    link_url: '',
    number_of_downloads: 0,
    price: '',
    sample_file: '',
    sample_file_content: {},
    sample_type: '',
    sample_url: '',
    sort_order: 0,
    title: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links/:id',
  headers: {'content-type': 'application/json'},
  body: {
    isGlobalScopeContent: false,
    link: {
      extension_attributes: {},
      id: 0,
      is_shareable: 0,
      link_file: '',
      link_file_content: {extension_attributes: {}, file_data: '', name: ''},
      link_type: '',
      link_url: '',
      number_of_downloads: 0,
      price: '',
      sample_file: '',
      sample_file_content: {},
      sample_type: '',
      sample_url: '',
      sort_order: 0,
      title: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/products/:sku/downloadable-links/:id');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  isGlobalScopeContent: false,
  link: {
    extension_attributes: {},
    id: 0,
    is_shareable: 0,
    link_file: '',
    link_file_content: {
      extension_attributes: {},
      file_data: '',
      name: ''
    },
    link_type: '',
    link_url: '',
    number_of_downloads: 0,
    price: '',
    sample_file: '',
    sample_file_content: {},
    sample_type: '',
    sample_url: '',
    sort_order: 0,
    title: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links/:id',
  headers: {'content-type': 'application/json'},
  data: {
    isGlobalScopeContent: false,
    link: {
      extension_attributes: {},
      id: 0,
      is_shareable: 0,
      link_file: '',
      link_file_content: {extension_attributes: {}, file_data: '', name: ''},
      link_type: '',
      link_url: '',
      number_of_downloads: 0,
      price: '',
      sample_file: '',
      sample_file_content: {},
      sample_type: '',
      sample_url: '',
      sort_order: 0,
      title: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/downloadable-links/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"isGlobalScopeContent":false,"link":{"extension_attributes":{},"id":0,"is_shareable":0,"link_file":"","link_file_content":{"extension_attributes":{},"file_data":"","name":""},"link_type":"","link_url":"","number_of_downloads":0,"price":"","sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"isGlobalScopeContent": @NO,
                              @"link": @{ @"extension_attributes": @{  }, @"id": @0, @"is_shareable": @0, @"link_file": @"", @"link_file_content": @{ @"extension_attributes": @{  }, @"file_data": @"", @"name": @"" }, @"link_type": @"", @"link_url": @"", @"number_of_downloads": @0, @"price": @"", @"sample_file": @"", @"sample_file_content": @{  }, @"sample_type": @"", @"sample_url": @"", @"sort_order": @0, @"title": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/downloadable-links/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku/downloadable-links/:id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/downloadable-links/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'isGlobalScopeContent' => null,
    'link' => [
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'is_shareable' => 0,
        'link_file' => '',
        'link_file_content' => [
                'extension_attributes' => [
                                
                ],
                'file_data' => '',
                'name' => ''
        ],
        'link_type' => '',
        'link_url' => '',
        'number_of_downloads' => 0,
        'price' => '',
        'sample_file' => '',
        'sample_file_content' => [
                
        ],
        'sample_type' => '',
        'sample_url' => '',
        'sort_order' => 0,
        'title' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/products/:sku/downloadable-links/:id', [
  'body' => '{
  "isGlobalScopeContent": false,
  "link": {
    "extension_attributes": {},
    "id": 0,
    "is_shareable": 0,
    "link_file": "",
    "link_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "link_type": "",
    "link_url": "",
    "number_of_downloads": 0,
    "price": "",
    "sample_file": "",
    "sample_file_content": {},
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/downloadable-links/:id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'isGlobalScopeContent' => null,
  'link' => [
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'is_shareable' => 0,
    'link_file' => '',
    'link_file_content' => [
        'extension_attributes' => [
                
        ],
        'file_data' => '',
        'name' => ''
    ],
    'link_type' => '',
    'link_url' => '',
    'number_of_downloads' => 0,
    'price' => '',
    'sample_file' => '',
    'sample_file_content' => [
        
    ],
    'sample_type' => '',
    'sample_url' => '',
    'sort_order' => 0,
    'title' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'isGlobalScopeContent' => null,
  'link' => [
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'is_shareable' => 0,
    'link_file' => '',
    'link_file_content' => [
        'extension_attributes' => [
                
        ],
        'file_data' => '',
        'name' => ''
    ],
    'link_type' => '',
    'link_url' => '',
    'number_of_downloads' => 0,
    'price' => '',
    'sample_file' => '',
    'sample_file_content' => [
        
    ],
    'sample_type' => '',
    'sample_url' => '',
    'sort_order' => 0,
    'title' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/:sku/downloadable-links/:id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/downloadable-links/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "isGlobalScopeContent": false,
  "link": {
    "extension_attributes": {},
    "id": 0,
    "is_shareable": 0,
    "link_file": "",
    "link_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "link_type": "",
    "link_url": "",
    "number_of_downloads": 0,
    "price": "",
    "sample_file": "",
    "sample_file_content": {},
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/downloadable-links/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "isGlobalScopeContent": false,
  "link": {
    "extension_attributes": {},
    "id": 0,
    "is_shareable": 0,
    "link_file": "",
    "link_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "link_type": "",
    "link_url": "",
    "number_of_downloads": 0,
    "price": "",
    "sample_file": "",
    "sample_file_content": {},
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/products/:sku/downloadable-links/:id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/downloadable-links/:id"

payload = {
    "isGlobalScopeContent": False,
    "link": {
        "extension_attributes": {},
        "id": 0,
        "is_shareable": 0,
        "link_file": "",
        "link_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
        },
        "link_type": "",
        "link_url": "",
        "number_of_downloads": 0,
        "price": "",
        "sample_file": "",
        "sample_file_content": {},
        "sample_type": "",
        "sample_url": "",
        "sort_order": 0,
        "title": ""
    }
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/downloadable-links/:id"

payload <- "{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/downloadable-links/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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/V1/products/:sku/downloadable-links/:id') do |req|
  req.body = "{\n  \"isGlobalScopeContent\": false,\n  \"link\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"is_shareable\": 0,\n    \"link_file\": \"\",\n    \"link_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"link_type\": \"\",\n    \"link_url\": \"\",\n    \"number_of_downloads\": 0,\n    \"price\": \"\",\n    \"sample_file\": \"\",\n    \"sample_file_content\": {},\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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}}/V1/products/:sku/downloadable-links/:id";

    let payload = json!({
        "isGlobalScopeContent": false,
        "link": json!({
            "extension_attributes": json!({}),
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": json!({
                "extension_attributes": json!({}),
                "file_data": "",
                "name": ""
            }),
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": json!({}),
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/products/:sku/downloadable-links/:id \
  --header 'content-type: application/json' \
  --data '{
  "isGlobalScopeContent": false,
  "link": {
    "extension_attributes": {},
    "id": 0,
    "is_shareable": 0,
    "link_file": "",
    "link_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "link_type": "",
    "link_url": "",
    "number_of_downloads": 0,
    "price": "",
    "sample_file": "",
    "sample_file_content": {},
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}'
echo '{
  "isGlobalScopeContent": false,
  "link": {
    "extension_attributes": {},
    "id": 0,
    "is_shareable": 0,
    "link_file": "",
    "link_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "link_type": "",
    "link_url": "",
    "number_of_downloads": 0,
    "price": "",
    "sample_file": "",
    "sample_file_content": {},
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/products/:sku/downloadable-links/:id \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "isGlobalScopeContent": false,\n  "link": {\n    "extension_attributes": {},\n    "id": 0,\n    "is_shareable": 0,\n    "link_file": "",\n    "link_file_content": {\n      "extension_attributes": {},\n      "file_data": "",\n      "name": ""\n    },\n    "link_type": "",\n    "link_url": "",\n    "number_of_downloads": 0,\n    "price": "",\n    "sample_file": "",\n    "sample_file_content": {},\n    "sample_type": "",\n    "sample_url": "",\n    "sort_order": 0,\n    "title": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/downloadable-links/:id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "isGlobalScopeContent": false,
  "link": [
    "extension_attributes": [],
    "id": 0,
    "is_shareable": 0,
    "link_file": "",
    "link_file_content": [
      "extension_attributes": [],
      "file_data": "",
      "name": ""
    ],
    "link_type": "",
    "link_url": "",
    "number_of_downloads": 0,
    "price": "",
    "sample_file": "",
    "sample_file_content": [],
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/downloadable-links/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST products-{sku}-downloadable-links-samples (POST)
{{baseUrl}}/V1/products/:sku/downloadable-links/samples
QUERY PARAMS

sku
BODY json

{
  "isGlobalScopeContent": false,
  "sample": {
    "extension_attributes": {},
    "id": 0,
    "sample_file": "",
    "sample_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/downloadable-links/samples");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/:sku/downloadable-links/samples" {:content-type :json
                                                                                        :form-params {:isGlobalScopeContent false
                                                                                                      :sample {:extension_attributes {}
                                                                                                               :id 0
                                                                                                               :sample_file ""
                                                                                                               :sample_file_content {:extension_attributes {}
                                                                                                                                     :file_data ""
                                                                                                                                     :name ""}
                                                                                                               :sample_type ""
                                                                                                               :sample_url ""
                                                                                                               :sort_order 0
                                                                                                               :title ""}}})
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/downloadable-links/samples"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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}}/V1/products/:sku/downloadable-links/samples"),
    Content = new StringContent("{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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}}/V1/products/:sku/downloadable-links/samples");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/downloadable-links/samples"

	payload := strings.NewReader("{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/:sku/downloadable-links/samples HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 314

{
  "isGlobalScopeContent": false,
  "sample": {
    "extension_attributes": {},
    "id": 0,
    "sample_file": "",
    "sample_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/:sku/downloadable-links/samples")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/downloadable-links/samples"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/downloadable-links/samples")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/:sku/downloadable-links/samples")
  .header("content-type", "application/json")
  .body("{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  isGlobalScopeContent: false,
  sample: {
    extension_attributes: {},
    id: 0,
    sample_file: '',
    sample_file_content: {
      extension_attributes: {},
      file_data: '',
      name: ''
    },
    sample_type: '',
    sample_url: '',
    sort_order: 0,
    title: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/products/:sku/downloadable-links/samples');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links/samples',
  headers: {'content-type': 'application/json'},
  data: {
    isGlobalScopeContent: false,
    sample: {
      extension_attributes: {},
      id: 0,
      sample_file: '',
      sample_file_content: {extension_attributes: {}, file_data: '', name: ''},
      sample_type: '',
      sample_url: '',
      sort_order: 0,
      title: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/downloadable-links/samples';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"isGlobalScopeContent":false,"sample":{"extension_attributes":{},"id":0,"sample_file":"","sample_file_content":{"extension_attributes":{},"file_data":"","name":""},"sample_type":"","sample_url":"","sort_order":0,"title":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links/samples',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "isGlobalScopeContent": false,\n  "sample": {\n    "extension_attributes": {},\n    "id": 0,\n    "sample_file": "",\n    "sample_file_content": {\n      "extension_attributes": {},\n      "file_data": "",\n      "name": ""\n    },\n    "sample_type": "",\n    "sample_url": "",\n    "sort_order": 0,\n    "title": ""\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  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/downloadable-links/samples")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/downloadable-links/samples',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  isGlobalScopeContent: false,
  sample: {
    extension_attributes: {},
    id: 0,
    sample_file: '',
    sample_file_content: {extension_attributes: {}, file_data: '', name: ''},
    sample_type: '',
    sample_url: '',
    sort_order: 0,
    title: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links/samples',
  headers: {'content-type': 'application/json'},
  body: {
    isGlobalScopeContent: false,
    sample: {
      extension_attributes: {},
      id: 0,
      sample_file: '',
      sample_file_content: {extension_attributes: {}, file_data: '', name: ''},
      sample_type: '',
      sample_url: '',
      sort_order: 0,
      title: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/products/:sku/downloadable-links/samples');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  isGlobalScopeContent: false,
  sample: {
    extension_attributes: {},
    id: 0,
    sample_file: '',
    sample_file_content: {
      extension_attributes: {},
      file_data: '',
      name: ''
    },
    sample_type: '',
    sample_url: '',
    sort_order: 0,
    title: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links/samples',
  headers: {'content-type': 'application/json'},
  data: {
    isGlobalScopeContent: false,
    sample: {
      extension_attributes: {},
      id: 0,
      sample_file: '',
      sample_file_content: {extension_attributes: {}, file_data: '', name: ''},
      sample_type: '',
      sample_url: '',
      sort_order: 0,
      title: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/downloadable-links/samples';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"isGlobalScopeContent":false,"sample":{"extension_attributes":{},"id":0,"sample_file":"","sample_file_content":{"extension_attributes":{},"file_data":"","name":""},"sample_type":"","sample_url":"","sort_order":0,"title":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"isGlobalScopeContent": @NO,
                              @"sample": @{ @"extension_attributes": @{  }, @"id": @0, @"sample_file": @"", @"sample_file_content": @{ @"extension_attributes": @{  }, @"file_data": @"", @"name": @"" }, @"sample_type": @"", @"sample_url": @"", @"sort_order": @0, @"title": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/downloadable-links/samples"]
                                                       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}}/V1/products/:sku/downloadable-links/samples" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/downloadable-links/samples",
  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([
    'isGlobalScopeContent' => null,
    'sample' => [
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'sample_file' => '',
        'sample_file_content' => [
                'extension_attributes' => [
                                
                ],
                'file_data' => '',
                'name' => ''
        ],
        'sample_type' => '',
        'sample_url' => '',
        'sort_order' => 0,
        'title' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/:sku/downloadable-links/samples', [
  'body' => '{
  "isGlobalScopeContent": false,
  "sample": {
    "extension_attributes": {},
    "id": 0,
    "sample_file": "",
    "sample_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/downloadable-links/samples');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'isGlobalScopeContent' => null,
  'sample' => [
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'sample_file' => '',
    'sample_file_content' => [
        'extension_attributes' => [
                
        ],
        'file_data' => '',
        'name' => ''
    ],
    'sample_type' => '',
    'sample_url' => '',
    'sort_order' => 0,
    'title' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'isGlobalScopeContent' => null,
  'sample' => [
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'sample_file' => '',
    'sample_file_content' => [
        'extension_attributes' => [
                
        ],
        'file_data' => '',
        'name' => ''
    ],
    'sample_type' => '',
    'sample_url' => '',
    'sort_order' => 0,
    'title' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/:sku/downloadable-links/samples');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/downloadable-links/samples' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "isGlobalScopeContent": false,
  "sample": {
    "extension_attributes": {},
    "id": 0,
    "sample_file": "",
    "sample_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/downloadable-links/samples' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "isGlobalScopeContent": false,
  "sample": {
    "extension_attributes": {},
    "id": 0,
    "sample_file": "",
    "sample_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/:sku/downloadable-links/samples", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/downloadable-links/samples"

payload = {
    "isGlobalScopeContent": False,
    "sample": {
        "extension_attributes": {},
        "id": 0,
        "sample_file": "",
        "sample_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
        },
        "sample_type": "",
        "sample_url": "",
        "sort_order": 0,
        "title": ""
    }
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/downloadable-links/samples"

payload <- "{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/downloadable-links/samples")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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/V1/products/:sku/downloadable-links/samples') do |req|
  req.body = "{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/downloadable-links/samples";

    let payload = json!({
        "isGlobalScopeContent": false,
        "sample": json!({
            "extension_attributes": json!({}),
            "id": 0,
            "sample_file": "",
            "sample_file_content": json!({
                "extension_attributes": json!({}),
                "file_data": "",
                "name": ""
            }),
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/:sku/downloadable-links/samples \
  --header 'content-type: application/json' \
  --data '{
  "isGlobalScopeContent": false,
  "sample": {
    "extension_attributes": {},
    "id": 0,
    "sample_file": "",
    "sample_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}'
echo '{
  "isGlobalScopeContent": false,
  "sample": {
    "extension_attributes": {},
    "id": 0,
    "sample_file": "",
    "sample_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/products/:sku/downloadable-links/samples \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "isGlobalScopeContent": false,\n  "sample": {\n    "extension_attributes": {},\n    "id": 0,\n    "sample_file": "",\n    "sample_file_content": {\n      "extension_attributes": {},\n      "file_data": "",\n      "name": ""\n    },\n    "sample_type": "",\n    "sample_url": "",\n    "sort_order": 0,\n    "title": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/downloadable-links/samples
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "isGlobalScopeContent": false,
  "sample": [
    "extension_attributes": [],
    "id": 0,
    "sample_file": "",
    "sample_file_content": [
      "extension_attributes": [],
      "file_data": "",
      "name": ""
    ],
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/downloadable-links/samples")! 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}}/V1/products/:sku/downloadable-links/samples");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/:sku/downloadable-links/samples")
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/downloadable-links/samples"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/:sku/downloadable-links/samples"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/:sku/downloadable-links/samples");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/downloadable-links/samples"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/:sku/downloadable-links/samples HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/:sku/downloadable-links/samples")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/downloadable-links/samples"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/downloadable-links/samples")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/:sku/downloadable-links/samples")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/:sku/downloadable-links/samples');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links/samples'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/downloadable-links/samples';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links/samples',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/downloadable-links/samples")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/downloadable-links/samples',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links/samples'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/:sku/downloadable-links/samples');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links/samples'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/downloadable-links/samples';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/downloadable-links/samples"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku/downloadable-links/samples" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/downloadable-links/samples",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/:sku/downloadable-links/samples');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/downloadable-links/samples');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/:sku/downloadable-links/samples');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/downloadable-links/samples' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/downloadable-links/samples' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/:sku/downloadable-links/samples")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/downloadable-links/samples"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/downloadable-links/samples"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/downloadable-links/samples")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/:sku/downloadable-links/samples') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/downloadable-links/samples";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/:sku/downloadable-links/samples
http GET {{baseUrl}}/V1/products/:sku/downloadable-links/samples
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/downloadable-links/samples
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/downloadable-links/samples")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id" {:content-type :json
                                                                                           :form-params {:isGlobalScopeContent false
                                                                                                         :sample {:extension_attributes {}
                                                                                                                  :id 0
                                                                                                                  :sample_file ""
                                                                                                                  :sample_file_content {:extension_attributes {}
                                                                                                                                        :file_data ""
                                                                                                                                        :name ""}
                                                                                                                  :sample_type ""
                                                                                                                  :sample_url ""
                                                                                                                  :sort_order 0
                                                                                                                  :title ""}}})
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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}}/V1/products/:sku/downloadable-links/samples/:id"),
    Content = new StringContent("{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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}}/V1/products/:sku/downloadable-links/samples/:id");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id"

	payload := strings.NewReader("{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/products/:sku/downloadable-links/samples/:id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 314

{
  "isGlobalScopeContent": false,
  "sample": {
    "extension_attributes": {},
    "id": 0,
    "sample_file": "",
    "sample_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id")
  .header("content-type", "application/json")
  .body("{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  isGlobalScopeContent: false,
  sample: {
    extension_attributes: {},
    id: 0,
    sample_file: '',
    sample_file_content: {
      extension_attributes: {},
      file_data: '',
      name: ''
    },
    sample_type: '',
    sample_url: '',
    sort_order: 0,
    title: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id',
  headers: {'content-type': 'application/json'},
  data: {
    isGlobalScopeContent: false,
    sample: {
      extension_attributes: {},
      id: 0,
      sample_file: '',
      sample_file_content: {extension_attributes: {}, file_data: '', name: ''},
      sample_type: '',
      sample_url: '',
      sort_order: 0,
      title: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"isGlobalScopeContent":false,"sample":{"extension_attributes":{},"id":0,"sample_file":"","sample_file_content":{"extension_attributes":{},"file_data":"","name":""},"sample_type":"","sample_url":"","sort_order":0,"title":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "isGlobalScopeContent": false,\n  "sample": {\n    "extension_attributes": {},\n    "id": 0,\n    "sample_file": "",\n    "sample_file_content": {\n      "extension_attributes": {},\n      "file_data": "",\n      "name": ""\n    },\n    "sample_type": "",\n    "sample_url": "",\n    "sort_order": 0,\n    "title": ""\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  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/downloadable-links/samples/:id',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  isGlobalScopeContent: false,
  sample: {
    extension_attributes: {},
    id: 0,
    sample_file: '',
    sample_file_content: {extension_attributes: {}, file_data: '', name: ''},
    sample_type: '',
    sample_url: '',
    sort_order: 0,
    title: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id',
  headers: {'content-type': 'application/json'},
  body: {
    isGlobalScopeContent: false,
    sample: {
      extension_attributes: {},
      id: 0,
      sample_file: '',
      sample_file_content: {extension_attributes: {}, file_data: '', name: ''},
      sample_type: '',
      sample_url: '',
      sort_order: 0,
      title: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  isGlobalScopeContent: false,
  sample: {
    extension_attributes: {},
    id: 0,
    sample_file: '',
    sample_file_content: {
      extension_attributes: {},
      file_data: '',
      name: ''
    },
    sample_type: '',
    sample_url: '',
    sort_order: 0,
    title: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id',
  headers: {'content-type': 'application/json'},
  data: {
    isGlobalScopeContent: false,
    sample: {
      extension_attributes: {},
      id: 0,
      sample_file: '',
      sample_file_content: {extension_attributes: {}, file_data: '', name: ''},
      sample_type: '',
      sample_url: '',
      sort_order: 0,
      title: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"isGlobalScopeContent":false,"sample":{"extension_attributes":{},"id":0,"sample_file":"","sample_file_content":{"extension_attributes":{},"file_data":"","name":""},"sample_type":"","sample_url":"","sort_order":0,"title":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"isGlobalScopeContent": @NO,
                              @"sample": @{ @"extension_attributes": @{  }, @"id": @0, @"sample_file": @"", @"sample_file_content": @{ @"extension_attributes": @{  }, @"file_data": @"", @"name": @"" }, @"sample_type": @"", @"sample_url": @"", @"sort_order": @0, @"title": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'isGlobalScopeContent' => null,
    'sample' => [
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'sample_file' => '',
        'sample_file_content' => [
                'extension_attributes' => [
                                
                ],
                'file_data' => '',
                'name' => ''
        ],
        'sample_type' => '',
        'sample_url' => '',
        'sort_order' => 0,
        'title' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id', [
  'body' => '{
  "isGlobalScopeContent": false,
  "sample": {
    "extension_attributes": {},
    "id": 0,
    "sample_file": "",
    "sample_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'isGlobalScopeContent' => null,
  'sample' => [
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'sample_file' => '',
    'sample_file_content' => [
        'extension_attributes' => [
                
        ],
        'file_data' => '',
        'name' => ''
    ],
    'sample_type' => '',
    'sample_url' => '',
    'sort_order' => 0,
    'title' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'isGlobalScopeContent' => null,
  'sample' => [
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'sample_file' => '',
    'sample_file_content' => [
        'extension_attributes' => [
                
        ],
        'file_data' => '',
        'name' => ''
    ],
    'sample_type' => '',
    'sample_url' => '',
    'sort_order' => 0,
    'title' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "isGlobalScopeContent": false,
  "sample": {
    "extension_attributes": {},
    "id": 0,
    "sample_file": "",
    "sample_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "isGlobalScopeContent": false,
  "sample": {
    "extension_attributes": {},
    "id": 0,
    "sample_file": "",
    "sample_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/products/:sku/downloadable-links/samples/:id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id"

payload = {
    "isGlobalScopeContent": False,
    "sample": {
        "extension_attributes": {},
        "id": 0,
        "sample_file": "",
        "sample_file_content": {
            "extension_attributes": {},
            "file_data": "",
            "name": ""
        },
        "sample_type": "",
        "sample_url": "",
        "sort_order": 0,
        "title": ""
    }
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id"

payload <- "{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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/V1/products/:sku/downloadable-links/samples/:id') do |req|
  req.body = "{\n  \"isGlobalScopeContent\": false,\n  \"sample\": {\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"sample_file\": \"\",\n    \"sample_file_content\": {\n      \"extension_attributes\": {},\n      \"file_data\": \"\",\n      \"name\": \"\"\n    },\n    \"sample_type\": \"\",\n    \"sample_url\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\"\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}}/V1/products/:sku/downloadable-links/samples/:id";

    let payload = json!({
        "isGlobalScopeContent": false,
        "sample": json!({
            "extension_attributes": json!({}),
            "id": 0,
            "sample_file": "",
            "sample_file_content": json!({
                "extension_attributes": json!({}),
                "file_data": "",
                "name": ""
            }),
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id \
  --header 'content-type: application/json' \
  --data '{
  "isGlobalScopeContent": false,
  "sample": {
    "extension_attributes": {},
    "id": 0,
    "sample_file": "",
    "sample_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}'
echo '{
  "isGlobalScopeContent": false,
  "sample": {
    "extension_attributes": {},
    "id": 0,
    "sample_file": "",
    "sample_file_content": {
      "extension_attributes": {},
      "file_data": "",
      "name": ""
    },
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "isGlobalScopeContent": false,\n  "sample": {\n    "extension_attributes": {},\n    "id": 0,\n    "sample_file": "",\n    "sample_file_content": {\n      "extension_attributes": {},\n      "file_data": "",\n      "name": ""\n    },\n    "sample_type": "",\n    "sample_url": "",\n    "sort_order": 0,\n    "title": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "isGlobalScopeContent": false,
  "sample": [
    "extension_attributes": [],
    "id": 0,
    "sample_file": "",
    "sample_file_content": [
      "extension_attributes": [],
      "file_data": "",
      "name": ""
    ],
    "sample_type": "",
    "sample_url": "",
    "sort_order": 0,
    "title": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/downloadable-links/samples/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET products-{sku}-group-prices-{customerGroupId}-tiers
{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers
QUERY PARAMS

sku
customerGroupId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers")
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/:sku/group-prices/:customerGroupId/tiers HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/group-prices/:customerGroupId/tiers',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/:sku/group-prices/:customerGroupId/tiers")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/:sku/group-prices/:customerGroupId/tiers') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers
http GET {{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE products-{sku}-group-prices-{customerGroupId}-tiers-{qty}
{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty
QUERY PARAMS

sku
customerGroupId
qty
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty")
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty"))
    .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}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty")
  .asString();
const 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}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty');

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}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty
http DELETE {{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST products-{sku}-group-prices-{customerGroupId}-tiers-{qty}-price-{price}
{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price
QUERY PARAMS

sku
customerGroupId
price
qty
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price")
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price"))
    .method("POST", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price
http POST {{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/group-prices/:customerGroupId/tiers/:qty/price/:price")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/links");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"entity\": {\n    \"extension_attributes\": {\n      \"qty\": \"\"\n    },\n    \"link_type\": \"\",\n    \"linked_product_sku\": \"\",\n    \"linked_product_type\": \"\",\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/products/:sku/links" {:content-type :json
                                                                  :form-params {:entity {:extension_attributes {:qty ""}
                                                                                         :link_type ""
                                                                                         :linked_product_sku ""
                                                                                         :linked_product_type ""
                                                                                         :position 0
                                                                                         :sku ""}}})
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/links"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"entity\": {\n    \"extension_attributes\": {\n      \"qty\": \"\"\n    },\n    \"link_type\": \"\",\n    \"linked_product_sku\": \"\",\n    \"linked_product_type\": \"\",\n    \"position\": 0,\n    \"sku\": \"\"\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}}/V1/products/:sku/links"),
    Content = new StringContent("{\n  \"entity\": {\n    \"extension_attributes\": {\n      \"qty\": \"\"\n    },\n    \"link_type\": \"\",\n    \"linked_product_sku\": \"\",\n    \"linked_product_type\": \"\",\n    \"position\": 0,\n    \"sku\": \"\"\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}}/V1/products/:sku/links");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"entity\": {\n    \"extension_attributes\": {\n      \"qty\": \"\"\n    },\n    \"link_type\": \"\",\n    \"linked_product_sku\": \"\",\n    \"linked_product_type\": \"\",\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/links"

	payload := strings.NewReader("{\n  \"entity\": {\n    \"extension_attributes\": {\n      \"qty\": \"\"\n    },\n    \"link_type\": \"\",\n    \"linked_product_sku\": \"\",\n    \"linked_product_type\": \"\",\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/products/:sku/links HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 189

{
  "entity": {
    "extension_attributes": {
      "qty": ""
    },
    "link_type": "",
    "linked_product_sku": "",
    "linked_product_type": "",
    "position": 0,
    "sku": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/products/:sku/links")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"entity\": {\n    \"extension_attributes\": {\n      \"qty\": \"\"\n    },\n    \"link_type\": \"\",\n    \"linked_product_sku\": \"\",\n    \"linked_product_type\": \"\",\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/links"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"entity\": {\n    \"extension_attributes\": {\n      \"qty\": \"\"\n    },\n    \"link_type\": \"\",\n    \"linked_product_sku\": \"\",\n    \"linked_product_type\": \"\",\n    \"position\": 0,\n    \"sku\": \"\"\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  \"entity\": {\n    \"extension_attributes\": {\n      \"qty\": \"\"\n    },\n    \"link_type\": \"\",\n    \"linked_product_sku\": \"\",\n    \"linked_product_type\": \"\",\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/links")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/products/:sku/links")
  .header("content-type", "application/json")
  .body("{\n  \"entity\": {\n    \"extension_attributes\": {\n      \"qty\": \"\"\n    },\n    \"link_type\": \"\",\n    \"linked_product_sku\": \"\",\n    \"linked_product_type\": \"\",\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  entity: {
    extension_attributes: {
      qty: ''
    },
    link_type: '',
    linked_product_sku: '',
    linked_product_type: '',
    position: 0,
    sku: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/products/:sku/links');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/:sku/links',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      extension_attributes: {qty: ''},
      link_type: '',
      linked_product_sku: '',
      linked_product_type: '',
      position: 0,
      sku: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/links';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"extension_attributes":{"qty":""},"link_type":"","linked_product_sku":"","linked_product_type":"","position":0,"sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/links',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "entity": {\n    "extension_attributes": {\n      "qty": ""\n    },\n    "link_type": "",\n    "linked_product_sku": "",\n    "linked_product_type": "",\n    "position": 0,\n    "sku": ""\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  \"entity\": {\n    \"extension_attributes\": {\n      \"qty\": \"\"\n    },\n    \"link_type\": \"\",\n    \"linked_product_sku\": \"\",\n    \"linked_product_type\": \"\",\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/links")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/links',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  entity: {
    extension_attributes: {qty: ''},
    link_type: '',
    linked_product_sku: '',
    linked_product_type: '',
    position: 0,
    sku: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/:sku/links',
  headers: {'content-type': 'application/json'},
  body: {
    entity: {
      extension_attributes: {qty: ''},
      link_type: '',
      linked_product_sku: '',
      linked_product_type: '',
      position: 0,
      sku: ''
    }
  },
  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}}/V1/products/:sku/links');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  entity: {
    extension_attributes: {
      qty: ''
    },
    link_type: '',
    linked_product_sku: '',
    linked_product_type: '',
    position: 0,
    sku: ''
  }
});

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}}/V1/products/:sku/links',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      extension_attributes: {qty: ''},
      link_type: '',
      linked_product_sku: '',
      linked_product_type: '',
      position: 0,
      sku: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/links';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"extension_attributes":{"qty":""},"link_type":"","linked_product_sku":"","linked_product_type":"","position":0,"sku":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"entity": @{ @"extension_attributes": @{ @"qty": @"" }, @"link_type": @"", @"linked_product_sku": @"", @"linked_product_type": @"", @"position": @0, @"sku": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/links"]
                                                       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}}/V1/products/:sku/links" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"entity\": {\n    \"extension_attributes\": {\n      \"qty\": \"\"\n    },\n    \"link_type\": \"\",\n    \"linked_product_sku\": \"\",\n    \"linked_product_type\": \"\",\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/links",
  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([
    'entity' => [
        'extension_attributes' => [
                'qty' => ''
        ],
        'link_type' => '',
        'linked_product_sku' => '',
        'linked_product_type' => '',
        'position' => 0,
        'sku' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/products/:sku/links', [
  'body' => '{
  "entity": {
    "extension_attributes": {
      "qty": ""
    },
    "link_type": "",
    "linked_product_sku": "",
    "linked_product_type": "",
    "position": 0,
    "sku": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/links');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'entity' => [
    'extension_attributes' => [
        'qty' => ''
    ],
    'link_type' => '',
    'linked_product_sku' => '',
    'linked_product_type' => '',
    'position' => 0,
    'sku' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'entity' => [
    'extension_attributes' => [
        'qty' => ''
    ],
    'link_type' => '',
    'linked_product_sku' => '',
    'linked_product_type' => '',
    'position' => 0,
    'sku' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/:sku/links');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/links' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "extension_attributes": {
      "qty": ""
    },
    "link_type": "",
    "linked_product_sku": "",
    "linked_product_type": "",
    "position": 0,
    "sku": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/links' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "extension_attributes": {
      "qty": ""
    },
    "link_type": "",
    "linked_product_sku": "",
    "linked_product_type": "",
    "position": 0,
    "sku": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"entity\": {\n    \"extension_attributes\": {\n      \"qty\": \"\"\n    },\n    \"link_type\": \"\",\n    \"linked_product_sku\": \"\",\n    \"linked_product_type\": \"\",\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/products/:sku/links", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/links"

payload = { "entity": {
        "extension_attributes": { "qty": "" },
        "link_type": "",
        "linked_product_sku": "",
        "linked_product_type": "",
        "position": 0,
        "sku": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/links"

payload <- "{\n  \"entity\": {\n    \"extension_attributes\": {\n      \"qty\": \"\"\n    },\n    \"link_type\": \"\",\n    \"linked_product_sku\": \"\",\n    \"linked_product_type\": \"\",\n    \"position\": 0,\n    \"sku\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/links")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"entity\": {\n    \"extension_attributes\": {\n      \"qty\": \"\"\n    },\n    \"link_type\": \"\",\n    \"linked_product_sku\": \"\",\n    \"linked_product_type\": \"\",\n    \"position\": 0,\n    \"sku\": \"\"\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/V1/products/:sku/links') do |req|
  req.body = "{\n  \"entity\": {\n    \"extension_attributes\": {\n      \"qty\": \"\"\n    },\n    \"link_type\": \"\",\n    \"linked_product_sku\": \"\",\n    \"linked_product_type\": \"\",\n    \"position\": 0,\n    \"sku\": \"\"\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}}/V1/products/:sku/links";

    let payload = json!({"entity": json!({
            "extension_attributes": json!({"qty": ""}),
            "link_type": "",
            "linked_product_sku": "",
            "linked_product_type": "",
            "position": 0,
            "sku": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/products/:sku/links \
  --header 'content-type: application/json' \
  --data '{
  "entity": {
    "extension_attributes": {
      "qty": ""
    },
    "link_type": "",
    "linked_product_sku": "",
    "linked_product_type": "",
    "position": 0,
    "sku": ""
  }
}'
echo '{
  "entity": {
    "extension_attributes": {
      "qty": ""
    },
    "link_type": "",
    "linked_product_sku": "",
    "linked_product_type": "",
    "position": 0,
    "sku": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/products/:sku/links \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "entity": {\n    "extension_attributes": {\n      "qty": ""\n    },\n    "link_type": "",\n    "linked_product_sku": "",\n    "linked_product_type": "",\n    "position": 0,\n    "sku": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/links
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["entity": [
    "extension_attributes": ["qty": ""],
    "link_type": "",
    "linked_product_sku": "",
    "linked_product_type": "",
    "position": 0,
    "sku": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/links")! 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, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/links");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"items\": [\n    {\n      \"extension_attributes\": {\n        \"qty\": \"\"\n      },\n      \"link_type\": \"\",\n      \"linked_product_sku\": \"\",\n      \"linked_product_type\": \"\",\n      \"position\": 0,\n      \"sku\": \"\"\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/:sku/links" {:content-type :json
                                                                   :form-params {:items [{:extension_attributes {:qty ""}
                                                                                          :link_type ""
                                                                                          :linked_product_sku ""
                                                                                          :linked_product_type ""
                                                                                          :position 0
                                                                                          :sku ""}]}})
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/links"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"items\": [\n    {\n      \"extension_attributes\": {\n        \"qty\": \"\"\n      },\n      \"link_type\": \"\",\n      \"linked_product_sku\": \"\",\n      \"linked_product_type\": \"\",\n      \"position\": 0,\n      \"sku\": \"\"\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}}/V1/products/:sku/links"),
    Content = new StringContent("{\n  \"items\": [\n    {\n      \"extension_attributes\": {\n        \"qty\": \"\"\n      },\n      \"link_type\": \"\",\n      \"linked_product_sku\": \"\",\n      \"linked_product_type\": \"\",\n      \"position\": 0,\n      \"sku\": \"\"\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}}/V1/products/:sku/links");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"items\": [\n    {\n      \"extension_attributes\": {\n        \"qty\": \"\"\n      },\n      \"link_type\": \"\",\n      \"linked_product_sku\": \"\",\n      \"linked_product_type\": \"\",\n      \"position\": 0,\n      \"sku\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/links"

	payload := strings.NewReader("{\n  \"items\": [\n    {\n      \"extension_attributes\": {\n        \"qty\": \"\"\n      },\n      \"link_type\": \"\",\n      \"linked_product_sku\": \"\",\n      \"linked_product_type\": \"\",\n      \"position\": 0,\n      \"sku\": \"\"\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/:sku/links HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 216

{
  "items": [
    {
      "extension_attributes": {
        "qty": ""
      },
      "link_type": "",
      "linked_product_sku": "",
      "linked_product_type": "",
      "position": 0,
      "sku": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/:sku/links")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"items\": [\n    {\n      \"extension_attributes\": {\n        \"qty\": \"\"\n      },\n      \"link_type\": \"\",\n      \"linked_product_sku\": \"\",\n      \"linked_product_type\": \"\",\n      \"position\": 0,\n      \"sku\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/links"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"items\": [\n    {\n      \"extension_attributes\": {\n        \"qty\": \"\"\n      },\n      \"link_type\": \"\",\n      \"linked_product_sku\": \"\",\n      \"linked_product_type\": \"\",\n      \"position\": 0,\n      \"sku\": \"\"\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  \"items\": [\n    {\n      \"extension_attributes\": {\n        \"qty\": \"\"\n      },\n      \"link_type\": \"\",\n      \"linked_product_sku\": \"\",\n      \"linked_product_type\": \"\",\n      \"position\": 0,\n      \"sku\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/links")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/:sku/links")
  .header("content-type", "application/json")
  .body("{\n  \"items\": [\n    {\n      \"extension_attributes\": {\n        \"qty\": \"\"\n      },\n      \"link_type\": \"\",\n      \"linked_product_sku\": \"\",\n      \"linked_product_type\": \"\",\n      \"position\": 0,\n      \"sku\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  items: [
    {
      extension_attributes: {
        qty: ''
      },
      link_type: '',
      linked_product_sku: '',
      linked_product_type: '',
      position: 0,
      sku: ''
    }
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/products/:sku/links');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/:sku/links',
  headers: {'content-type': 'application/json'},
  data: {
    items: [
      {
        extension_attributes: {qty: ''},
        link_type: '',
        linked_product_sku: '',
        linked_product_type: '',
        position: 0,
        sku: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/links';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"items":[{"extension_attributes":{"qty":""},"link_type":"","linked_product_sku":"","linked_product_type":"","position":0,"sku":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/links',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "items": [\n    {\n      "extension_attributes": {\n        "qty": ""\n      },\n      "link_type": "",\n      "linked_product_sku": "",\n      "linked_product_type": "",\n      "position": 0,\n      "sku": ""\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  \"items\": [\n    {\n      \"extension_attributes\": {\n        \"qty\": \"\"\n      },\n      \"link_type\": \"\",\n      \"linked_product_sku\": \"\",\n      \"linked_product_type\": \"\",\n      \"position\": 0,\n      \"sku\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/links")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/links',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  items: [
    {
      extension_attributes: {qty: ''},
      link_type: '',
      linked_product_sku: '',
      linked_product_type: '',
      position: 0,
      sku: ''
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/:sku/links',
  headers: {'content-type': 'application/json'},
  body: {
    items: [
      {
        extension_attributes: {qty: ''},
        link_type: '',
        linked_product_sku: '',
        linked_product_type: '',
        position: 0,
        sku: ''
      }
    ]
  },
  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}}/V1/products/:sku/links');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  items: [
    {
      extension_attributes: {
        qty: ''
      },
      link_type: '',
      linked_product_sku: '',
      linked_product_type: '',
      position: 0,
      sku: ''
    }
  ]
});

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}}/V1/products/:sku/links',
  headers: {'content-type': 'application/json'},
  data: {
    items: [
      {
        extension_attributes: {qty: ''},
        link_type: '',
        linked_product_sku: '',
        linked_product_type: '',
        position: 0,
        sku: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/links';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"items":[{"extension_attributes":{"qty":""},"link_type":"","linked_product_sku":"","linked_product_type":"","position":0,"sku":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"items": @[ @{ @"extension_attributes": @{ @"qty": @"" }, @"link_type": @"", @"linked_product_sku": @"", @"linked_product_type": @"", @"position": @0, @"sku": @"" } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/links"]
                                                       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}}/V1/products/:sku/links" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"items\": [\n    {\n      \"extension_attributes\": {\n        \"qty\": \"\"\n      },\n      \"link_type\": \"\",\n      \"linked_product_sku\": \"\",\n      \"linked_product_type\": \"\",\n      \"position\": 0,\n      \"sku\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/links",
  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([
    'items' => [
        [
                'extension_attributes' => [
                                'qty' => ''
                ],
                'link_type' => '',
                'linked_product_sku' => '',
                'linked_product_type' => '',
                'position' => 0,
                'sku' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/:sku/links', [
  'body' => '{
  "items": [
    {
      "extension_attributes": {
        "qty": ""
      },
      "link_type": "",
      "linked_product_sku": "",
      "linked_product_type": "",
      "position": 0,
      "sku": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/links');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'items' => [
    [
        'extension_attributes' => [
                'qty' => ''
        ],
        'link_type' => '',
        'linked_product_sku' => '',
        'linked_product_type' => '',
        'position' => 0,
        'sku' => ''
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'items' => [
    [
        'extension_attributes' => [
                'qty' => ''
        ],
        'link_type' => '',
        'linked_product_sku' => '',
        'linked_product_type' => '',
        'position' => 0,
        'sku' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/:sku/links');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/links' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "items": [
    {
      "extension_attributes": {
        "qty": ""
      },
      "link_type": "",
      "linked_product_sku": "",
      "linked_product_type": "",
      "position": 0,
      "sku": ""
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/links' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "items": [
    {
      "extension_attributes": {
        "qty": ""
      },
      "link_type": "",
      "linked_product_sku": "",
      "linked_product_type": "",
      "position": 0,
      "sku": ""
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"items\": [\n    {\n      \"extension_attributes\": {\n        \"qty\": \"\"\n      },\n      \"link_type\": \"\",\n      \"linked_product_sku\": \"\",\n      \"linked_product_type\": \"\",\n      \"position\": 0,\n      \"sku\": \"\"\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/:sku/links", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/links"

payload = { "items": [
        {
            "extension_attributes": { "qty": "" },
            "link_type": "",
            "linked_product_sku": "",
            "linked_product_type": "",
            "position": 0,
            "sku": ""
        }
    ] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/links"

payload <- "{\n  \"items\": [\n    {\n      \"extension_attributes\": {\n        \"qty\": \"\"\n      },\n      \"link_type\": \"\",\n      \"linked_product_sku\": \"\",\n      \"linked_product_type\": \"\",\n      \"position\": 0,\n      \"sku\": \"\"\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/links")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"items\": [\n    {\n      \"extension_attributes\": {\n        \"qty\": \"\"\n      },\n      \"link_type\": \"\",\n      \"linked_product_sku\": \"\",\n      \"linked_product_type\": \"\",\n      \"position\": 0,\n      \"sku\": \"\"\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/V1/products/:sku/links') do |req|
  req.body = "{\n  \"items\": [\n    {\n      \"extension_attributes\": {\n        \"qty\": \"\"\n      },\n      \"link_type\": \"\",\n      \"linked_product_sku\": \"\",\n      \"linked_product_type\": \"\",\n      \"position\": 0,\n      \"sku\": \"\"\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}}/V1/products/:sku/links";

    let payload = json!({"items": (
            json!({
                "extension_attributes": json!({"qty": ""}),
                "link_type": "",
                "linked_product_sku": "",
                "linked_product_type": "",
                "position": 0,
                "sku": ""
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/:sku/links \
  --header 'content-type: application/json' \
  --data '{
  "items": [
    {
      "extension_attributes": {
        "qty": ""
      },
      "link_type": "",
      "linked_product_sku": "",
      "linked_product_type": "",
      "position": 0,
      "sku": ""
    }
  ]
}'
echo '{
  "items": [
    {
      "extension_attributes": {
        "qty": ""
      },
      "link_type": "",
      "linked_product_sku": "",
      "linked_product_type": "",
      "position": 0,
      "sku": ""
    }
  ]
}' |  \
  http POST {{baseUrl}}/V1/products/:sku/links \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "items": [\n    {\n      "extension_attributes": {\n        "qty": ""\n      },\n      "link_type": "",\n      "linked_product_sku": "",\n      "linked_product_type": "",\n      "position": 0,\n      "sku": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/links
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["items": [
    [
      "extension_attributes": ["qty": ""],
      "link_type": "",
      "linked_product_sku": "",
      "linked_product_type": "",
      "position": 0,
      "sku": ""
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/links")! 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}}/V1/products/:sku/links/:type");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/:sku/links/:type")
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/links/:type"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/:sku/links/:type"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/:sku/links/:type");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/links/:type"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/:sku/links/:type HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/:sku/links/:type")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/links/:type"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/links/:type")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/:sku/links/:type")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/:sku/links/:type');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/:sku/links/:type'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/links/:type';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/links/:type',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/links/:type")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/links/:type',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/:sku/links/:type'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/:sku/links/: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: 'GET', url: '{{baseUrl}}/V1/products/:sku/links/:type'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/links/:type';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/links/:type"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku/links/:type" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/links/:type",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/:sku/links/:type');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/links/:type');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/:sku/links/:type');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/links/:type' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/links/:type' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/:sku/links/:type")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/links/:type"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/links/:type"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/links/:type")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/:sku/links/:type') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/links/:type";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/:sku/links/:type
http GET {{baseUrl}}/V1/products/:sku/links/:type
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/links/:type
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/links/:type")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku")
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/products/:sku/links/:type/:linkedProductSku HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku"))
    .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}}/V1/products/:sku/links/:type/:linkedProductSku")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku")
  .asString();
const 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}}/V1/products/:sku/links/:type/:linkedProductSku');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/links/:type/:linkedProductSku',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku');

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}}/V1/products/:sku/links/:type/:linkedProductSku'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/products/:sku/links/:type/:linkedProductSku")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/products/:sku/links/:type/:linkedProductSku') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku
http DELETE {{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/links/:type/:linkedProductSku")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST products-{sku}-media (POST)
{{baseUrl}}/V1/products/:sku/media
QUERY PARAMS

sku
BODY json

{
  "entry": {
    "content": {
      "base64_encoded_data": "",
      "name": "",
      "type": ""
    },
    "disabled": false,
    "extension_attributes": {
      "video_content": {
        "media_type": "",
        "video_description": "",
        "video_metadata": "",
        "video_provider": "",
        "video_title": "",
        "video_url": ""
      }
    },
    "file": "",
    "id": 0,
    "label": "",
    "media_type": "",
    "position": 0,
    "types": []
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/media");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/:sku/media" {:content-type :json
                                                                   :form-params {:entry {:content {:base64_encoded_data ""
                                                                                                   :name ""
                                                                                                   :type ""}
                                                                                         :disabled false
                                                                                         :extension_attributes {:video_content {:media_type ""
                                                                                                                                :video_description ""
                                                                                                                                :video_metadata ""
                                                                                                                                :video_provider ""
                                                                                                                                :video_title ""
                                                                                                                                :video_url ""}}
                                                                                         :file ""
                                                                                         :id 0
                                                                                         :label ""
                                                                                         :media_type ""
                                                                                         :position 0
                                                                                         :types []}}})
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/media"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\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}}/V1/products/:sku/media"),
    Content = new StringContent("{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\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}}/V1/products/:sku/media");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/media"

	payload := strings.NewReader("{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/:sku/media HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 478

{
  "entry": {
    "content": {
      "base64_encoded_data": "",
      "name": "",
      "type": ""
    },
    "disabled": false,
    "extension_attributes": {
      "video_content": {
        "media_type": "",
        "video_description": "",
        "video_metadata": "",
        "video_provider": "",
        "video_title": "",
        "video_url": ""
      }
    },
    "file": "",
    "id": 0,
    "label": "",
    "media_type": "",
    "position": 0,
    "types": []
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/:sku/media")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/media"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\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  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/media")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/:sku/media")
  .header("content-type", "application/json")
  .body("{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}")
  .asString();
const data = JSON.stringify({
  entry: {
    content: {
      base64_encoded_data: '',
      name: '',
      type: ''
    },
    disabled: false,
    extension_attributes: {
      video_content: {
        media_type: '',
        video_description: '',
        video_metadata: '',
        video_provider: '',
        video_title: '',
        video_url: ''
      }
    },
    file: '',
    id: 0,
    label: '',
    media_type: '',
    position: 0,
    types: []
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/products/:sku/media');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/:sku/media',
  headers: {'content-type': 'application/json'},
  data: {
    entry: {
      content: {base64_encoded_data: '', name: '', type: ''},
      disabled: false,
      extension_attributes: {
        video_content: {
          media_type: '',
          video_description: '',
          video_metadata: '',
          video_provider: '',
          video_title: '',
          video_url: ''
        }
      },
      file: '',
      id: 0,
      label: '',
      media_type: '',
      position: 0,
      types: []
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/media';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entry":{"content":{"base64_encoded_data":"","name":"","type":""},"disabled":false,"extension_attributes":{"video_content":{"media_type":"","video_description":"","video_metadata":"","video_provider":"","video_title":"","video_url":""}},"file":"","id":0,"label":"","media_type":"","position":0,"types":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/media',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "entry": {\n    "content": {\n      "base64_encoded_data": "",\n      "name": "",\n      "type": ""\n    },\n    "disabled": false,\n    "extension_attributes": {\n      "video_content": {\n        "media_type": "",\n        "video_description": "",\n        "video_metadata": "",\n        "video_provider": "",\n        "video_title": "",\n        "video_url": ""\n      }\n    },\n    "file": "",\n    "id": 0,\n    "label": "",\n    "media_type": "",\n    "position": 0,\n    "types": []\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  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/media")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/media',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  entry: {
    content: {base64_encoded_data: '', name: '', type: ''},
    disabled: false,
    extension_attributes: {
      video_content: {
        media_type: '',
        video_description: '',
        video_metadata: '',
        video_provider: '',
        video_title: '',
        video_url: ''
      }
    },
    file: '',
    id: 0,
    label: '',
    media_type: '',
    position: 0,
    types: []
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/:sku/media',
  headers: {'content-type': 'application/json'},
  body: {
    entry: {
      content: {base64_encoded_data: '', name: '', type: ''},
      disabled: false,
      extension_attributes: {
        video_content: {
          media_type: '',
          video_description: '',
          video_metadata: '',
          video_provider: '',
          video_title: '',
          video_url: ''
        }
      },
      file: '',
      id: 0,
      label: '',
      media_type: '',
      position: 0,
      types: []
    }
  },
  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}}/V1/products/:sku/media');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  entry: {
    content: {
      base64_encoded_data: '',
      name: '',
      type: ''
    },
    disabled: false,
    extension_attributes: {
      video_content: {
        media_type: '',
        video_description: '',
        video_metadata: '',
        video_provider: '',
        video_title: '',
        video_url: ''
      }
    },
    file: '',
    id: 0,
    label: '',
    media_type: '',
    position: 0,
    types: []
  }
});

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}}/V1/products/:sku/media',
  headers: {'content-type': 'application/json'},
  data: {
    entry: {
      content: {base64_encoded_data: '', name: '', type: ''},
      disabled: false,
      extension_attributes: {
        video_content: {
          media_type: '',
          video_description: '',
          video_metadata: '',
          video_provider: '',
          video_title: '',
          video_url: ''
        }
      },
      file: '',
      id: 0,
      label: '',
      media_type: '',
      position: 0,
      types: []
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/media';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entry":{"content":{"base64_encoded_data":"","name":"","type":""},"disabled":false,"extension_attributes":{"video_content":{"media_type":"","video_description":"","video_metadata":"","video_provider":"","video_title":"","video_url":""}},"file":"","id":0,"label":"","media_type":"","position":0,"types":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"entry": @{ @"content": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" }, @"disabled": @NO, @"extension_attributes": @{ @"video_content": @{ @"media_type": @"", @"video_description": @"", @"video_metadata": @"", @"video_provider": @"", @"video_title": @"", @"video_url": @"" } }, @"file": @"", @"id": @0, @"label": @"", @"media_type": @"", @"position": @0, @"types": @[  ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/media"]
                                                       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}}/V1/products/:sku/media" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/media",
  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([
    'entry' => [
        'content' => [
                'base64_encoded_data' => '',
                'name' => '',
                'type' => ''
        ],
        'disabled' => null,
        'extension_attributes' => [
                'video_content' => [
                                'media_type' => '',
                                'video_description' => '',
                                'video_metadata' => '',
                                'video_provider' => '',
                                'video_title' => '',
                                'video_url' => ''
                ]
        ],
        'file' => '',
        'id' => 0,
        'label' => '',
        'media_type' => '',
        'position' => 0,
        'types' => [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/:sku/media', [
  'body' => '{
  "entry": {
    "content": {
      "base64_encoded_data": "",
      "name": "",
      "type": ""
    },
    "disabled": false,
    "extension_attributes": {
      "video_content": {
        "media_type": "",
        "video_description": "",
        "video_metadata": "",
        "video_provider": "",
        "video_title": "",
        "video_url": ""
      }
    },
    "file": "",
    "id": 0,
    "label": "",
    "media_type": "",
    "position": 0,
    "types": []
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/media');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'entry' => [
    'content' => [
        'base64_encoded_data' => '',
        'name' => '',
        'type' => ''
    ],
    'disabled' => null,
    'extension_attributes' => [
        'video_content' => [
                'media_type' => '',
                'video_description' => '',
                'video_metadata' => '',
                'video_provider' => '',
                'video_title' => '',
                'video_url' => ''
        ]
    ],
    'file' => '',
    'id' => 0,
    'label' => '',
    'media_type' => '',
    'position' => 0,
    'types' => [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'entry' => [
    'content' => [
        'base64_encoded_data' => '',
        'name' => '',
        'type' => ''
    ],
    'disabled' => null,
    'extension_attributes' => [
        'video_content' => [
                'media_type' => '',
                'video_description' => '',
                'video_metadata' => '',
                'video_provider' => '',
                'video_title' => '',
                'video_url' => ''
        ]
    ],
    'file' => '',
    'id' => 0,
    'label' => '',
    'media_type' => '',
    'position' => 0,
    'types' => [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/:sku/media');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/media' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entry": {
    "content": {
      "base64_encoded_data": "",
      "name": "",
      "type": ""
    },
    "disabled": false,
    "extension_attributes": {
      "video_content": {
        "media_type": "",
        "video_description": "",
        "video_metadata": "",
        "video_provider": "",
        "video_title": "",
        "video_url": ""
      }
    },
    "file": "",
    "id": 0,
    "label": "",
    "media_type": "",
    "position": 0,
    "types": []
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/media' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entry": {
    "content": {
      "base64_encoded_data": "",
      "name": "",
      "type": ""
    },
    "disabled": false,
    "extension_attributes": {
      "video_content": {
        "media_type": "",
        "video_description": "",
        "video_metadata": "",
        "video_provider": "",
        "video_title": "",
        "video_url": ""
      }
    },
    "file": "",
    "id": 0,
    "label": "",
    "media_type": "",
    "position": 0,
    "types": []
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/:sku/media", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/media"

payload = { "entry": {
        "content": {
            "base64_encoded_data": "",
            "name": "",
            "type": ""
        },
        "disabled": False,
        "extension_attributes": { "video_content": {
                "media_type": "",
                "video_description": "",
                "video_metadata": "",
                "video_provider": "",
                "video_title": "",
                "video_url": ""
            } },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/media"

payload <- "{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/media")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\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/V1/products/:sku/media') do |req|
  req.body = "{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/media";

    let payload = json!({"entry": json!({
            "content": json!({
                "base64_encoded_data": "",
                "name": "",
                "type": ""
            }),
            "disabled": false,
            "extension_attributes": json!({"video_content": json!({
                    "media_type": "",
                    "video_description": "",
                    "video_metadata": "",
                    "video_provider": "",
                    "video_title": "",
                    "video_url": ""
                })}),
            "file": "",
            "id": 0,
            "label": "",
            "media_type": "",
            "position": 0,
            "types": ()
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/:sku/media \
  --header 'content-type: application/json' \
  --data '{
  "entry": {
    "content": {
      "base64_encoded_data": "",
      "name": "",
      "type": ""
    },
    "disabled": false,
    "extension_attributes": {
      "video_content": {
        "media_type": "",
        "video_description": "",
        "video_metadata": "",
        "video_provider": "",
        "video_title": "",
        "video_url": ""
      }
    },
    "file": "",
    "id": 0,
    "label": "",
    "media_type": "",
    "position": 0,
    "types": []
  }
}'
echo '{
  "entry": {
    "content": {
      "base64_encoded_data": "",
      "name": "",
      "type": ""
    },
    "disabled": false,
    "extension_attributes": {
      "video_content": {
        "media_type": "",
        "video_description": "",
        "video_metadata": "",
        "video_provider": "",
        "video_title": "",
        "video_url": ""
      }
    },
    "file": "",
    "id": 0,
    "label": "",
    "media_type": "",
    "position": 0,
    "types": []
  }
}' |  \
  http POST {{baseUrl}}/V1/products/:sku/media \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "entry": {\n    "content": {\n      "base64_encoded_data": "",\n      "name": "",\n      "type": ""\n    },\n    "disabled": false,\n    "extension_attributes": {\n      "video_content": {\n        "media_type": "",\n        "video_description": "",\n        "video_metadata": "",\n        "video_provider": "",\n        "video_title": "",\n        "video_url": ""\n      }\n    },\n    "file": "",\n    "id": 0,\n    "label": "",\n    "media_type": "",\n    "position": 0,\n    "types": []\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/media
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["entry": [
    "content": [
      "base64_encoded_data": "",
      "name": "",
      "type": ""
    ],
    "disabled": false,
    "extension_attributes": ["video_content": [
        "media_type": "",
        "video_description": "",
        "video_metadata": "",
        "video_provider": "",
        "video_title": "",
        "video_url": ""
      ]],
    "file": "",
    "id": 0,
    "label": "",
    "media_type": "",
    "position": 0,
    "types": []
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/media")! 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 products-{sku}-media
{{baseUrl}}/V1/products/:sku/media
QUERY PARAMS

sku
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/media");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/:sku/media")
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/media"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/:sku/media"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/:sku/media");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/media"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/:sku/media HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/:sku/media")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/media"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/media")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/:sku/media")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/:sku/media');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/:sku/media'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/media';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/media',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/media")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/media',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/:sku/media'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/:sku/media');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/:sku/media'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/media';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/media"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku/media" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/media",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/:sku/media');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/media');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/:sku/media');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/media' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/media' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/:sku/media")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/media"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/media"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/media")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/:sku/media') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/media";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/:sku/media
http GET {{baseUrl}}/V1/products/:sku/media
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/media
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/media")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET products-{sku}-media-{entryId} (GET)
{{baseUrl}}/V1/products/:sku/media/:entryId
QUERY PARAMS

sku
entryId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/media/:entryId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/:sku/media/:entryId")
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/media/:entryId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/:sku/media/:entryId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/:sku/media/:entryId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/media/:entryId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/:sku/media/:entryId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/:sku/media/:entryId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/media/:entryId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/media/:entryId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/:sku/media/:entryId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/:sku/media/:entryId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/:sku/media/:entryId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/media/:entryId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/media/:entryId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/media/:entryId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/media/:entryId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/:sku/media/:entryId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/:sku/media/:entryId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/:sku/media/:entryId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/media/:entryId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/media/:entryId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku/media/:entryId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/media/:entryId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/:sku/media/:entryId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/media/:entryId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/:sku/media/:entryId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/media/:entryId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/media/:entryId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/:sku/media/:entryId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/media/:entryId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/media/:entryId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/media/:entryId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/:sku/media/:entryId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/media/:entryId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/:sku/media/:entryId
http GET {{baseUrl}}/V1/products/:sku/media/:entryId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/media/:entryId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/media/:entryId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT products-{sku}-media-{entryId} (PUT)
{{baseUrl}}/V1/products/:sku/media/:entryId
QUERY PARAMS

sku
entryId
BODY json

{
  "entry": {
    "content": {
      "base64_encoded_data": "",
      "name": "",
      "type": ""
    },
    "disabled": false,
    "extension_attributes": {
      "video_content": {
        "media_type": "",
        "video_description": "",
        "video_metadata": "",
        "video_provider": "",
        "video_title": "",
        "video_url": ""
      }
    },
    "file": "",
    "id": 0,
    "label": "",
    "media_type": "",
    "position": 0,
    "types": []
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/media/:entryId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/products/:sku/media/:entryId" {:content-type :json
                                                                           :form-params {:entry {:content {:base64_encoded_data ""
                                                                                                           :name ""
                                                                                                           :type ""}
                                                                                                 :disabled false
                                                                                                 :extension_attributes {:video_content {:media_type ""
                                                                                                                                        :video_description ""
                                                                                                                                        :video_metadata ""
                                                                                                                                        :video_provider ""
                                                                                                                                        :video_title ""
                                                                                                                                        :video_url ""}}
                                                                                                 :file ""
                                                                                                 :id 0
                                                                                                 :label ""
                                                                                                 :media_type ""
                                                                                                 :position 0
                                                                                                 :types []}}})
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/media/:entryId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\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}}/V1/products/:sku/media/:entryId"),
    Content = new StringContent("{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\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}}/V1/products/:sku/media/:entryId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/media/:entryId"

	payload := strings.NewReader("{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/products/:sku/media/:entryId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 478

{
  "entry": {
    "content": {
      "base64_encoded_data": "",
      "name": "",
      "type": ""
    },
    "disabled": false,
    "extension_attributes": {
      "video_content": {
        "media_type": "",
        "video_description": "",
        "video_metadata": "",
        "video_provider": "",
        "video_title": "",
        "video_url": ""
      }
    },
    "file": "",
    "id": 0,
    "label": "",
    "media_type": "",
    "position": 0,
    "types": []
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/products/:sku/media/:entryId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/media/:entryId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\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  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/media/:entryId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/products/:sku/media/:entryId")
  .header("content-type", "application/json")
  .body("{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}")
  .asString();
const data = JSON.stringify({
  entry: {
    content: {
      base64_encoded_data: '',
      name: '',
      type: ''
    },
    disabled: false,
    extension_attributes: {
      video_content: {
        media_type: '',
        video_description: '',
        video_metadata: '',
        video_provider: '',
        video_title: '',
        video_url: ''
      }
    },
    file: '',
    id: 0,
    label: '',
    media_type: '',
    position: 0,
    types: []
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/products/:sku/media/:entryId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/:sku/media/:entryId',
  headers: {'content-type': 'application/json'},
  data: {
    entry: {
      content: {base64_encoded_data: '', name: '', type: ''},
      disabled: false,
      extension_attributes: {
        video_content: {
          media_type: '',
          video_description: '',
          video_metadata: '',
          video_provider: '',
          video_title: '',
          video_url: ''
        }
      },
      file: '',
      id: 0,
      label: '',
      media_type: '',
      position: 0,
      types: []
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/media/:entryId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"entry":{"content":{"base64_encoded_data":"","name":"","type":""},"disabled":false,"extension_attributes":{"video_content":{"media_type":"","video_description":"","video_metadata":"","video_provider":"","video_title":"","video_url":""}},"file":"","id":0,"label":"","media_type":"","position":0,"types":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/media/:entryId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "entry": {\n    "content": {\n      "base64_encoded_data": "",\n      "name": "",\n      "type": ""\n    },\n    "disabled": false,\n    "extension_attributes": {\n      "video_content": {\n        "media_type": "",\n        "video_description": "",\n        "video_metadata": "",\n        "video_provider": "",\n        "video_title": "",\n        "video_url": ""\n      }\n    },\n    "file": "",\n    "id": 0,\n    "label": "",\n    "media_type": "",\n    "position": 0,\n    "types": []\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  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/media/:entryId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/media/:entryId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  entry: {
    content: {base64_encoded_data: '', name: '', type: ''},
    disabled: false,
    extension_attributes: {
      video_content: {
        media_type: '',
        video_description: '',
        video_metadata: '',
        video_provider: '',
        video_title: '',
        video_url: ''
      }
    },
    file: '',
    id: 0,
    label: '',
    media_type: '',
    position: 0,
    types: []
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/:sku/media/:entryId',
  headers: {'content-type': 'application/json'},
  body: {
    entry: {
      content: {base64_encoded_data: '', name: '', type: ''},
      disabled: false,
      extension_attributes: {
        video_content: {
          media_type: '',
          video_description: '',
          video_metadata: '',
          video_provider: '',
          video_title: '',
          video_url: ''
        }
      },
      file: '',
      id: 0,
      label: '',
      media_type: '',
      position: 0,
      types: []
    }
  },
  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}}/V1/products/:sku/media/:entryId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  entry: {
    content: {
      base64_encoded_data: '',
      name: '',
      type: ''
    },
    disabled: false,
    extension_attributes: {
      video_content: {
        media_type: '',
        video_description: '',
        video_metadata: '',
        video_provider: '',
        video_title: '',
        video_url: ''
      }
    },
    file: '',
    id: 0,
    label: '',
    media_type: '',
    position: 0,
    types: []
  }
});

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}}/V1/products/:sku/media/:entryId',
  headers: {'content-type': 'application/json'},
  data: {
    entry: {
      content: {base64_encoded_data: '', name: '', type: ''},
      disabled: false,
      extension_attributes: {
        video_content: {
          media_type: '',
          video_description: '',
          video_metadata: '',
          video_provider: '',
          video_title: '',
          video_url: ''
        }
      },
      file: '',
      id: 0,
      label: '',
      media_type: '',
      position: 0,
      types: []
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/media/:entryId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"entry":{"content":{"base64_encoded_data":"","name":"","type":""},"disabled":false,"extension_attributes":{"video_content":{"media_type":"","video_description":"","video_metadata":"","video_provider":"","video_title":"","video_url":""}},"file":"","id":0,"label":"","media_type":"","position":0,"types":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"entry": @{ @"content": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" }, @"disabled": @NO, @"extension_attributes": @{ @"video_content": @{ @"media_type": @"", @"video_description": @"", @"video_metadata": @"", @"video_provider": @"", @"video_title": @"", @"video_url": @"" } }, @"file": @"", @"id": @0, @"label": @"", @"media_type": @"", @"position": @0, @"types": @[  ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/media/:entryId"]
                                                       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}}/V1/products/:sku/media/:entryId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/media/:entryId",
  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([
    'entry' => [
        'content' => [
                'base64_encoded_data' => '',
                'name' => '',
                'type' => ''
        ],
        'disabled' => null,
        'extension_attributes' => [
                'video_content' => [
                                'media_type' => '',
                                'video_description' => '',
                                'video_metadata' => '',
                                'video_provider' => '',
                                'video_title' => '',
                                'video_url' => ''
                ]
        ],
        'file' => '',
        'id' => 0,
        'label' => '',
        'media_type' => '',
        'position' => 0,
        'types' => [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/products/:sku/media/:entryId', [
  'body' => '{
  "entry": {
    "content": {
      "base64_encoded_data": "",
      "name": "",
      "type": ""
    },
    "disabled": false,
    "extension_attributes": {
      "video_content": {
        "media_type": "",
        "video_description": "",
        "video_metadata": "",
        "video_provider": "",
        "video_title": "",
        "video_url": ""
      }
    },
    "file": "",
    "id": 0,
    "label": "",
    "media_type": "",
    "position": 0,
    "types": []
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/media/:entryId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'entry' => [
    'content' => [
        'base64_encoded_data' => '',
        'name' => '',
        'type' => ''
    ],
    'disabled' => null,
    'extension_attributes' => [
        'video_content' => [
                'media_type' => '',
                'video_description' => '',
                'video_metadata' => '',
                'video_provider' => '',
                'video_title' => '',
                'video_url' => ''
        ]
    ],
    'file' => '',
    'id' => 0,
    'label' => '',
    'media_type' => '',
    'position' => 0,
    'types' => [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'entry' => [
    'content' => [
        'base64_encoded_data' => '',
        'name' => '',
        'type' => ''
    ],
    'disabled' => null,
    'extension_attributes' => [
        'video_content' => [
                'media_type' => '',
                'video_description' => '',
                'video_metadata' => '',
                'video_provider' => '',
                'video_title' => '',
                'video_url' => ''
        ]
    ],
    'file' => '',
    'id' => 0,
    'label' => '',
    'media_type' => '',
    'position' => 0,
    'types' => [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/:sku/media/:entryId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/media/:entryId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "entry": {
    "content": {
      "base64_encoded_data": "",
      "name": "",
      "type": ""
    },
    "disabled": false,
    "extension_attributes": {
      "video_content": {
        "media_type": "",
        "video_description": "",
        "video_metadata": "",
        "video_provider": "",
        "video_title": "",
        "video_url": ""
      }
    },
    "file": "",
    "id": 0,
    "label": "",
    "media_type": "",
    "position": 0,
    "types": []
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/media/:entryId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "entry": {
    "content": {
      "base64_encoded_data": "",
      "name": "",
      "type": ""
    },
    "disabled": false,
    "extension_attributes": {
      "video_content": {
        "media_type": "",
        "video_description": "",
        "video_metadata": "",
        "video_provider": "",
        "video_title": "",
        "video_url": ""
      }
    },
    "file": "",
    "id": 0,
    "label": "",
    "media_type": "",
    "position": 0,
    "types": []
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/products/:sku/media/:entryId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/media/:entryId"

payload = { "entry": {
        "content": {
            "base64_encoded_data": "",
            "name": "",
            "type": ""
        },
        "disabled": False,
        "extension_attributes": { "video_content": {
                "media_type": "",
                "video_description": "",
                "video_metadata": "",
                "video_provider": "",
                "video_title": "",
                "video_url": ""
            } },
        "file": "",
        "id": 0,
        "label": "",
        "media_type": "",
        "position": 0,
        "types": []
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/media/:entryId"

payload <- "{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/media/:entryId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\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/V1/products/:sku/media/:entryId') do |req|
  req.body = "{\n  \"entry\": {\n    \"content\": {\n      \"base64_encoded_data\": \"\",\n      \"name\": \"\",\n      \"type\": \"\"\n    },\n    \"disabled\": false,\n    \"extension_attributes\": {\n      \"video_content\": {\n        \"media_type\": \"\",\n        \"video_description\": \"\",\n        \"video_metadata\": \"\",\n        \"video_provider\": \"\",\n        \"video_title\": \"\",\n        \"video_url\": \"\"\n      }\n    },\n    \"file\": \"\",\n    \"id\": 0,\n    \"label\": \"\",\n    \"media_type\": \"\",\n    \"position\": 0,\n    \"types\": []\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}}/V1/products/:sku/media/:entryId";

    let payload = json!({"entry": json!({
            "content": json!({
                "base64_encoded_data": "",
                "name": "",
                "type": ""
            }),
            "disabled": false,
            "extension_attributes": json!({"video_content": json!({
                    "media_type": "",
                    "video_description": "",
                    "video_metadata": "",
                    "video_provider": "",
                    "video_title": "",
                    "video_url": ""
                })}),
            "file": "",
            "id": 0,
            "label": "",
            "media_type": "",
            "position": 0,
            "types": ()
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/products/:sku/media/:entryId \
  --header 'content-type: application/json' \
  --data '{
  "entry": {
    "content": {
      "base64_encoded_data": "",
      "name": "",
      "type": ""
    },
    "disabled": false,
    "extension_attributes": {
      "video_content": {
        "media_type": "",
        "video_description": "",
        "video_metadata": "",
        "video_provider": "",
        "video_title": "",
        "video_url": ""
      }
    },
    "file": "",
    "id": 0,
    "label": "",
    "media_type": "",
    "position": 0,
    "types": []
  }
}'
echo '{
  "entry": {
    "content": {
      "base64_encoded_data": "",
      "name": "",
      "type": ""
    },
    "disabled": false,
    "extension_attributes": {
      "video_content": {
        "media_type": "",
        "video_description": "",
        "video_metadata": "",
        "video_provider": "",
        "video_title": "",
        "video_url": ""
      }
    },
    "file": "",
    "id": 0,
    "label": "",
    "media_type": "",
    "position": 0,
    "types": []
  }
}' |  \
  http PUT {{baseUrl}}/V1/products/:sku/media/:entryId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "entry": {\n    "content": {\n      "base64_encoded_data": "",\n      "name": "",\n      "type": ""\n    },\n    "disabled": false,\n    "extension_attributes": {\n      "video_content": {\n        "media_type": "",\n        "video_description": "",\n        "video_metadata": "",\n        "video_provider": "",\n        "video_title": "",\n        "video_url": ""\n      }\n    },\n    "file": "",\n    "id": 0,\n    "label": "",\n    "media_type": "",\n    "position": 0,\n    "types": []\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/media/:entryId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["entry": [
    "content": [
      "base64_encoded_data": "",
      "name": "",
      "type": ""
    ],
    "disabled": false,
    "extension_attributes": ["video_content": [
        "media_type": "",
        "video_description": "",
        "video_metadata": "",
        "video_provider": "",
        "video_title": "",
        "video_url": ""
      ]],
    "file": "",
    "id": 0,
    "label": "",
    "media_type": "",
    "position": 0,
    "types": []
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/media/:entryId")! 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()
DELETE products-{sku}-media-{entryId}
{{baseUrl}}/V1/products/:sku/media/:entryId
QUERY PARAMS

sku
entryId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/media/:entryId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/products/:sku/media/:entryId")
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/media/:entryId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/products/:sku/media/:entryId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/:sku/media/:entryId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/media/:entryId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/products/:sku/media/:entryId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/products/:sku/media/:entryId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/media/:entryId"))
    .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}}/V1/products/:sku/media/:entryId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/products/:sku/media/:entryId")
  .asString();
const 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}}/V1/products/:sku/media/:entryId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/:sku/media/:entryId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/media/:entryId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/media/:entryId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/media/:entryId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/media/:entryId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/:sku/media/:entryId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/products/:sku/media/:entryId');

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}}/V1/products/:sku/media/:entryId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/media/:entryId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/media/:entryId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku/media/:entryId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/media/:entryId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/products/:sku/media/:entryId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/media/:entryId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/:sku/media/:entryId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/media/:entryId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/media/:entryId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/products/:sku/media/:entryId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/media/:entryId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/media/:entryId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/media/:entryId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/products/:sku/media/:entryId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/media/:entryId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/products/:sku/media/:entryId
http DELETE {{baseUrl}}/V1/products/:sku/media/:entryId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/media/:entryId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/media/:entryId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET products-{sku}-options
{{baseUrl}}/V1/products/:sku/options
QUERY PARAMS

sku
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/options");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/:sku/options")
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/options"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/:sku/options"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/:sku/options");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/options"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/:sku/options HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/:sku/options")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/options"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/options")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/:sku/options")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/:sku/options');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/:sku/options'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/options';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/options',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/options")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/options',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/:sku/options'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/:sku/options');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/:sku/options'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/options';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/options"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku/options" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/options",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/:sku/options');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/options');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/:sku/options');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/options' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/options' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/:sku/options")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/options"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/options"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/options")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/:sku/options') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/options";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/:sku/options
http GET {{baseUrl}}/V1/products/:sku/options
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/options
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/options")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET products-{sku}-options-{optionId} (GET)
{{baseUrl}}/V1/products/:sku/options/:optionId
QUERY PARAMS

sku
optionId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/options/:optionId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/:sku/options/:optionId")
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/options/:optionId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/:sku/options/:optionId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/:sku/options/:optionId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/options/:optionId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/:sku/options/:optionId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/:sku/options/:optionId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/options/:optionId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/options/:optionId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/:sku/options/:optionId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/:sku/options/:optionId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/:sku/options/:optionId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/options/:optionId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/options/:optionId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/options/:optionId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/options/:optionId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/:sku/options/:optionId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/:sku/options/:optionId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/:sku/options/:optionId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/options/:optionId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/options/:optionId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku/options/:optionId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/options/:optionId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/:sku/options/:optionId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/options/:optionId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/:sku/options/:optionId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/options/:optionId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/options/:optionId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/:sku/options/:optionId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/options/:optionId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/options/:optionId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/options/:optionId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/:sku/options/:optionId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/options/:optionId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/:sku/options/:optionId
http GET {{baseUrl}}/V1/products/:sku/options/:optionId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/options/:optionId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/options/:optionId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE products-{sku}-options-{optionId}
{{baseUrl}}/V1/products/:sku/options/:optionId
QUERY PARAMS

sku
optionId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/options/:optionId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/products/:sku/options/:optionId")
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/options/:optionId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/products/:sku/options/:optionId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/:sku/options/:optionId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/options/:optionId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/products/:sku/options/:optionId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/products/:sku/options/:optionId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/options/:optionId"))
    .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}}/V1/products/:sku/options/:optionId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/products/:sku/options/:optionId")
  .asString();
const 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}}/V1/products/:sku/options/:optionId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/:sku/options/:optionId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/options/:optionId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/options/:optionId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/options/:optionId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/options/:optionId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/:sku/options/:optionId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/products/:sku/options/:optionId');

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}}/V1/products/:sku/options/:optionId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/options/:optionId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/options/:optionId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku/options/:optionId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/options/:optionId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/products/:sku/options/:optionId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/options/:optionId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/:sku/options/:optionId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/options/:optionId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/options/:optionId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/products/:sku/options/:optionId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/options/:optionId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/options/:optionId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/options/:optionId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/products/:sku/options/:optionId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/options/:optionId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/products/:sku/options/:optionId
http DELETE {{baseUrl}}/V1/products/:sku/options/:optionId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/options/:optionId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/options/:optionId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT products-{sku}-websites (PUT)
{{baseUrl}}/V1/products/:sku/websites
QUERY PARAMS

sku
BODY json

{
  "productWebsiteLink": {
    "sku": "",
    "website_id": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/websites");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/products/:sku/websites" {:content-type :json
                                                                     :form-params {:productWebsiteLink {:sku ""
                                                                                                        :website_id 0}}})
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/websites"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\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}}/V1/products/:sku/websites"),
    Content = new StringContent("{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\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}}/V1/products/:sku/websites");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/websites"

	payload := strings.NewReader("{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/products/:sku/websites HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 68

{
  "productWebsiteLink": {
    "sku": "",
    "website_id": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/products/:sku/websites")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/websites"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\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  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/websites")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/products/:sku/websites")
  .header("content-type", "application/json")
  .body("{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  productWebsiteLink: {
    sku: '',
    website_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}}/V1/products/:sku/websites');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/:sku/websites',
  headers: {'content-type': 'application/json'},
  data: {productWebsiteLink: {sku: '', website_id: 0}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/websites';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"productWebsiteLink":{"sku":"","website_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}}/V1/products/:sku/websites',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "productWebsiteLink": {\n    "sku": "",\n    "website_id": 0\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  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/websites")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/websites',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({productWebsiteLink: {sku: '', website_id: 0}}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/:sku/websites',
  headers: {'content-type': 'application/json'},
  body: {productWebsiteLink: {sku: '', website_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}}/V1/products/:sku/websites');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  productWebsiteLink: {
    sku: '',
    website_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}}/V1/products/:sku/websites',
  headers: {'content-type': 'application/json'},
  data: {productWebsiteLink: {sku: '', website_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}}/V1/products/:sku/websites';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"productWebsiteLink":{"sku":"","website_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 = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"productWebsiteLink": @{ @"sku": @"", @"website_id": @0 } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/websites"]
                                                       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}}/V1/products/:sku/websites" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/websites",
  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([
    'productWebsiteLink' => [
        'sku' => '',
        'website_id' => 0
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/products/:sku/websites', [
  'body' => '{
  "productWebsiteLink": {
    "sku": "",
    "website_id": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/websites');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'productWebsiteLink' => [
    'sku' => '',
    'website_id' => 0
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'productWebsiteLink' => [
    'sku' => '',
    'website_id' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/:sku/websites');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/websites' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "productWebsiteLink": {
    "sku": "",
    "website_id": 0
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/websites' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "productWebsiteLink": {
    "sku": "",
    "website_id": 0
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/products/:sku/websites", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/websites"

payload = { "productWebsiteLink": {
        "sku": "",
        "website_id": 0
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/websites"

payload <- "{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/websites")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\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/V1/products/:sku/websites') do |req|
  req.body = "{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\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}}/V1/products/:sku/websites";

    let payload = json!({"productWebsiteLink": json!({
            "sku": "",
            "website_id": 0
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/products/:sku/websites \
  --header 'content-type: application/json' \
  --data '{
  "productWebsiteLink": {
    "sku": "",
    "website_id": 0
  }
}'
echo '{
  "productWebsiteLink": {
    "sku": "",
    "website_id": 0
  }
}' |  \
  http PUT {{baseUrl}}/V1/products/:sku/websites \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "productWebsiteLink": {\n    "sku": "",\n    "website_id": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/websites
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["productWebsiteLink": [
    "sku": "",
    "website_id": 0
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/websites")! 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 products-{sku}-websites
{{baseUrl}}/V1/products/:sku/websites
QUERY PARAMS

sku
BODY json

{
  "productWebsiteLink": {
    "sku": "",
    "website_id": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/websites");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/:sku/websites" {:content-type :json
                                                                      :form-params {:productWebsiteLink {:sku ""
                                                                                                         :website_id 0}}})
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/websites"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\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}}/V1/products/:sku/websites"),
    Content = new StringContent("{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\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}}/V1/products/:sku/websites");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/websites"

	payload := strings.NewReader("{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/:sku/websites HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 68

{
  "productWebsiteLink": {
    "sku": "",
    "website_id": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/:sku/websites")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/websites"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\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  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/websites")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/:sku/websites")
  .header("content-type", "application/json")
  .body("{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  productWebsiteLink: {
    sku: '',
    website_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}}/V1/products/:sku/websites');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/:sku/websites',
  headers: {'content-type': 'application/json'},
  data: {productWebsiteLink: {sku: '', website_id: 0}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/websites';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"productWebsiteLink":{"sku":"","website_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}}/V1/products/:sku/websites',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "productWebsiteLink": {\n    "sku": "",\n    "website_id": 0\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  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/websites")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/websites',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({productWebsiteLink: {sku: '', website_id: 0}}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/:sku/websites',
  headers: {'content-type': 'application/json'},
  body: {productWebsiteLink: {sku: '', website_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}}/V1/products/:sku/websites');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  productWebsiteLink: {
    sku: '',
    website_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}}/V1/products/:sku/websites',
  headers: {'content-type': 'application/json'},
  data: {productWebsiteLink: {sku: '', website_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}}/V1/products/:sku/websites';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"productWebsiteLink":{"sku":"","website_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 = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"productWebsiteLink": @{ @"sku": @"", @"website_id": @0 } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/websites"]
                                                       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}}/V1/products/:sku/websites" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/websites",
  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([
    'productWebsiteLink' => [
        'sku' => '',
        'website_id' => 0
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/:sku/websites', [
  'body' => '{
  "productWebsiteLink": {
    "sku": "",
    "website_id": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/websites');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'productWebsiteLink' => [
    'sku' => '',
    'website_id' => 0
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'productWebsiteLink' => [
    'sku' => '',
    'website_id' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/:sku/websites');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/websites' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "productWebsiteLink": {
    "sku": "",
    "website_id": 0
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/websites' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "productWebsiteLink": {
    "sku": "",
    "website_id": 0
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/:sku/websites", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/websites"

payload = { "productWebsiteLink": {
        "sku": "",
        "website_id": 0
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/websites"

payload <- "{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/websites")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\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/V1/products/:sku/websites') do |req|
  req.body = "{\n  \"productWebsiteLink\": {\n    \"sku\": \"\",\n    \"website_id\": 0\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/websites";

    let payload = json!({"productWebsiteLink": json!({
            "sku": "",
            "website_id": 0
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/:sku/websites \
  --header 'content-type: application/json' \
  --data '{
  "productWebsiteLink": {
    "sku": "",
    "website_id": 0
  }
}'
echo '{
  "productWebsiteLink": {
    "sku": "",
    "website_id": 0
  }
}' |  \
  http POST {{baseUrl}}/V1/products/:sku/websites \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "productWebsiteLink": {\n    "sku": "",\n    "website_id": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/websites
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["productWebsiteLink": [
    "sku": "",
    "website_id": 0
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/websites")! 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 products-{sku}-websites-{websiteId}
{{baseUrl}}/V1/products/:sku/websites/:websiteId
QUERY PARAMS

sku
websiteId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/:sku/websites/:websiteId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/products/:sku/websites/:websiteId")
require "http/client"

url = "{{baseUrl}}/V1/products/:sku/websites/:websiteId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/products/:sku/websites/:websiteId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/:sku/websites/:websiteId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/:sku/websites/:websiteId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/products/:sku/websites/:websiteId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/products/:sku/websites/:websiteId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/:sku/websites/:websiteId"))
    .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}}/V1/products/:sku/websites/:websiteId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/products/:sku/websites/:websiteId")
  .asString();
const 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}}/V1/products/:sku/websites/:websiteId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/:sku/websites/:websiteId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/:sku/websites/:websiteId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/:sku/websites/:websiteId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/:sku/websites/:websiteId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/:sku/websites/:websiteId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/:sku/websites/:websiteId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/products/:sku/websites/:websiteId');

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}}/V1/products/:sku/websites/:websiteId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/:sku/websites/:websiteId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/:sku/websites/:websiteId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/:sku/websites/:websiteId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/:sku/websites/:websiteId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/products/:sku/websites/:websiteId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/:sku/websites/:websiteId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/:sku/websites/:websiteId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/:sku/websites/:websiteId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/:sku/websites/:websiteId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/products/:sku/websites/:websiteId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/:sku/websites/:websiteId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/:sku/websites/:websiteId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/:sku/websites/:websiteId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/products/:sku/websites/:websiteId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/:sku/websites/:websiteId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/products/:sku/websites/:websiteId
http DELETE {{baseUrl}}/V1/products/:sku/websites/:websiteId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/products/:sku/websites/:websiteId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/:sku/websites/:websiteId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST products-attribute-sets
{{baseUrl}}/V1/products/attribute-sets
BODY json

{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  },
  "skeletonId": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attribute-sets");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"skeletonId\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/attribute-sets" {:content-type :json
                                                                       :form-params {:attributeSet {:attribute_set_id 0
                                                                                                    :attribute_set_name ""
                                                                                                    :entity_type_id 0
                                                                                                    :extension_attributes {}
                                                                                                    :sort_order 0}
                                                                                     :skeletonId 0}})
require "http/client"

url = "{{baseUrl}}/V1/products/attribute-sets"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"skeletonId\": 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}}/V1/products/attribute-sets"),
    Content = new StringContent("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"skeletonId\": 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}}/V1/products/attribute-sets");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"skeletonId\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attribute-sets"

	payload := strings.NewReader("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"skeletonId\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/attribute-sets HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 180

{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  },
  "skeletonId": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/attribute-sets")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"skeletonId\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attribute-sets"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"skeletonId\": 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  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"skeletonId\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/attribute-sets")
  .header("content-type", "application/json")
  .body("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"skeletonId\": 0\n}")
  .asString();
const data = JSON.stringify({
  attributeSet: {
    attribute_set_id: 0,
    attribute_set_name: '',
    entity_type_id: 0,
    extension_attributes: {},
    sort_order: 0
  },
  skeletonId: 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}}/V1/products/attribute-sets');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/attribute-sets',
  headers: {'content-type': 'application/json'},
  data: {
    attributeSet: {
      attribute_set_id: 0,
      attribute_set_name: '',
      entity_type_id: 0,
      extension_attributes: {},
      sort_order: 0
    },
    skeletonId: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attribute-sets';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"attributeSet":{"attribute_set_id":0,"attribute_set_name":"","entity_type_id":0,"extension_attributes":{},"sort_order":0},"skeletonId":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}}/V1/products/attribute-sets',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attributeSet": {\n    "attribute_set_id": 0,\n    "attribute_set_name": "",\n    "entity_type_id": 0,\n    "extension_attributes": {},\n    "sort_order": 0\n  },\n  "skeletonId": 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  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"skeletonId\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attribute-sets',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  attributeSet: {
    attribute_set_id: 0,
    attribute_set_name: '',
    entity_type_id: 0,
    extension_attributes: {},
    sort_order: 0
  },
  skeletonId: 0
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/attribute-sets',
  headers: {'content-type': 'application/json'},
  body: {
    attributeSet: {
      attribute_set_id: 0,
      attribute_set_name: '',
      entity_type_id: 0,
      extension_attributes: {},
      sort_order: 0
    },
    skeletonId: 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}}/V1/products/attribute-sets');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attributeSet: {
    attribute_set_id: 0,
    attribute_set_name: '',
    entity_type_id: 0,
    extension_attributes: {},
    sort_order: 0
  },
  skeletonId: 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}}/V1/products/attribute-sets',
  headers: {'content-type': 'application/json'},
  data: {
    attributeSet: {
      attribute_set_id: 0,
      attribute_set_name: '',
      entity_type_id: 0,
      extension_attributes: {},
      sort_order: 0
    },
    skeletonId: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attribute-sets';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"attributeSet":{"attribute_set_id":0,"attribute_set_name":"","entity_type_id":0,"extension_attributes":{},"sort_order":0},"skeletonId":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attributeSet": @{ @"attribute_set_id": @0, @"attribute_set_name": @"", @"entity_type_id": @0, @"extension_attributes": @{  }, @"sort_order": @0 },
                              @"skeletonId": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attribute-sets"]
                                                       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}}/V1/products/attribute-sets" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"skeletonId\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attribute-sets",
  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([
    'attributeSet' => [
        'attribute_set_id' => 0,
        'attribute_set_name' => '',
        'entity_type_id' => 0,
        'extension_attributes' => [
                
        ],
        'sort_order' => 0
    ],
    'skeletonId' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/attribute-sets', [
  'body' => '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  },
  "skeletonId": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attribute-sets');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attributeSet' => [
    'attribute_set_id' => 0,
    'attribute_set_name' => '',
    'entity_type_id' => 0,
    'extension_attributes' => [
        
    ],
    'sort_order' => 0
  ],
  'skeletonId' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attributeSet' => [
    'attribute_set_id' => 0,
    'attribute_set_name' => '',
    'entity_type_id' => 0,
    'extension_attributes' => [
        
    ],
    'sort_order' => 0
  ],
  'skeletonId' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/attribute-sets');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attribute-sets' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  },
  "skeletonId": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attribute-sets' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  },
  "skeletonId": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"skeletonId\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/attribute-sets", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attribute-sets"

payload = {
    "attributeSet": {
        "attribute_set_id": 0,
        "attribute_set_name": "",
        "entity_type_id": 0,
        "extension_attributes": {},
        "sort_order": 0
    },
    "skeletonId": 0
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attribute-sets"

payload <- "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"skeletonId\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attribute-sets")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"skeletonId\": 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/V1/products/attribute-sets') do |req|
  req.body = "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  },\n  \"skeletonId\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/attribute-sets";

    let payload = json!({
        "attributeSet": json!({
            "attribute_set_id": 0,
            "attribute_set_name": "",
            "entity_type_id": 0,
            "extension_attributes": json!({}),
            "sort_order": 0
        }),
        "skeletonId": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/attribute-sets \
  --header 'content-type: application/json' \
  --data '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  },
  "skeletonId": 0
}'
echo '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  },
  "skeletonId": 0
}' |  \
  http POST {{baseUrl}}/V1/products/attribute-sets \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "attributeSet": {\n    "attribute_set_id": 0,\n    "attribute_set_name": "",\n    "entity_type_id": 0,\n    "extension_attributes": {},\n    "sort_order": 0\n  },\n  "skeletonId": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/attribute-sets
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "attributeSet": [
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": [],
    "sort_order": 0
  ],
  "skeletonId": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attribute-sets")! 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 products-attribute-sets-{attributeSetId} (GET)
{{baseUrl}}/V1/products/attribute-sets/:attributeSetId
QUERY PARAMS

attributeSetId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")
require "http/client"

url = "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/attribute-sets/:attributeSetId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attribute-sets/:attributeSetId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attribute-sets/:attributeSetId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/attribute-sets/:attributeSetId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/attribute-sets/:attributeSetId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/attribute-sets/:attributeSetId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/attribute-sets/:attributeSetId
http GET {{baseUrl}}/V1/products/attribute-sets/:attributeSetId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/attribute-sets/:attributeSetId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT products-attribute-sets-{attributeSetId} (PUT)
{{baseUrl}}/V1/products/attribute-sets/:attributeSetId
QUERY PARAMS

attributeSetId
BODY json

{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId" {:content-type :json
                                                                                      :form-params {:attributeSet {:attribute_set_id 0
                                                                                                                   :attribute_set_name ""
                                                                                                                   :entity_type_id 0
                                                                                                                   :extension_attributes {}
                                                                                                                   :sort_order 0}}})
require "http/client"

url = "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\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}}/V1/products/attribute-sets/:attributeSetId"),
    Content = new StringContent("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\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}}/V1/products/attribute-sets/:attributeSetId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"

	payload := strings.NewReader("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/products/attribute-sets/:attributeSetId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 161

{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\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  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")
  .header("content-type", "application/json")
  .body("{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  attributeSet: {
    attribute_set_id: 0,
    attribute_set_name: '',
    entity_type_id: 0,
    extension_attributes: {},
    sort_order: 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}}/V1/products/attribute-sets/:attributeSetId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId',
  headers: {'content-type': 'application/json'},
  data: {
    attributeSet: {
      attribute_set_id: 0,
      attribute_set_name: '',
      entity_type_id: 0,
      extension_attributes: {},
      sort_order: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"attributeSet":{"attribute_set_id":0,"attribute_set_name":"","entity_type_id":0,"extension_attributes":{},"sort_order":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}}/V1/products/attribute-sets/:attributeSetId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attributeSet": {\n    "attribute_set_id": 0,\n    "attribute_set_name": "",\n    "entity_type_id": 0,\n    "extension_attributes": {},\n    "sort_order": 0\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  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attribute-sets/:attributeSetId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  attributeSet: {
    attribute_set_id: 0,
    attribute_set_name: '',
    entity_type_id: 0,
    extension_attributes: {},
    sort_order: 0
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId',
  headers: {'content-type': 'application/json'},
  body: {
    attributeSet: {
      attribute_set_id: 0,
      attribute_set_name: '',
      entity_type_id: 0,
      extension_attributes: {},
      sort_order: 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}}/V1/products/attribute-sets/:attributeSetId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attributeSet: {
    attribute_set_id: 0,
    attribute_set_name: '',
    entity_type_id: 0,
    extension_attributes: {},
    sort_order: 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}}/V1/products/attribute-sets/:attributeSetId',
  headers: {'content-type': 'application/json'},
  data: {
    attributeSet: {
      attribute_set_id: 0,
      attribute_set_name: '',
      entity_type_id: 0,
      extension_attributes: {},
      sort_order: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"attributeSet":{"attribute_set_id":0,"attribute_set_name":"","entity_type_id":0,"extension_attributes":{},"sort_order":0}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attributeSet": @{ @"attribute_set_id": @0, @"attribute_set_name": @"", @"entity_type_id": @0, @"extension_attributes": @{  }, @"sort_order": @0 } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"]
                                                       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}}/V1/products/attribute-sets/:attributeSetId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId",
  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([
    'attributeSet' => [
        'attribute_set_id' => 0,
        'attribute_set_name' => '',
        'entity_type_id' => 0,
        'extension_attributes' => [
                
        ],
        'sort_order' => 0
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId', [
  'body' => '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attribute-sets/:attributeSetId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attributeSet' => [
    'attribute_set_id' => 0,
    'attribute_set_name' => '',
    'entity_type_id' => 0,
    'extension_attributes' => [
        
    ],
    'sort_order' => 0
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attributeSet' => [
    'attribute_set_id' => 0,
    'attribute_set_name' => '',
    'entity_type_id' => 0,
    'extension_attributes' => [
        
    ],
    'sort_order' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/attribute-sets/:attributeSetId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/products/attribute-sets/:attributeSetId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"

payload = { "attributeSet": {
        "attribute_set_id": 0,
        "attribute_set_name": "",
        "entity_type_id": 0,
        "extension_attributes": {},
        "sort_order": 0
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"

payload <- "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\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/V1/products/attribute-sets/:attributeSetId') do |req|
  req.body = "{\n  \"attributeSet\": {\n    \"attribute_set_id\": 0,\n    \"attribute_set_name\": \"\",\n    \"entity_type_id\": 0,\n    \"extension_attributes\": {},\n    \"sort_order\": 0\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}}/V1/products/attribute-sets/:attributeSetId";

    let payload = json!({"attributeSet": json!({
            "attribute_set_id": 0,
            "attribute_set_name": "",
            "entity_type_id": 0,
            "extension_attributes": json!({}),
            "sort_order": 0
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/products/attribute-sets/:attributeSetId \
  --header 'content-type: application/json' \
  --data '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  }
}'
echo '{
  "attributeSet": {
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": {},
    "sort_order": 0
  }
}' |  \
  http PUT {{baseUrl}}/V1/products/attribute-sets/:attributeSetId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "attributeSet": {\n    "attribute_set_id": 0,\n    "attribute_set_name": "",\n    "entity_type_id": 0,\n    "extension_attributes": {},\n    "sort_order": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/attribute-sets/:attributeSetId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["attributeSet": [
    "attribute_set_id": 0,
    "attribute_set_name": "",
    "entity_type_id": 0,
    "extension_attributes": [],
    "sort_order": 0
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")! 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()
DELETE products-attribute-sets-{attributeSetId}
{{baseUrl}}/V1/products/attribute-sets/:attributeSetId
QUERY PARAMS

attributeSetId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")
require "http/client"

url = "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/products/attribute-sets/:attributeSetId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"))
    .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}}/V1/products/attribute-sets/:attributeSetId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")
  .asString();
const 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}}/V1/products/attribute-sets/:attributeSetId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attribute-sets/:attributeSetId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId');

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}}/V1/products/attribute-sets/:attributeSetId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attribute-sets/:attributeSetId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/attribute-sets/:attributeSetId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/products/attribute-sets/:attributeSetId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/products/attribute-sets/:attributeSetId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/products/attribute-sets/:attributeSetId
http DELETE {{baseUrl}}/V1/products/attribute-sets/:attributeSetId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/products/attribute-sets/:attributeSetId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET products-attribute-sets-{attributeSetId}-attributes
{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes
QUERY PARAMS

attributeSetId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes")
require "http/client"

url = "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/attribute-sets/:attributeSetId/attributes HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attribute-sets/:attributeSetId/attributes',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/attribute-sets/:attributeSetId/attributes")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/attribute-sets/:attributeSetId/attributes') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes
http GET {{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE products-attribute-sets-{attributeSetId}-attributes-{attributeCode}
{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode
QUERY PARAMS

attributeSetId
attributeCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode")
require "http/client"

url = "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode"))
    .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}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode")
  .asString();
const 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}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode');

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}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode
http DELETE {{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/attributes/:attributeCode")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT products-attribute-sets-{attributeSetId}-groups
{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups
QUERY PARAMS

attributeSetId
BODY json

{
  "group": {
    "attribute_group_id": "",
    "attribute_group_name": "",
    "attribute_set_id": 0,
    "extension_attributes": {
      "attribute_group_code": "",
      "sort_order": ""
    }
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups" {:content-type :json
                                                                                             :form-params {:group {:attribute_group_id ""
                                                                                                                   :attribute_group_name ""
                                                                                                                   :attribute_set_id 0
                                                                                                                   :extension_attributes {:attribute_group_code ""
                                                                                                                                          :sort_order ""}}}})
require "http/client"

url = "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups"),
    Content = new StringContent("{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\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}}/V1/products/attribute-sets/:attributeSetId/groups");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups"

	payload := strings.NewReader("{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/products/attribute-sets/:attributeSetId/groups HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 202

{
  "group": {
    "attribute_group_id": "",
    "attribute_group_name": "",
    "attribute_set_id": 0,
    "extension_attributes": {
      "attribute_group_code": "",
      "sort_order": ""
    }
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\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  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups")
  .header("content-type", "application/json")
  .body("{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}")
  .asString();
const data = JSON.stringify({
  group: {
    attribute_group_id: '',
    attribute_group_name: '',
    attribute_set_id: 0,
    extension_attributes: {
      attribute_group_code: '',
      sort_order: ''
    }
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups',
  headers: {'content-type': 'application/json'},
  data: {
    group: {
      attribute_group_id: '',
      attribute_group_name: '',
      attribute_set_id: 0,
      extension_attributes: {attribute_group_code: '', sort_order: ''}
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"group":{"attribute_group_id":"","attribute_group_name":"","attribute_set_id":0,"extension_attributes":{"attribute_group_code":"","sort_order":""}}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "group": {\n    "attribute_group_id": "",\n    "attribute_group_name": "",\n    "attribute_set_id": 0,\n    "extension_attributes": {\n      "attribute_group_code": "",\n      "sort_order": ""\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  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attribute-sets/:attributeSetId/groups',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  group: {
    attribute_group_id: '',
    attribute_group_name: '',
    attribute_set_id: 0,
    extension_attributes: {attribute_group_code: '', sort_order: ''}
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups',
  headers: {'content-type': 'application/json'},
  body: {
    group: {
      attribute_group_id: '',
      attribute_group_name: '',
      attribute_set_id: 0,
      extension_attributes: {attribute_group_code: '', sort_order: ''}
    }
  },
  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}}/V1/products/attribute-sets/:attributeSetId/groups');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  group: {
    attribute_group_id: '',
    attribute_group_name: '',
    attribute_set_id: 0,
    extension_attributes: {
      attribute_group_code: '',
      sort_order: ''
    }
  }
});

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}}/V1/products/attribute-sets/:attributeSetId/groups',
  headers: {'content-type': 'application/json'},
  data: {
    group: {
      attribute_group_id: '',
      attribute_group_name: '',
      attribute_set_id: 0,
      extension_attributes: {attribute_group_code: '', sort_order: ''}
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"group":{"attribute_group_id":"","attribute_group_name":"","attribute_set_id":0,"extension_attributes":{"attribute_group_code":"","sort_order":""}}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"group": @{ @"attribute_group_id": @"", @"attribute_group_name": @"", @"attribute_set_id": @0, @"extension_attributes": @{ @"attribute_group_code": @"", @"sort_order": @"" } } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups"]
                                                       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}}/V1/products/attribute-sets/:attributeSetId/groups" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups",
  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([
    'group' => [
        'attribute_group_id' => '',
        'attribute_group_name' => '',
        'attribute_set_id' => 0,
        'extension_attributes' => [
                'attribute_group_code' => '',
                'sort_order' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups', [
  'body' => '{
  "group": {
    "attribute_group_id": "",
    "attribute_group_name": "",
    "attribute_set_id": 0,
    "extension_attributes": {
      "attribute_group_code": "",
      "sort_order": ""
    }
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'group' => [
    'attribute_group_id' => '',
    'attribute_group_name' => '',
    'attribute_set_id' => 0,
    'extension_attributes' => [
        'attribute_group_code' => '',
        'sort_order' => ''
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'group' => [
    'attribute_group_id' => '',
    'attribute_group_name' => '',
    'attribute_set_id' => 0,
    'extension_attributes' => [
        'attribute_group_code' => '',
        'sort_order' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "group": {
    "attribute_group_id": "",
    "attribute_group_name": "",
    "attribute_set_id": 0,
    "extension_attributes": {
      "attribute_group_code": "",
      "sort_order": ""
    }
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "group": {
    "attribute_group_id": "",
    "attribute_group_name": "",
    "attribute_set_id": 0,
    "extension_attributes": {
      "attribute_group_code": "",
      "sort_order": ""
    }
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/products/attribute-sets/:attributeSetId/groups", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups"

payload = { "group": {
        "attribute_group_id": "",
        "attribute_group_name": "",
        "attribute_set_id": 0,
        "extension_attributes": {
            "attribute_group_code": "",
            "sort_order": ""
        }
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups"

payload <- "{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/V1/products/attribute-sets/:attributeSetId/groups') do |req|
  req.body = "{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups";

    let payload = json!({"group": json!({
            "attribute_group_id": "",
            "attribute_group_name": "",
            "attribute_set_id": 0,
            "extension_attributes": json!({
                "attribute_group_code": "",
                "sort_order": ""
            })
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups \
  --header 'content-type: application/json' \
  --data '{
  "group": {
    "attribute_group_id": "",
    "attribute_group_name": "",
    "attribute_set_id": 0,
    "extension_attributes": {
      "attribute_group_code": "",
      "sort_order": ""
    }
  }
}'
echo '{
  "group": {
    "attribute_group_id": "",
    "attribute_group_name": "",
    "attribute_set_id": 0,
    "extension_attributes": {
      "attribute_group_code": "",
      "sort_order": ""
    }
  }
}' |  \
  http PUT {{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "group": {\n    "attribute_group_id": "",\n    "attribute_group_name": "",\n    "attribute_set_id": 0,\n    "extension_attributes": {\n      "attribute_group_code": "",\n      "sort_order": ""\n    }\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["group": [
    "attribute_group_id": "",
    "attribute_group_name": "",
    "attribute_set_id": 0,
    "extension_attributes": [
      "attribute_group_code": "",
      "sort_order": ""
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attribute-sets/:attributeSetId/groups")! 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 products-attribute-sets-attributes
{{baseUrl}}/V1/products/attribute-sets/attributes
BODY json

{
  "attributeCode": "",
  "attributeGroupId": 0,
  "attributeSetId": 0,
  "sortOrder": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attribute-sets/attributes");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attributeCode\": \"\",\n  \"attributeGroupId\": 0,\n  \"attributeSetId\": 0,\n  \"sortOrder\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/attribute-sets/attributes" {:content-type :json
                                                                                  :form-params {:attributeCode ""
                                                                                                :attributeGroupId 0
                                                                                                :attributeSetId 0
                                                                                                :sortOrder 0}})
require "http/client"

url = "{{baseUrl}}/V1/products/attribute-sets/attributes"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"attributeCode\": \"\",\n  \"attributeGroupId\": 0,\n  \"attributeSetId\": 0,\n  \"sortOrder\": 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}}/V1/products/attribute-sets/attributes"),
    Content = new StringContent("{\n  \"attributeCode\": \"\",\n  \"attributeGroupId\": 0,\n  \"attributeSetId\": 0,\n  \"sortOrder\": 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}}/V1/products/attribute-sets/attributes");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attributeCode\": \"\",\n  \"attributeGroupId\": 0,\n  \"attributeSetId\": 0,\n  \"sortOrder\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attribute-sets/attributes"

	payload := strings.NewReader("{\n  \"attributeCode\": \"\",\n  \"attributeGroupId\": 0,\n  \"attributeSetId\": 0,\n  \"sortOrder\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/attribute-sets/attributes HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 91

{
  "attributeCode": "",
  "attributeGroupId": 0,
  "attributeSetId": 0,
  "sortOrder": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/attribute-sets/attributes")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attributeCode\": \"\",\n  \"attributeGroupId\": 0,\n  \"attributeSetId\": 0,\n  \"sortOrder\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attribute-sets/attributes"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attributeCode\": \"\",\n  \"attributeGroupId\": 0,\n  \"attributeSetId\": 0,\n  \"sortOrder\": 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  \"attributeCode\": \"\",\n  \"attributeGroupId\": 0,\n  \"attributeSetId\": 0,\n  \"sortOrder\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/attributes")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/attribute-sets/attributes")
  .header("content-type", "application/json")
  .body("{\n  \"attributeCode\": \"\",\n  \"attributeGroupId\": 0,\n  \"attributeSetId\": 0,\n  \"sortOrder\": 0\n}")
  .asString();
const data = JSON.stringify({
  attributeCode: '',
  attributeGroupId: 0,
  attributeSetId: 0,
  sortOrder: 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}}/V1/products/attribute-sets/attributes');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/attribute-sets/attributes',
  headers: {'content-type': 'application/json'},
  data: {attributeCode: '', attributeGroupId: 0, attributeSetId: 0, sortOrder: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attribute-sets/attributes';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"attributeCode":"","attributeGroupId":0,"attributeSetId":0,"sortOrder":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}}/V1/products/attribute-sets/attributes',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attributeCode": "",\n  "attributeGroupId": 0,\n  "attributeSetId": 0,\n  "sortOrder": 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  \"attributeCode\": \"\",\n  \"attributeGroupId\": 0,\n  \"attributeSetId\": 0,\n  \"sortOrder\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/attributes")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attribute-sets/attributes',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attributeCode: '', attributeGroupId: 0, attributeSetId: 0, sortOrder: 0}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/attribute-sets/attributes',
  headers: {'content-type': 'application/json'},
  body: {attributeCode: '', attributeGroupId: 0, attributeSetId: 0, sortOrder: 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}}/V1/products/attribute-sets/attributes');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attributeCode: '',
  attributeGroupId: 0,
  attributeSetId: 0,
  sortOrder: 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}}/V1/products/attribute-sets/attributes',
  headers: {'content-type': 'application/json'},
  data: {attributeCode: '', attributeGroupId: 0, attributeSetId: 0, sortOrder: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attribute-sets/attributes';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"attributeCode":"","attributeGroupId":0,"attributeSetId":0,"sortOrder":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attributeCode": @"",
                              @"attributeGroupId": @0,
                              @"attributeSetId": @0,
                              @"sortOrder": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attribute-sets/attributes"]
                                                       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}}/V1/products/attribute-sets/attributes" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"attributeCode\": \"\",\n  \"attributeGroupId\": 0,\n  \"attributeSetId\": 0,\n  \"sortOrder\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attribute-sets/attributes",
  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([
    'attributeCode' => '',
    'attributeGroupId' => 0,
    'attributeSetId' => 0,
    'sortOrder' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/attribute-sets/attributes', [
  'body' => '{
  "attributeCode": "",
  "attributeGroupId": 0,
  "attributeSetId": 0,
  "sortOrder": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attribute-sets/attributes');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attributeCode' => '',
  'attributeGroupId' => 0,
  'attributeSetId' => 0,
  'sortOrder' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attributeCode' => '',
  'attributeGroupId' => 0,
  'attributeSetId' => 0,
  'sortOrder' => 0
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/attribute-sets/attributes');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attribute-sets/attributes' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attributeCode": "",
  "attributeGroupId": 0,
  "attributeSetId": 0,
  "sortOrder": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attribute-sets/attributes' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attributeCode": "",
  "attributeGroupId": 0,
  "attributeSetId": 0,
  "sortOrder": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attributeCode\": \"\",\n  \"attributeGroupId\": 0,\n  \"attributeSetId\": 0,\n  \"sortOrder\": 0\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/attribute-sets/attributes", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attribute-sets/attributes"

payload = {
    "attributeCode": "",
    "attributeGroupId": 0,
    "attributeSetId": 0,
    "sortOrder": 0
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attribute-sets/attributes"

payload <- "{\n  \"attributeCode\": \"\",\n  \"attributeGroupId\": 0,\n  \"attributeSetId\": 0,\n  \"sortOrder\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attribute-sets/attributes")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"attributeCode\": \"\",\n  \"attributeGroupId\": 0,\n  \"attributeSetId\": 0,\n  \"sortOrder\": 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/V1/products/attribute-sets/attributes') do |req|
  req.body = "{\n  \"attributeCode\": \"\",\n  \"attributeGroupId\": 0,\n  \"attributeSetId\": 0,\n  \"sortOrder\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/attribute-sets/attributes";

    let payload = json!({
        "attributeCode": "",
        "attributeGroupId": 0,
        "attributeSetId": 0,
        "sortOrder": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/attribute-sets/attributes \
  --header 'content-type: application/json' \
  --data '{
  "attributeCode": "",
  "attributeGroupId": 0,
  "attributeSetId": 0,
  "sortOrder": 0
}'
echo '{
  "attributeCode": "",
  "attributeGroupId": 0,
  "attributeSetId": 0,
  "sortOrder": 0
}' |  \
  http POST {{baseUrl}}/V1/products/attribute-sets/attributes \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "attributeCode": "",\n  "attributeGroupId": 0,\n  "attributeSetId": 0,\n  "sortOrder": 0\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/attribute-sets/attributes
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "attributeCode": "",
  "attributeGroupId": 0,
  "attributeSetId": 0,
  "sortOrder": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attribute-sets/attributes")! 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 products-attribute-sets-groups
{{baseUrl}}/V1/products/attribute-sets/groups
BODY json

{
  "group": {
    "attribute_group_id": "",
    "attribute_group_name": "",
    "attribute_set_id": 0,
    "extension_attributes": {
      "attribute_group_code": "",
      "sort_order": ""
    }
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attribute-sets/groups");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/attribute-sets/groups" {:content-type :json
                                                                              :form-params {:group {:attribute_group_id ""
                                                                                                    :attribute_group_name ""
                                                                                                    :attribute_set_id 0
                                                                                                    :extension_attributes {:attribute_group_code ""
                                                                                                                           :sort_order ""}}}})
require "http/client"

url = "{{baseUrl}}/V1/products/attribute-sets/groups"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\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}}/V1/products/attribute-sets/groups"),
    Content = new StringContent("{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\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}}/V1/products/attribute-sets/groups");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attribute-sets/groups"

	payload := strings.NewReader("{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/attribute-sets/groups HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 202

{
  "group": {
    "attribute_group_id": "",
    "attribute_group_name": "",
    "attribute_set_id": 0,
    "extension_attributes": {
      "attribute_group_code": "",
      "sort_order": ""
    }
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/attribute-sets/groups")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attribute-sets/groups"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\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  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/groups")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/attribute-sets/groups")
  .header("content-type", "application/json")
  .body("{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}")
  .asString();
const data = JSON.stringify({
  group: {
    attribute_group_id: '',
    attribute_group_name: '',
    attribute_set_id: 0,
    extension_attributes: {
      attribute_group_code: '',
      sort_order: ''
    }
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/products/attribute-sets/groups');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/attribute-sets/groups',
  headers: {'content-type': 'application/json'},
  data: {
    group: {
      attribute_group_id: '',
      attribute_group_name: '',
      attribute_set_id: 0,
      extension_attributes: {attribute_group_code: '', sort_order: ''}
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attribute-sets/groups';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"group":{"attribute_group_id":"","attribute_group_name":"","attribute_set_id":0,"extension_attributes":{"attribute_group_code":"","sort_order":""}}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/attribute-sets/groups',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "group": {\n    "attribute_group_id": "",\n    "attribute_group_name": "",\n    "attribute_set_id": 0,\n    "extension_attributes": {\n      "attribute_group_code": "",\n      "sort_order": ""\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  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/groups")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attribute-sets/groups',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  group: {
    attribute_group_id: '',
    attribute_group_name: '',
    attribute_set_id: 0,
    extension_attributes: {attribute_group_code: '', sort_order: ''}
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/attribute-sets/groups',
  headers: {'content-type': 'application/json'},
  body: {
    group: {
      attribute_group_id: '',
      attribute_group_name: '',
      attribute_set_id: 0,
      extension_attributes: {attribute_group_code: '', sort_order: ''}
    }
  },
  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}}/V1/products/attribute-sets/groups');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  group: {
    attribute_group_id: '',
    attribute_group_name: '',
    attribute_set_id: 0,
    extension_attributes: {
      attribute_group_code: '',
      sort_order: ''
    }
  }
});

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}}/V1/products/attribute-sets/groups',
  headers: {'content-type': 'application/json'},
  data: {
    group: {
      attribute_group_id: '',
      attribute_group_name: '',
      attribute_set_id: 0,
      extension_attributes: {attribute_group_code: '', sort_order: ''}
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attribute-sets/groups';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"group":{"attribute_group_id":"","attribute_group_name":"","attribute_set_id":0,"extension_attributes":{"attribute_group_code":"","sort_order":""}}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"group": @{ @"attribute_group_id": @"", @"attribute_group_name": @"", @"attribute_set_id": @0, @"extension_attributes": @{ @"attribute_group_code": @"", @"sort_order": @"" } } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attribute-sets/groups"]
                                                       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}}/V1/products/attribute-sets/groups" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attribute-sets/groups",
  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([
    'group' => [
        'attribute_group_id' => '',
        'attribute_group_name' => '',
        'attribute_set_id' => 0,
        'extension_attributes' => [
                'attribute_group_code' => '',
                'sort_order' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/attribute-sets/groups', [
  'body' => '{
  "group": {
    "attribute_group_id": "",
    "attribute_group_name": "",
    "attribute_set_id": 0,
    "extension_attributes": {
      "attribute_group_code": "",
      "sort_order": ""
    }
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attribute-sets/groups');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'group' => [
    'attribute_group_id' => '',
    'attribute_group_name' => '',
    'attribute_set_id' => 0,
    'extension_attributes' => [
        'attribute_group_code' => '',
        'sort_order' => ''
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'group' => [
    'attribute_group_id' => '',
    'attribute_group_name' => '',
    'attribute_set_id' => 0,
    'extension_attributes' => [
        'attribute_group_code' => '',
        'sort_order' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/attribute-sets/groups');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attribute-sets/groups' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "group": {
    "attribute_group_id": "",
    "attribute_group_name": "",
    "attribute_set_id": 0,
    "extension_attributes": {
      "attribute_group_code": "",
      "sort_order": ""
    }
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attribute-sets/groups' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "group": {
    "attribute_group_id": "",
    "attribute_group_name": "",
    "attribute_set_id": 0,
    "extension_attributes": {
      "attribute_group_code": "",
      "sort_order": ""
    }
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/attribute-sets/groups", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attribute-sets/groups"

payload = { "group": {
        "attribute_group_id": "",
        "attribute_group_name": "",
        "attribute_set_id": 0,
        "extension_attributes": {
            "attribute_group_code": "",
            "sort_order": ""
        }
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attribute-sets/groups"

payload <- "{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\n    }\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attribute-sets/groups")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\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/V1/products/attribute-sets/groups') do |req|
  req.body = "{\n  \"group\": {\n    \"attribute_group_id\": \"\",\n    \"attribute_group_name\": \"\",\n    \"attribute_set_id\": 0,\n    \"extension_attributes\": {\n      \"attribute_group_code\": \"\",\n      \"sort_order\": \"\"\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}}/V1/products/attribute-sets/groups";

    let payload = json!({"group": json!({
            "attribute_group_id": "",
            "attribute_group_name": "",
            "attribute_set_id": 0,
            "extension_attributes": json!({
                "attribute_group_code": "",
                "sort_order": ""
            })
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/attribute-sets/groups \
  --header 'content-type: application/json' \
  --data '{
  "group": {
    "attribute_group_id": "",
    "attribute_group_name": "",
    "attribute_set_id": 0,
    "extension_attributes": {
      "attribute_group_code": "",
      "sort_order": ""
    }
  }
}'
echo '{
  "group": {
    "attribute_group_id": "",
    "attribute_group_name": "",
    "attribute_set_id": 0,
    "extension_attributes": {
      "attribute_group_code": "",
      "sort_order": ""
    }
  }
}' |  \
  http POST {{baseUrl}}/V1/products/attribute-sets/groups \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "group": {\n    "attribute_group_id": "",\n    "attribute_group_name": "",\n    "attribute_set_id": 0,\n    "extension_attributes": {\n      "attribute_group_code": "",\n      "sort_order": ""\n    }\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/attribute-sets/groups
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["group": [
    "attribute_group_id": "",
    "attribute_group_name": "",
    "attribute_set_id": 0,
    "extension_attributes": [
      "attribute_group_code": "",
      "sort_order": ""
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attribute-sets/groups")! 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 products-attribute-sets-groups-{groupId}
{{baseUrl}}/V1/products/attribute-sets/groups/:groupId
QUERY PARAMS

groupId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attribute-sets/groups/:groupId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/products/attribute-sets/groups/:groupId")
require "http/client"

url = "{{baseUrl}}/V1/products/attribute-sets/groups/:groupId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/products/attribute-sets/groups/:groupId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/attribute-sets/groups/:groupId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attribute-sets/groups/:groupId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/products/attribute-sets/groups/:groupId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/products/attribute-sets/groups/:groupId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attribute-sets/groups/:groupId"))
    .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}}/V1/products/attribute-sets/groups/:groupId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/products/attribute-sets/groups/:groupId")
  .asString();
const 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}}/V1/products/attribute-sets/groups/:groupId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/attribute-sets/groups/:groupId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attribute-sets/groups/:groupId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/attribute-sets/groups/:groupId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/groups/:groupId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attribute-sets/groups/:groupId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/attribute-sets/groups/:groupId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/products/attribute-sets/groups/:groupId');

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}}/V1/products/attribute-sets/groups/:groupId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attribute-sets/groups/:groupId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attribute-sets/groups/:groupId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/attribute-sets/groups/:groupId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attribute-sets/groups/:groupId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/products/attribute-sets/groups/:groupId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attribute-sets/groups/:groupId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/attribute-sets/groups/:groupId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attribute-sets/groups/:groupId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attribute-sets/groups/:groupId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/products/attribute-sets/groups/:groupId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attribute-sets/groups/:groupId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attribute-sets/groups/:groupId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attribute-sets/groups/:groupId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/products/attribute-sets/groups/:groupId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/attribute-sets/groups/:groupId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/products/attribute-sets/groups/:groupId
http DELETE {{baseUrl}}/V1/products/attribute-sets/groups/:groupId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/products/attribute-sets/groups/:groupId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attribute-sets/groups/:groupId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET products-attribute-sets-groups-list
{{baseUrl}}/V1/products/attribute-sets/groups/list
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attribute-sets/groups/list");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/attribute-sets/groups/list")
require "http/client"

url = "{{baseUrl}}/V1/products/attribute-sets/groups/list"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/attribute-sets/groups/list"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/attribute-sets/groups/list");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attribute-sets/groups/list"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/attribute-sets/groups/list HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/attribute-sets/groups/list")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attribute-sets/groups/list"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/groups/list")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/attribute-sets/groups/list")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/attribute-sets/groups/list');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attribute-sets/groups/list'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attribute-sets/groups/list';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/attribute-sets/groups/list',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/groups/list")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attribute-sets/groups/list',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attribute-sets/groups/list'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/attribute-sets/groups/list');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attribute-sets/groups/list'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attribute-sets/groups/list';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attribute-sets/groups/list"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/attribute-sets/groups/list" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attribute-sets/groups/list",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/attribute-sets/groups/list');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attribute-sets/groups/list');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/attribute-sets/groups/list');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attribute-sets/groups/list' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attribute-sets/groups/list' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/attribute-sets/groups/list")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attribute-sets/groups/list"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attribute-sets/groups/list"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attribute-sets/groups/list")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/attribute-sets/groups/list') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/attribute-sets/groups/list";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/attribute-sets/groups/list
http GET {{baseUrl}}/V1/products/attribute-sets/groups/list
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/attribute-sets/groups/list
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attribute-sets/groups/list")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET products-attribute-sets-sets-list
{{baseUrl}}/V1/products/attribute-sets/sets/list
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attribute-sets/sets/list");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/attribute-sets/sets/list")
require "http/client"

url = "{{baseUrl}}/V1/products/attribute-sets/sets/list"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/attribute-sets/sets/list"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/attribute-sets/sets/list");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attribute-sets/sets/list"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/attribute-sets/sets/list HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/attribute-sets/sets/list")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attribute-sets/sets/list"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/sets/list")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/attribute-sets/sets/list")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/attribute-sets/sets/list');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attribute-sets/sets/list'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attribute-sets/sets/list';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/attribute-sets/sets/list',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attribute-sets/sets/list")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attribute-sets/sets/list',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attribute-sets/sets/list'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/attribute-sets/sets/list');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attribute-sets/sets/list'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attribute-sets/sets/list';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attribute-sets/sets/list"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/attribute-sets/sets/list" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attribute-sets/sets/list",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/attribute-sets/sets/list');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attribute-sets/sets/list');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/attribute-sets/sets/list');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attribute-sets/sets/list' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attribute-sets/sets/list' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/attribute-sets/sets/list")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attribute-sets/sets/list"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attribute-sets/sets/list"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attribute-sets/sets/list")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/attribute-sets/sets/list') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/attribute-sets/sets/list";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/attribute-sets/sets/list
http GET {{baseUrl}}/V1/products/attribute-sets/sets/list
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/attribute-sets/sets/list
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attribute-sets/sets/list")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST products-attributes (POST)
{{baseUrl}}/V1/products/attributes
BODY json

{
  "attribute": {
    "apply_to": [],
    "attribute_code": "",
    "attribute_id": 0,
    "backend_model": "",
    "backend_type": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "default_frontend_label": "",
    "default_value": "",
    "entity_type_id": "",
    "extension_attributes": {},
    "frontend_class": "",
    "frontend_input": "",
    "frontend_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "is_comparable": "",
    "is_filterable": false,
    "is_filterable_in_grid": false,
    "is_filterable_in_search": false,
    "is_html_allowed_on_front": false,
    "is_required": false,
    "is_searchable": "",
    "is_unique": "",
    "is_used_for_promo_rules": "",
    "is_used_in_grid": false,
    "is_user_defined": false,
    "is_visible": false,
    "is_visible_in_advanced_search": "",
    "is_visible_in_grid": false,
    "is_visible_on_front": "",
    "is_wysiwyg_enabled": false,
    "note": "",
    "options": [
      {
        "is_default": false,
        "label": "",
        "sort_order": 0,
        "store_labels": [
          {
            "label": "",
            "store_id": 0
          }
        ],
        "value": ""
      }
    ],
    "position": 0,
    "scope": "",
    "source_model": "",
    "used_for_sort_by": false,
    "used_in_product_listing": "",
    "validation_rules": [
      {
        "key": "",
        "value": ""
      }
    ]
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attributes");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/attributes" {:content-type :json
                                                                   :form-params {:attribute {:apply_to []
                                                                                             :attribute_code ""
                                                                                             :attribute_id 0
                                                                                             :backend_model ""
                                                                                             :backend_type ""
                                                                                             :custom_attributes [{:attribute_code ""
                                                                                                                  :value ""}]
                                                                                             :default_frontend_label ""
                                                                                             :default_value ""
                                                                                             :entity_type_id ""
                                                                                             :extension_attributes {}
                                                                                             :frontend_class ""
                                                                                             :frontend_input ""
                                                                                             :frontend_labels [{:label ""
                                                                                                                :store_id 0}]
                                                                                             :is_comparable ""
                                                                                             :is_filterable false
                                                                                             :is_filterable_in_grid false
                                                                                             :is_filterable_in_search false
                                                                                             :is_html_allowed_on_front false
                                                                                             :is_required false
                                                                                             :is_searchable ""
                                                                                             :is_unique ""
                                                                                             :is_used_for_promo_rules ""
                                                                                             :is_used_in_grid false
                                                                                             :is_user_defined false
                                                                                             :is_visible false
                                                                                             :is_visible_in_advanced_search ""
                                                                                             :is_visible_in_grid false
                                                                                             :is_visible_on_front ""
                                                                                             :is_wysiwyg_enabled false
                                                                                             :note ""
                                                                                             :options [{:is_default false
                                                                                                        :label ""
                                                                                                        :sort_order 0
                                                                                                        :store_labels [{:label ""
                                                                                                                        :store_id 0}]
                                                                                                        :value ""}]
                                                                                             :position 0
                                                                                             :scope ""
                                                                                             :source_model ""
                                                                                             :used_for_sort_by false
                                                                                             :used_in_product_listing ""
                                                                                             :validation_rules [{:key ""
                                                                                                                 :value ""}]}}})
require "http/client"

url = "{{baseUrl}}/V1/products/attributes"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\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}}/V1/products/attributes"),
    Content = new StringContent("{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/attributes");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attributes"

	payload := strings.NewReader("{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/attributes HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1474

{
  "attribute": {
    "apply_to": [],
    "attribute_code": "",
    "attribute_id": 0,
    "backend_model": "",
    "backend_type": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "default_frontend_label": "",
    "default_value": "",
    "entity_type_id": "",
    "extension_attributes": {},
    "frontend_class": "",
    "frontend_input": "",
    "frontend_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "is_comparable": "",
    "is_filterable": false,
    "is_filterable_in_grid": false,
    "is_filterable_in_search": false,
    "is_html_allowed_on_front": false,
    "is_required": false,
    "is_searchable": "",
    "is_unique": "",
    "is_used_for_promo_rules": "",
    "is_used_in_grid": false,
    "is_user_defined": false,
    "is_visible": false,
    "is_visible_in_advanced_search": "",
    "is_visible_in_grid": false,
    "is_visible_on_front": "",
    "is_wysiwyg_enabled": false,
    "note": "",
    "options": [
      {
        "is_default": false,
        "label": "",
        "sort_order": 0,
        "store_labels": [
          {
            "label": "",
            "store_id": 0
          }
        ],
        "value": ""
      }
    ],
    "position": 0,
    "scope": "",
    "source_model": "",
    "used_for_sort_by": false,
    "used_in_product_listing": "",
    "validation_rules": [
      {
        "key": "",
        "value": ""
      }
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/attributes")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attributes"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/attributes")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/attributes")
  .header("content-type", "application/json")
  .body("{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}")
  .asString();
const data = JSON.stringify({
  attribute: {
    apply_to: [],
    attribute_code: '',
    attribute_id: 0,
    backend_model: '',
    backend_type: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    default_frontend_label: '',
    default_value: '',
    entity_type_id: '',
    extension_attributes: {},
    frontend_class: '',
    frontend_input: '',
    frontend_labels: [
      {
        label: '',
        store_id: 0
      }
    ],
    is_comparable: '',
    is_filterable: false,
    is_filterable_in_grid: false,
    is_filterable_in_search: false,
    is_html_allowed_on_front: false,
    is_required: false,
    is_searchable: '',
    is_unique: '',
    is_used_for_promo_rules: '',
    is_used_in_grid: false,
    is_user_defined: false,
    is_visible: false,
    is_visible_in_advanced_search: '',
    is_visible_in_grid: false,
    is_visible_on_front: '',
    is_wysiwyg_enabled: false,
    note: '',
    options: [
      {
        is_default: false,
        label: '',
        sort_order: 0,
        store_labels: [
          {
            label: '',
            store_id: 0
          }
        ],
        value: ''
      }
    ],
    position: 0,
    scope: '',
    source_model: '',
    used_for_sort_by: false,
    used_in_product_listing: '',
    validation_rules: [
      {
        key: '',
        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}}/V1/products/attributes');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/attributes',
  headers: {'content-type': 'application/json'},
  data: {
    attribute: {
      apply_to: [],
      attribute_code: '',
      attribute_id: 0,
      backend_model: '',
      backend_type: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      default_frontend_label: '',
      default_value: '',
      entity_type_id: '',
      extension_attributes: {},
      frontend_class: '',
      frontend_input: '',
      frontend_labels: [{label: '', store_id: 0}],
      is_comparable: '',
      is_filterable: false,
      is_filterable_in_grid: false,
      is_filterable_in_search: false,
      is_html_allowed_on_front: false,
      is_required: false,
      is_searchable: '',
      is_unique: '',
      is_used_for_promo_rules: '',
      is_used_in_grid: false,
      is_user_defined: false,
      is_visible: false,
      is_visible_in_advanced_search: '',
      is_visible_in_grid: false,
      is_visible_on_front: '',
      is_wysiwyg_enabled: false,
      note: '',
      options: [
        {
          is_default: false,
          label: '',
          sort_order: 0,
          store_labels: [{label: '', store_id: 0}],
          value: ''
        }
      ],
      position: 0,
      scope: '',
      source_model: '',
      used_for_sort_by: false,
      used_in_product_listing: '',
      validation_rules: [{key: '', value: ''}]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attributes';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"attribute":{"apply_to":[],"attribute_code":"","attribute_id":0,"backend_model":"","backend_type":"","custom_attributes":[{"attribute_code":"","value":""}],"default_frontend_label":"","default_value":"","entity_type_id":"","extension_attributes":{},"frontend_class":"","frontend_input":"","frontend_labels":[{"label":"","store_id":0}],"is_comparable":"","is_filterable":false,"is_filterable_in_grid":false,"is_filterable_in_search":false,"is_html_allowed_on_front":false,"is_required":false,"is_searchable":"","is_unique":"","is_used_for_promo_rules":"","is_used_in_grid":false,"is_user_defined":false,"is_visible":false,"is_visible_in_advanced_search":"","is_visible_in_grid":false,"is_visible_on_front":"","is_wysiwyg_enabled":false,"note":"","options":[{"is_default":false,"label":"","sort_order":0,"store_labels":[{"label":"","store_id":0}],"value":""}],"position":0,"scope":"","source_model":"","used_for_sort_by":false,"used_in_product_listing":"","validation_rules":[{"key":"","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}}/V1/products/attributes',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attribute": {\n    "apply_to": [],\n    "attribute_code": "",\n    "attribute_id": 0,\n    "backend_model": "",\n    "backend_type": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "default_frontend_label": "",\n    "default_value": "",\n    "entity_type_id": "",\n    "extension_attributes": {},\n    "frontend_class": "",\n    "frontend_input": "",\n    "frontend_labels": [\n      {\n        "label": "",\n        "store_id": 0\n      }\n    ],\n    "is_comparable": "",\n    "is_filterable": false,\n    "is_filterable_in_grid": false,\n    "is_filterable_in_search": false,\n    "is_html_allowed_on_front": false,\n    "is_required": false,\n    "is_searchable": "",\n    "is_unique": "",\n    "is_used_for_promo_rules": "",\n    "is_used_in_grid": false,\n    "is_user_defined": false,\n    "is_visible": false,\n    "is_visible_in_advanced_search": "",\n    "is_visible_in_grid": false,\n    "is_visible_on_front": "",\n    "is_wysiwyg_enabled": false,\n    "note": "",\n    "options": [\n      {\n        "is_default": false,\n        "label": "",\n        "sort_order": 0,\n        "store_labels": [\n          {\n            "label": "",\n            "store_id": 0\n          }\n        ],\n        "value": ""\n      }\n    ],\n    "position": 0,\n    "scope": "",\n    "source_model": "",\n    "used_for_sort_by": false,\n    "used_in_product_listing": "",\n    "validation_rules": [\n      {\n        "key": "",\n        "value": ""\n      }\n    ]\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attributes")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attributes',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  attribute: {
    apply_to: [],
    attribute_code: '',
    attribute_id: 0,
    backend_model: '',
    backend_type: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    default_frontend_label: '',
    default_value: '',
    entity_type_id: '',
    extension_attributes: {},
    frontend_class: '',
    frontend_input: '',
    frontend_labels: [{label: '', store_id: 0}],
    is_comparable: '',
    is_filterable: false,
    is_filterable_in_grid: false,
    is_filterable_in_search: false,
    is_html_allowed_on_front: false,
    is_required: false,
    is_searchable: '',
    is_unique: '',
    is_used_for_promo_rules: '',
    is_used_in_grid: false,
    is_user_defined: false,
    is_visible: false,
    is_visible_in_advanced_search: '',
    is_visible_in_grid: false,
    is_visible_on_front: '',
    is_wysiwyg_enabled: false,
    note: '',
    options: [
      {
        is_default: false,
        label: '',
        sort_order: 0,
        store_labels: [{label: '', store_id: 0}],
        value: ''
      }
    ],
    position: 0,
    scope: '',
    source_model: '',
    used_for_sort_by: false,
    used_in_product_listing: '',
    validation_rules: [{key: '', value: ''}]
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/attributes',
  headers: {'content-type': 'application/json'},
  body: {
    attribute: {
      apply_to: [],
      attribute_code: '',
      attribute_id: 0,
      backend_model: '',
      backend_type: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      default_frontend_label: '',
      default_value: '',
      entity_type_id: '',
      extension_attributes: {},
      frontend_class: '',
      frontend_input: '',
      frontend_labels: [{label: '', store_id: 0}],
      is_comparable: '',
      is_filterable: false,
      is_filterable_in_grid: false,
      is_filterable_in_search: false,
      is_html_allowed_on_front: false,
      is_required: false,
      is_searchable: '',
      is_unique: '',
      is_used_for_promo_rules: '',
      is_used_in_grid: false,
      is_user_defined: false,
      is_visible: false,
      is_visible_in_advanced_search: '',
      is_visible_in_grid: false,
      is_visible_on_front: '',
      is_wysiwyg_enabled: false,
      note: '',
      options: [
        {
          is_default: false,
          label: '',
          sort_order: 0,
          store_labels: [{label: '', store_id: 0}],
          value: ''
        }
      ],
      position: 0,
      scope: '',
      source_model: '',
      used_for_sort_by: false,
      used_in_product_listing: '',
      validation_rules: [{key: '', 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}}/V1/products/attributes');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attribute: {
    apply_to: [],
    attribute_code: '',
    attribute_id: 0,
    backend_model: '',
    backend_type: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    default_frontend_label: '',
    default_value: '',
    entity_type_id: '',
    extension_attributes: {},
    frontend_class: '',
    frontend_input: '',
    frontend_labels: [
      {
        label: '',
        store_id: 0
      }
    ],
    is_comparable: '',
    is_filterable: false,
    is_filterable_in_grid: false,
    is_filterable_in_search: false,
    is_html_allowed_on_front: false,
    is_required: false,
    is_searchable: '',
    is_unique: '',
    is_used_for_promo_rules: '',
    is_used_in_grid: false,
    is_user_defined: false,
    is_visible: false,
    is_visible_in_advanced_search: '',
    is_visible_in_grid: false,
    is_visible_on_front: '',
    is_wysiwyg_enabled: false,
    note: '',
    options: [
      {
        is_default: false,
        label: '',
        sort_order: 0,
        store_labels: [
          {
            label: '',
            store_id: 0
          }
        ],
        value: ''
      }
    ],
    position: 0,
    scope: '',
    source_model: '',
    used_for_sort_by: false,
    used_in_product_listing: '',
    validation_rules: [
      {
        key: '',
        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}}/V1/products/attributes',
  headers: {'content-type': 'application/json'},
  data: {
    attribute: {
      apply_to: [],
      attribute_code: '',
      attribute_id: 0,
      backend_model: '',
      backend_type: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      default_frontend_label: '',
      default_value: '',
      entity_type_id: '',
      extension_attributes: {},
      frontend_class: '',
      frontend_input: '',
      frontend_labels: [{label: '', store_id: 0}],
      is_comparable: '',
      is_filterable: false,
      is_filterable_in_grid: false,
      is_filterable_in_search: false,
      is_html_allowed_on_front: false,
      is_required: false,
      is_searchable: '',
      is_unique: '',
      is_used_for_promo_rules: '',
      is_used_in_grid: false,
      is_user_defined: false,
      is_visible: false,
      is_visible_in_advanced_search: '',
      is_visible_in_grid: false,
      is_visible_on_front: '',
      is_wysiwyg_enabled: false,
      note: '',
      options: [
        {
          is_default: false,
          label: '',
          sort_order: 0,
          store_labels: [{label: '', store_id: 0}],
          value: ''
        }
      ],
      position: 0,
      scope: '',
      source_model: '',
      used_for_sort_by: false,
      used_in_product_listing: '',
      validation_rules: [{key: '', value: ''}]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attributes';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"attribute":{"apply_to":[],"attribute_code":"","attribute_id":0,"backend_model":"","backend_type":"","custom_attributes":[{"attribute_code":"","value":""}],"default_frontend_label":"","default_value":"","entity_type_id":"","extension_attributes":{},"frontend_class":"","frontend_input":"","frontend_labels":[{"label":"","store_id":0}],"is_comparable":"","is_filterable":false,"is_filterable_in_grid":false,"is_filterable_in_search":false,"is_html_allowed_on_front":false,"is_required":false,"is_searchable":"","is_unique":"","is_used_for_promo_rules":"","is_used_in_grid":false,"is_user_defined":false,"is_visible":false,"is_visible_in_advanced_search":"","is_visible_in_grid":false,"is_visible_on_front":"","is_wysiwyg_enabled":false,"note":"","options":[{"is_default":false,"label":"","sort_order":0,"store_labels":[{"label":"","store_id":0}],"value":""}],"position":0,"scope":"","source_model":"","used_for_sort_by":false,"used_in_product_listing":"","validation_rules":[{"key":"","value":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attribute": @{ @"apply_to": @[  ], @"attribute_code": @"", @"attribute_id": @0, @"backend_model": @"", @"backend_type": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"default_frontend_label": @"", @"default_value": @"", @"entity_type_id": @"", @"extension_attributes": @{  }, @"frontend_class": @"", @"frontend_input": @"", @"frontend_labels": @[ @{ @"label": @"", @"store_id": @0 } ], @"is_comparable": @"", @"is_filterable": @NO, @"is_filterable_in_grid": @NO, @"is_filterable_in_search": @NO, @"is_html_allowed_on_front": @NO, @"is_required": @NO, @"is_searchable": @"", @"is_unique": @"", @"is_used_for_promo_rules": @"", @"is_used_in_grid": @NO, @"is_user_defined": @NO, @"is_visible": @NO, @"is_visible_in_advanced_search": @"", @"is_visible_in_grid": @NO, @"is_visible_on_front": @"", @"is_wysiwyg_enabled": @NO, @"note": @"", @"options": @[ @{ @"is_default": @NO, @"label": @"", @"sort_order": @0, @"store_labels": @[ @{ @"label": @"", @"store_id": @0 } ], @"value": @"" } ], @"position": @0, @"scope": @"", @"source_model": @"", @"used_for_sort_by": @NO, @"used_in_product_listing": @"", @"validation_rules": @[ @{ @"key": @"", @"value": @"" } ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attributes"]
                                                       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}}/V1/products/attributes" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attributes",
  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([
    'attribute' => [
        'apply_to' => [
                
        ],
        'attribute_code' => '',
        'attribute_id' => 0,
        'backend_model' => '',
        'backend_type' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'default_frontend_label' => '',
        'default_value' => '',
        'entity_type_id' => '',
        'extension_attributes' => [
                
        ],
        'frontend_class' => '',
        'frontend_input' => '',
        'frontend_labels' => [
                [
                                'label' => '',
                                'store_id' => 0
                ]
        ],
        'is_comparable' => '',
        'is_filterable' => null,
        'is_filterable_in_grid' => null,
        'is_filterable_in_search' => null,
        'is_html_allowed_on_front' => null,
        'is_required' => null,
        'is_searchable' => '',
        'is_unique' => '',
        'is_used_for_promo_rules' => '',
        'is_used_in_grid' => null,
        'is_user_defined' => null,
        'is_visible' => null,
        'is_visible_in_advanced_search' => '',
        'is_visible_in_grid' => null,
        'is_visible_on_front' => '',
        'is_wysiwyg_enabled' => null,
        'note' => '',
        'options' => [
                [
                                'is_default' => null,
                                'label' => '',
                                'sort_order' => 0,
                                'store_labels' => [
                                                                [
                                                                                                                                'label' => '',
                                                                                                                                'store_id' => 0
                                                                ]
                                ],
                                'value' => ''
                ]
        ],
        'position' => 0,
        'scope' => '',
        'source_model' => '',
        'used_for_sort_by' => null,
        'used_in_product_listing' => '',
        'validation_rules' => [
                [
                                'key' => '',
                                'value' => ''
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/attributes', [
  'body' => '{
  "attribute": {
    "apply_to": [],
    "attribute_code": "",
    "attribute_id": 0,
    "backend_model": "",
    "backend_type": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "default_frontend_label": "",
    "default_value": "",
    "entity_type_id": "",
    "extension_attributes": {},
    "frontend_class": "",
    "frontend_input": "",
    "frontend_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "is_comparable": "",
    "is_filterable": false,
    "is_filterable_in_grid": false,
    "is_filterable_in_search": false,
    "is_html_allowed_on_front": false,
    "is_required": false,
    "is_searchable": "",
    "is_unique": "",
    "is_used_for_promo_rules": "",
    "is_used_in_grid": false,
    "is_user_defined": false,
    "is_visible": false,
    "is_visible_in_advanced_search": "",
    "is_visible_in_grid": false,
    "is_visible_on_front": "",
    "is_wysiwyg_enabled": false,
    "note": "",
    "options": [
      {
        "is_default": false,
        "label": "",
        "sort_order": 0,
        "store_labels": [
          {
            "label": "",
            "store_id": 0
          }
        ],
        "value": ""
      }
    ],
    "position": 0,
    "scope": "",
    "source_model": "",
    "used_for_sort_by": false,
    "used_in_product_listing": "",
    "validation_rules": [
      {
        "key": "",
        "value": ""
      }
    ]
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attributes');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attribute' => [
    'apply_to' => [
        
    ],
    'attribute_code' => '',
    'attribute_id' => 0,
    'backend_model' => '',
    'backend_type' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'default_frontend_label' => '',
    'default_value' => '',
    'entity_type_id' => '',
    'extension_attributes' => [
        
    ],
    'frontend_class' => '',
    'frontend_input' => '',
    'frontend_labels' => [
        [
                'label' => '',
                'store_id' => 0
        ]
    ],
    'is_comparable' => '',
    'is_filterable' => null,
    'is_filterable_in_grid' => null,
    'is_filterable_in_search' => null,
    'is_html_allowed_on_front' => null,
    'is_required' => null,
    'is_searchable' => '',
    'is_unique' => '',
    'is_used_for_promo_rules' => '',
    'is_used_in_grid' => null,
    'is_user_defined' => null,
    'is_visible' => null,
    'is_visible_in_advanced_search' => '',
    'is_visible_in_grid' => null,
    'is_visible_on_front' => '',
    'is_wysiwyg_enabled' => null,
    'note' => '',
    'options' => [
        [
                'is_default' => null,
                'label' => '',
                'sort_order' => 0,
                'store_labels' => [
                                [
                                                                'label' => '',
                                                                'store_id' => 0
                                ]
                ],
                'value' => ''
        ]
    ],
    'position' => 0,
    'scope' => '',
    'source_model' => '',
    'used_for_sort_by' => null,
    'used_in_product_listing' => '',
    'validation_rules' => [
        [
                'key' => '',
                'value' => ''
        ]
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attribute' => [
    'apply_to' => [
        
    ],
    'attribute_code' => '',
    'attribute_id' => 0,
    'backend_model' => '',
    'backend_type' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'default_frontend_label' => '',
    'default_value' => '',
    'entity_type_id' => '',
    'extension_attributes' => [
        
    ],
    'frontend_class' => '',
    'frontend_input' => '',
    'frontend_labels' => [
        [
                'label' => '',
                'store_id' => 0
        ]
    ],
    'is_comparable' => '',
    'is_filterable' => null,
    'is_filterable_in_grid' => null,
    'is_filterable_in_search' => null,
    'is_html_allowed_on_front' => null,
    'is_required' => null,
    'is_searchable' => '',
    'is_unique' => '',
    'is_used_for_promo_rules' => '',
    'is_used_in_grid' => null,
    'is_user_defined' => null,
    'is_visible' => null,
    'is_visible_in_advanced_search' => '',
    'is_visible_in_grid' => null,
    'is_visible_on_front' => '',
    'is_wysiwyg_enabled' => null,
    'note' => '',
    'options' => [
        [
                'is_default' => null,
                'label' => '',
                'sort_order' => 0,
                'store_labels' => [
                                [
                                                                'label' => '',
                                                                'store_id' => 0
                                ]
                ],
                'value' => ''
        ]
    ],
    'position' => 0,
    'scope' => '',
    'source_model' => '',
    'used_for_sort_by' => null,
    'used_in_product_listing' => '',
    'validation_rules' => [
        [
                'key' => '',
                'value' => ''
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/attributes');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attributes' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attribute": {
    "apply_to": [],
    "attribute_code": "",
    "attribute_id": 0,
    "backend_model": "",
    "backend_type": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "default_frontend_label": "",
    "default_value": "",
    "entity_type_id": "",
    "extension_attributes": {},
    "frontend_class": "",
    "frontend_input": "",
    "frontend_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "is_comparable": "",
    "is_filterable": false,
    "is_filterable_in_grid": false,
    "is_filterable_in_search": false,
    "is_html_allowed_on_front": false,
    "is_required": false,
    "is_searchable": "",
    "is_unique": "",
    "is_used_for_promo_rules": "",
    "is_used_in_grid": false,
    "is_user_defined": false,
    "is_visible": false,
    "is_visible_in_advanced_search": "",
    "is_visible_in_grid": false,
    "is_visible_on_front": "",
    "is_wysiwyg_enabled": false,
    "note": "",
    "options": [
      {
        "is_default": false,
        "label": "",
        "sort_order": 0,
        "store_labels": [
          {
            "label": "",
            "store_id": 0
          }
        ],
        "value": ""
      }
    ],
    "position": 0,
    "scope": "",
    "source_model": "",
    "used_for_sort_by": false,
    "used_in_product_listing": "",
    "validation_rules": [
      {
        "key": "",
        "value": ""
      }
    ]
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attributes' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attribute": {
    "apply_to": [],
    "attribute_code": "",
    "attribute_id": 0,
    "backend_model": "",
    "backend_type": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "default_frontend_label": "",
    "default_value": "",
    "entity_type_id": "",
    "extension_attributes": {},
    "frontend_class": "",
    "frontend_input": "",
    "frontend_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "is_comparable": "",
    "is_filterable": false,
    "is_filterable_in_grid": false,
    "is_filterable_in_search": false,
    "is_html_allowed_on_front": false,
    "is_required": false,
    "is_searchable": "",
    "is_unique": "",
    "is_used_for_promo_rules": "",
    "is_used_in_grid": false,
    "is_user_defined": false,
    "is_visible": false,
    "is_visible_in_advanced_search": "",
    "is_visible_in_grid": false,
    "is_visible_on_front": "",
    "is_wysiwyg_enabled": false,
    "note": "",
    "options": [
      {
        "is_default": false,
        "label": "",
        "sort_order": 0,
        "store_labels": [
          {
            "label": "",
            "store_id": 0
          }
        ],
        "value": ""
      }
    ],
    "position": 0,
    "scope": "",
    "source_model": "",
    "used_for_sort_by": false,
    "used_in_product_listing": "",
    "validation_rules": [
      {
        "key": "",
        "value": ""
      }
    ]
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/attributes", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attributes"

payload = { "attribute": {
        "apply_to": [],
        "attribute_code": "",
        "attribute_id": 0,
        "backend_model": "",
        "backend_type": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "default_frontend_label": "",
        "default_value": "",
        "entity_type_id": "",
        "extension_attributes": {},
        "frontend_class": "",
        "frontend_input": "",
        "frontend_labels": [
            {
                "label": "",
                "store_id": 0
            }
        ],
        "is_comparable": "",
        "is_filterable": False,
        "is_filterable_in_grid": False,
        "is_filterable_in_search": False,
        "is_html_allowed_on_front": False,
        "is_required": False,
        "is_searchable": "",
        "is_unique": "",
        "is_used_for_promo_rules": "",
        "is_used_in_grid": False,
        "is_user_defined": False,
        "is_visible": False,
        "is_visible_in_advanced_search": "",
        "is_visible_in_grid": False,
        "is_visible_on_front": "",
        "is_wysiwyg_enabled": False,
        "note": "",
        "options": [
            {
                "is_default": False,
                "label": "",
                "sort_order": 0,
                "store_labels": [
                    {
                        "label": "",
                        "store_id": 0
                    }
                ],
                "value": ""
            }
        ],
        "position": 0,
        "scope": "",
        "source_model": "",
        "used_for_sort_by": False,
        "used_in_product_listing": "",
        "validation_rules": [
            {
                "key": "",
                "value": ""
            }
        ]
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attributes"

payload <- "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attributes")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/V1/products/attributes') do |req|
  req.body = "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\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}}/V1/products/attributes";

    let payload = json!({"attribute": json!({
            "apply_to": (),
            "attribute_code": "",
            "attribute_id": 0,
            "backend_model": "",
            "backend_type": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "default_frontend_label": "",
            "default_value": "",
            "entity_type_id": "",
            "extension_attributes": json!({}),
            "frontend_class": "",
            "frontend_input": "",
            "frontend_labels": (
                json!({
                    "label": "",
                    "store_id": 0
                })
            ),
            "is_comparable": "",
            "is_filterable": false,
            "is_filterable_in_grid": false,
            "is_filterable_in_search": false,
            "is_html_allowed_on_front": false,
            "is_required": false,
            "is_searchable": "",
            "is_unique": "",
            "is_used_for_promo_rules": "",
            "is_used_in_grid": false,
            "is_user_defined": false,
            "is_visible": false,
            "is_visible_in_advanced_search": "",
            "is_visible_in_grid": false,
            "is_visible_on_front": "",
            "is_wysiwyg_enabled": false,
            "note": "",
            "options": (
                json!({
                    "is_default": false,
                    "label": "",
                    "sort_order": 0,
                    "store_labels": (
                        json!({
                            "label": "",
                            "store_id": 0
                        })
                    ),
                    "value": ""
                })
            ),
            "position": 0,
            "scope": "",
            "source_model": "",
            "used_for_sort_by": false,
            "used_in_product_listing": "",
            "validation_rules": (
                json!({
                    "key": "",
                    "value": ""
                })
            )
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/attributes \
  --header 'content-type: application/json' \
  --data '{
  "attribute": {
    "apply_to": [],
    "attribute_code": "",
    "attribute_id": 0,
    "backend_model": "",
    "backend_type": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "default_frontend_label": "",
    "default_value": "",
    "entity_type_id": "",
    "extension_attributes": {},
    "frontend_class": "",
    "frontend_input": "",
    "frontend_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "is_comparable": "",
    "is_filterable": false,
    "is_filterable_in_grid": false,
    "is_filterable_in_search": false,
    "is_html_allowed_on_front": false,
    "is_required": false,
    "is_searchable": "",
    "is_unique": "",
    "is_used_for_promo_rules": "",
    "is_used_in_grid": false,
    "is_user_defined": false,
    "is_visible": false,
    "is_visible_in_advanced_search": "",
    "is_visible_in_grid": false,
    "is_visible_on_front": "",
    "is_wysiwyg_enabled": false,
    "note": "",
    "options": [
      {
        "is_default": false,
        "label": "",
        "sort_order": 0,
        "store_labels": [
          {
            "label": "",
            "store_id": 0
          }
        ],
        "value": ""
      }
    ],
    "position": 0,
    "scope": "",
    "source_model": "",
    "used_for_sort_by": false,
    "used_in_product_listing": "",
    "validation_rules": [
      {
        "key": "",
        "value": ""
      }
    ]
  }
}'
echo '{
  "attribute": {
    "apply_to": [],
    "attribute_code": "",
    "attribute_id": 0,
    "backend_model": "",
    "backend_type": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "default_frontend_label": "",
    "default_value": "",
    "entity_type_id": "",
    "extension_attributes": {},
    "frontend_class": "",
    "frontend_input": "",
    "frontend_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "is_comparable": "",
    "is_filterable": false,
    "is_filterable_in_grid": false,
    "is_filterable_in_search": false,
    "is_html_allowed_on_front": false,
    "is_required": false,
    "is_searchable": "",
    "is_unique": "",
    "is_used_for_promo_rules": "",
    "is_used_in_grid": false,
    "is_user_defined": false,
    "is_visible": false,
    "is_visible_in_advanced_search": "",
    "is_visible_in_grid": false,
    "is_visible_on_front": "",
    "is_wysiwyg_enabled": false,
    "note": "",
    "options": [
      {
        "is_default": false,
        "label": "",
        "sort_order": 0,
        "store_labels": [
          {
            "label": "",
            "store_id": 0
          }
        ],
        "value": ""
      }
    ],
    "position": 0,
    "scope": "",
    "source_model": "",
    "used_for_sort_by": false,
    "used_in_product_listing": "",
    "validation_rules": [
      {
        "key": "",
        "value": ""
      }
    ]
  }
}' |  \
  http POST {{baseUrl}}/V1/products/attributes \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "attribute": {\n    "apply_to": [],\n    "attribute_code": "",\n    "attribute_id": 0,\n    "backend_model": "",\n    "backend_type": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "default_frontend_label": "",\n    "default_value": "",\n    "entity_type_id": "",\n    "extension_attributes": {},\n    "frontend_class": "",\n    "frontend_input": "",\n    "frontend_labels": [\n      {\n        "label": "",\n        "store_id": 0\n      }\n    ],\n    "is_comparable": "",\n    "is_filterable": false,\n    "is_filterable_in_grid": false,\n    "is_filterable_in_search": false,\n    "is_html_allowed_on_front": false,\n    "is_required": false,\n    "is_searchable": "",\n    "is_unique": "",\n    "is_used_for_promo_rules": "",\n    "is_used_in_grid": false,\n    "is_user_defined": false,\n    "is_visible": false,\n    "is_visible_in_advanced_search": "",\n    "is_visible_in_grid": false,\n    "is_visible_on_front": "",\n    "is_wysiwyg_enabled": false,\n    "note": "",\n    "options": [\n      {\n        "is_default": false,\n        "label": "",\n        "sort_order": 0,\n        "store_labels": [\n          {\n            "label": "",\n            "store_id": 0\n          }\n        ],\n        "value": ""\n      }\n    ],\n    "position": 0,\n    "scope": "",\n    "source_model": "",\n    "used_for_sort_by": false,\n    "used_in_product_listing": "",\n    "validation_rules": [\n      {\n        "key": "",\n        "value": ""\n      }\n    ]\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/attributes
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["attribute": [
    "apply_to": [],
    "attribute_code": "",
    "attribute_id": 0,
    "backend_model": "",
    "backend_type": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "default_frontend_label": "",
    "default_value": "",
    "entity_type_id": "",
    "extension_attributes": [],
    "frontend_class": "",
    "frontend_input": "",
    "frontend_labels": [
      [
        "label": "",
        "store_id": 0
      ]
    ],
    "is_comparable": "",
    "is_filterable": false,
    "is_filterable_in_grid": false,
    "is_filterable_in_search": false,
    "is_html_allowed_on_front": false,
    "is_required": false,
    "is_searchable": "",
    "is_unique": "",
    "is_used_for_promo_rules": "",
    "is_used_in_grid": false,
    "is_user_defined": false,
    "is_visible": false,
    "is_visible_in_advanced_search": "",
    "is_visible_in_grid": false,
    "is_visible_on_front": "",
    "is_wysiwyg_enabled": false,
    "note": "",
    "options": [
      [
        "is_default": false,
        "label": "",
        "sort_order": 0,
        "store_labels": [
          [
            "label": "",
            "store_id": 0
          ]
        ],
        "value": ""
      ]
    ],
    "position": 0,
    "scope": "",
    "source_model": "",
    "used_for_sort_by": false,
    "used_in_product_listing": "",
    "validation_rules": [
      [
        "key": "",
        "value": ""
      ]
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attributes")! 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 products-attributes
{{baseUrl}}/V1/products/attributes
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attributes");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/attributes")
require "http/client"

url = "{{baseUrl}}/V1/products/attributes"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/attributes"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/attributes");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attributes"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/attributes HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/attributes")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attributes"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/attributes")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/attributes")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/attributes');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/attributes'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attributes';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/attributes',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attributes")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attributes',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/attributes'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/attributes');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/attributes'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attributes';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attributes"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/attributes" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attributes",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/attributes');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attributes');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/attributes');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attributes' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attributes' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/attributes")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attributes"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attributes"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attributes")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/attributes') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/attributes";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/attributes
http GET {{baseUrl}}/V1/products/attributes
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/attributes
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attributes")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET products-attributes-{attributeCode} (GET)
{{baseUrl}}/V1/products/attributes/:attributeCode
QUERY PARAMS

attributeCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attributes/:attributeCode");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/attributes/:attributeCode")
require "http/client"

url = "{{baseUrl}}/V1/products/attributes/:attributeCode"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/attributes/:attributeCode"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/attributes/:attributeCode");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attributes/:attributeCode"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/attributes/:attributeCode HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/attributes/:attributeCode")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attributes/:attributeCode"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/attributes/:attributeCode")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/attributes/:attributeCode")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/attributes/:attributeCode');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attributes/:attributeCode';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attributes/:attributeCode")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attributes/:attributeCode',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/attributes/:attributeCode');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attributes/:attributeCode';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attributes/:attributeCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/attributes/:attributeCode" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attributes/:attributeCode",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/attributes/:attributeCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attributes/:attributeCode');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/attributes/:attributeCode');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attributes/:attributeCode' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attributes/:attributeCode' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/attributes/:attributeCode")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attributes/:attributeCode"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attributes/:attributeCode"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attributes/:attributeCode")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/attributes/:attributeCode') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/attributes/:attributeCode";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/attributes/:attributeCode
http GET {{baseUrl}}/V1/products/attributes/:attributeCode
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/attributes/:attributeCode
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attributes/:attributeCode")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT products-attributes-{attributeCode} (PUT)
{{baseUrl}}/V1/products/attributes/:attributeCode
QUERY PARAMS

attributeCode
BODY json

{
  "attribute": {
    "apply_to": [],
    "attribute_code": "",
    "attribute_id": 0,
    "backend_model": "",
    "backend_type": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "default_frontend_label": "",
    "default_value": "",
    "entity_type_id": "",
    "extension_attributes": {},
    "frontend_class": "",
    "frontend_input": "",
    "frontend_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "is_comparable": "",
    "is_filterable": false,
    "is_filterable_in_grid": false,
    "is_filterable_in_search": false,
    "is_html_allowed_on_front": false,
    "is_required": false,
    "is_searchable": "",
    "is_unique": "",
    "is_used_for_promo_rules": "",
    "is_used_in_grid": false,
    "is_user_defined": false,
    "is_visible": false,
    "is_visible_in_advanced_search": "",
    "is_visible_in_grid": false,
    "is_visible_on_front": "",
    "is_wysiwyg_enabled": false,
    "note": "",
    "options": [
      {
        "is_default": false,
        "label": "",
        "sort_order": 0,
        "store_labels": [
          {
            "label": "",
            "store_id": 0
          }
        ],
        "value": ""
      }
    ],
    "position": 0,
    "scope": "",
    "source_model": "",
    "used_for_sort_by": false,
    "used_in_product_listing": "",
    "validation_rules": [
      {
        "key": "",
        "value": ""
      }
    ]
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attributes/:attributeCode");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/products/attributes/:attributeCode" {:content-type :json
                                                                                 :form-params {:attribute {:apply_to []
                                                                                                           :attribute_code ""
                                                                                                           :attribute_id 0
                                                                                                           :backend_model ""
                                                                                                           :backend_type ""
                                                                                                           :custom_attributes [{:attribute_code ""
                                                                                                                                :value ""}]
                                                                                                           :default_frontend_label ""
                                                                                                           :default_value ""
                                                                                                           :entity_type_id ""
                                                                                                           :extension_attributes {}
                                                                                                           :frontend_class ""
                                                                                                           :frontend_input ""
                                                                                                           :frontend_labels [{:label ""
                                                                                                                              :store_id 0}]
                                                                                                           :is_comparable ""
                                                                                                           :is_filterable false
                                                                                                           :is_filterable_in_grid false
                                                                                                           :is_filterable_in_search false
                                                                                                           :is_html_allowed_on_front false
                                                                                                           :is_required false
                                                                                                           :is_searchable ""
                                                                                                           :is_unique ""
                                                                                                           :is_used_for_promo_rules ""
                                                                                                           :is_used_in_grid false
                                                                                                           :is_user_defined false
                                                                                                           :is_visible false
                                                                                                           :is_visible_in_advanced_search ""
                                                                                                           :is_visible_in_grid false
                                                                                                           :is_visible_on_front ""
                                                                                                           :is_wysiwyg_enabled false
                                                                                                           :note ""
                                                                                                           :options [{:is_default false
                                                                                                                      :label ""
                                                                                                                      :sort_order 0
                                                                                                                      :store_labels [{:label ""
                                                                                                                                      :store_id 0}]
                                                                                                                      :value ""}]
                                                                                                           :position 0
                                                                                                           :scope ""
                                                                                                           :source_model ""
                                                                                                           :used_for_sort_by false
                                                                                                           :used_in_product_listing ""
                                                                                                           :validation_rules [{:key ""
                                                                                                                               :value ""}]}}})
require "http/client"

url = "{{baseUrl}}/V1/products/attributes/:attributeCode"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/V1/products/attributes/:attributeCode"),
    Content = new StringContent("{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/attributes/:attributeCode");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attributes/:attributeCode"

	payload := strings.NewReader("{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/products/attributes/:attributeCode HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1474

{
  "attribute": {
    "apply_to": [],
    "attribute_code": "",
    "attribute_id": 0,
    "backend_model": "",
    "backend_type": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "default_frontend_label": "",
    "default_value": "",
    "entity_type_id": "",
    "extension_attributes": {},
    "frontend_class": "",
    "frontend_input": "",
    "frontend_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "is_comparable": "",
    "is_filterable": false,
    "is_filterable_in_grid": false,
    "is_filterable_in_search": false,
    "is_html_allowed_on_front": false,
    "is_required": false,
    "is_searchable": "",
    "is_unique": "",
    "is_used_for_promo_rules": "",
    "is_used_in_grid": false,
    "is_user_defined": false,
    "is_visible": false,
    "is_visible_in_advanced_search": "",
    "is_visible_in_grid": false,
    "is_visible_on_front": "",
    "is_wysiwyg_enabled": false,
    "note": "",
    "options": [
      {
        "is_default": false,
        "label": "",
        "sort_order": 0,
        "store_labels": [
          {
            "label": "",
            "store_id": 0
          }
        ],
        "value": ""
      }
    ],
    "position": 0,
    "scope": "",
    "source_model": "",
    "used_for_sort_by": false,
    "used_in_product_listing": "",
    "validation_rules": [
      {
        "key": "",
        "value": ""
      }
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/products/attributes/:attributeCode")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attributes/:attributeCode"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/attributes/:attributeCode")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/products/attributes/:attributeCode")
  .header("content-type", "application/json")
  .body("{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}")
  .asString();
const data = JSON.stringify({
  attribute: {
    apply_to: [],
    attribute_code: '',
    attribute_id: 0,
    backend_model: '',
    backend_type: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    default_frontend_label: '',
    default_value: '',
    entity_type_id: '',
    extension_attributes: {},
    frontend_class: '',
    frontend_input: '',
    frontend_labels: [
      {
        label: '',
        store_id: 0
      }
    ],
    is_comparable: '',
    is_filterable: false,
    is_filterable_in_grid: false,
    is_filterable_in_search: false,
    is_html_allowed_on_front: false,
    is_required: false,
    is_searchable: '',
    is_unique: '',
    is_used_for_promo_rules: '',
    is_used_in_grid: false,
    is_user_defined: false,
    is_visible: false,
    is_visible_in_advanced_search: '',
    is_visible_in_grid: false,
    is_visible_on_front: '',
    is_wysiwyg_enabled: false,
    note: '',
    options: [
      {
        is_default: false,
        label: '',
        sort_order: 0,
        store_labels: [
          {
            label: '',
            store_id: 0
          }
        ],
        value: ''
      }
    ],
    position: 0,
    scope: '',
    source_model: '',
    used_for_sort_by: false,
    used_in_product_listing: '',
    validation_rules: [
      {
        key: '',
        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}}/V1/products/attributes/:attributeCode');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode',
  headers: {'content-type': 'application/json'},
  data: {
    attribute: {
      apply_to: [],
      attribute_code: '',
      attribute_id: 0,
      backend_model: '',
      backend_type: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      default_frontend_label: '',
      default_value: '',
      entity_type_id: '',
      extension_attributes: {},
      frontend_class: '',
      frontend_input: '',
      frontend_labels: [{label: '', store_id: 0}],
      is_comparable: '',
      is_filterable: false,
      is_filterable_in_grid: false,
      is_filterable_in_search: false,
      is_html_allowed_on_front: false,
      is_required: false,
      is_searchable: '',
      is_unique: '',
      is_used_for_promo_rules: '',
      is_used_in_grid: false,
      is_user_defined: false,
      is_visible: false,
      is_visible_in_advanced_search: '',
      is_visible_in_grid: false,
      is_visible_on_front: '',
      is_wysiwyg_enabled: false,
      note: '',
      options: [
        {
          is_default: false,
          label: '',
          sort_order: 0,
          store_labels: [{label: '', store_id: 0}],
          value: ''
        }
      ],
      position: 0,
      scope: '',
      source_model: '',
      used_for_sort_by: false,
      used_in_product_listing: '',
      validation_rules: [{key: '', value: ''}]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attributes/:attributeCode';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"attribute":{"apply_to":[],"attribute_code":"","attribute_id":0,"backend_model":"","backend_type":"","custom_attributes":[{"attribute_code":"","value":""}],"default_frontend_label":"","default_value":"","entity_type_id":"","extension_attributes":{},"frontend_class":"","frontend_input":"","frontend_labels":[{"label":"","store_id":0}],"is_comparable":"","is_filterable":false,"is_filterable_in_grid":false,"is_filterable_in_search":false,"is_html_allowed_on_front":false,"is_required":false,"is_searchable":"","is_unique":"","is_used_for_promo_rules":"","is_used_in_grid":false,"is_user_defined":false,"is_visible":false,"is_visible_in_advanced_search":"","is_visible_in_grid":false,"is_visible_on_front":"","is_wysiwyg_enabled":false,"note":"","options":[{"is_default":false,"label":"","sort_order":0,"store_labels":[{"label":"","store_id":0}],"value":""}],"position":0,"scope":"","source_model":"","used_for_sort_by":false,"used_in_product_listing":"","validation_rules":[{"key":"","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}}/V1/products/attributes/:attributeCode',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attribute": {\n    "apply_to": [],\n    "attribute_code": "",\n    "attribute_id": 0,\n    "backend_model": "",\n    "backend_type": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "default_frontend_label": "",\n    "default_value": "",\n    "entity_type_id": "",\n    "extension_attributes": {},\n    "frontend_class": "",\n    "frontend_input": "",\n    "frontend_labels": [\n      {\n        "label": "",\n        "store_id": 0\n      }\n    ],\n    "is_comparable": "",\n    "is_filterable": false,\n    "is_filterable_in_grid": false,\n    "is_filterable_in_search": false,\n    "is_html_allowed_on_front": false,\n    "is_required": false,\n    "is_searchable": "",\n    "is_unique": "",\n    "is_used_for_promo_rules": "",\n    "is_used_in_grid": false,\n    "is_user_defined": false,\n    "is_visible": false,\n    "is_visible_in_advanced_search": "",\n    "is_visible_in_grid": false,\n    "is_visible_on_front": "",\n    "is_wysiwyg_enabled": false,\n    "note": "",\n    "options": [\n      {\n        "is_default": false,\n        "label": "",\n        "sort_order": 0,\n        "store_labels": [\n          {\n            "label": "",\n            "store_id": 0\n          }\n        ],\n        "value": ""\n      }\n    ],\n    "position": 0,\n    "scope": "",\n    "source_model": "",\n    "used_for_sort_by": false,\n    "used_in_product_listing": "",\n    "validation_rules": [\n      {\n        "key": "",\n        "value": ""\n      }\n    ]\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attributes/:attributeCode")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attributes/:attributeCode',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  attribute: {
    apply_to: [],
    attribute_code: '',
    attribute_id: 0,
    backend_model: '',
    backend_type: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    default_frontend_label: '',
    default_value: '',
    entity_type_id: '',
    extension_attributes: {},
    frontend_class: '',
    frontend_input: '',
    frontend_labels: [{label: '', store_id: 0}],
    is_comparable: '',
    is_filterable: false,
    is_filterable_in_grid: false,
    is_filterable_in_search: false,
    is_html_allowed_on_front: false,
    is_required: false,
    is_searchable: '',
    is_unique: '',
    is_used_for_promo_rules: '',
    is_used_in_grid: false,
    is_user_defined: false,
    is_visible: false,
    is_visible_in_advanced_search: '',
    is_visible_in_grid: false,
    is_visible_on_front: '',
    is_wysiwyg_enabled: false,
    note: '',
    options: [
      {
        is_default: false,
        label: '',
        sort_order: 0,
        store_labels: [{label: '', store_id: 0}],
        value: ''
      }
    ],
    position: 0,
    scope: '',
    source_model: '',
    used_for_sort_by: false,
    used_in_product_listing: '',
    validation_rules: [{key: '', value: ''}]
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode',
  headers: {'content-type': 'application/json'},
  body: {
    attribute: {
      apply_to: [],
      attribute_code: '',
      attribute_id: 0,
      backend_model: '',
      backend_type: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      default_frontend_label: '',
      default_value: '',
      entity_type_id: '',
      extension_attributes: {},
      frontend_class: '',
      frontend_input: '',
      frontend_labels: [{label: '', store_id: 0}],
      is_comparable: '',
      is_filterable: false,
      is_filterable_in_grid: false,
      is_filterable_in_search: false,
      is_html_allowed_on_front: false,
      is_required: false,
      is_searchable: '',
      is_unique: '',
      is_used_for_promo_rules: '',
      is_used_in_grid: false,
      is_user_defined: false,
      is_visible: false,
      is_visible_in_advanced_search: '',
      is_visible_in_grid: false,
      is_visible_on_front: '',
      is_wysiwyg_enabled: false,
      note: '',
      options: [
        {
          is_default: false,
          label: '',
          sort_order: 0,
          store_labels: [{label: '', store_id: 0}],
          value: ''
        }
      ],
      position: 0,
      scope: '',
      source_model: '',
      used_for_sort_by: false,
      used_in_product_listing: '',
      validation_rules: [{key: '', 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}}/V1/products/attributes/:attributeCode');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attribute: {
    apply_to: [],
    attribute_code: '',
    attribute_id: 0,
    backend_model: '',
    backend_type: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    default_frontend_label: '',
    default_value: '',
    entity_type_id: '',
    extension_attributes: {},
    frontend_class: '',
    frontend_input: '',
    frontend_labels: [
      {
        label: '',
        store_id: 0
      }
    ],
    is_comparable: '',
    is_filterable: false,
    is_filterable_in_grid: false,
    is_filterable_in_search: false,
    is_html_allowed_on_front: false,
    is_required: false,
    is_searchable: '',
    is_unique: '',
    is_used_for_promo_rules: '',
    is_used_in_grid: false,
    is_user_defined: false,
    is_visible: false,
    is_visible_in_advanced_search: '',
    is_visible_in_grid: false,
    is_visible_on_front: '',
    is_wysiwyg_enabled: false,
    note: '',
    options: [
      {
        is_default: false,
        label: '',
        sort_order: 0,
        store_labels: [
          {
            label: '',
            store_id: 0
          }
        ],
        value: ''
      }
    ],
    position: 0,
    scope: '',
    source_model: '',
    used_for_sort_by: false,
    used_in_product_listing: '',
    validation_rules: [
      {
        key: '',
        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}}/V1/products/attributes/:attributeCode',
  headers: {'content-type': 'application/json'},
  data: {
    attribute: {
      apply_to: [],
      attribute_code: '',
      attribute_id: 0,
      backend_model: '',
      backend_type: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      default_frontend_label: '',
      default_value: '',
      entity_type_id: '',
      extension_attributes: {},
      frontend_class: '',
      frontend_input: '',
      frontend_labels: [{label: '', store_id: 0}],
      is_comparable: '',
      is_filterable: false,
      is_filterable_in_grid: false,
      is_filterable_in_search: false,
      is_html_allowed_on_front: false,
      is_required: false,
      is_searchable: '',
      is_unique: '',
      is_used_for_promo_rules: '',
      is_used_in_grid: false,
      is_user_defined: false,
      is_visible: false,
      is_visible_in_advanced_search: '',
      is_visible_in_grid: false,
      is_visible_on_front: '',
      is_wysiwyg_enabled: false,
      note: '',
      options: [
        {
          is_default: false,
          label: '',
          sort_order: 0,
          store_labels: [{label: '', store_id: 0}],
          value: ''
        }
      ],
      position: 0,
      scope: '',
      source_model: '',
      used_for_sort_by: false,
      used_in_product_listing: '',
      validation_rules: [{key: '', value: ''}]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attributes/:attributeCode';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"attribute":{"apply_to":[],"attribute_code":"","attribute_id":0,"backend_model":"","backend_type":"","custom_attributes":[{"attribute_code":"","value":""}],"default_frontend_label":"","default_value":"","entity_type_id":"","extension_attributes":{},"frontend_class":"","frontend_input":"","frontend_labels":[{"label":"","store_id":0}],"is_comparable":"","is_filterable":false,"is_filterable_in_grid":false,"is_filterable_in_search":false,"is_html_allowed_on_front":false,"is_required":false,"is_searchable":"","is_unique":"","is_used_for_promo_rules":"","is_used_in_grid":false,"is_user_defined":false,"is_visible":false,"is_visible_in_advanced_search":"","is_visible_in_grid":false,"is_visible_on_front":"","is_wysiwyg_enabled":false,"note":"","options":[{"is_default":false,"label":"","sort_order":0,"store_labels":[{"label":"","store_id":0}],"value":""}],"position":0,"scope":"","source_model":"","used_for_sort_by":false,"used_in_product_listing":"","validation_rules":[{"key":"","value":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attribute": @{ @"apply_to": @[  ], @"attribute_code": @"", @"attribute_id": @0, @"backend_model": @"", @"backend_type": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"default_frontend_label": @"", @"default_value": @"", @"entity_type_id": @"", @"extension_attributes": @{  }, @"frontend_class": @"", @"frontend_input": @"", @"frontend_labels": @[ @{ @"label": @"", @"store_id": @0 } ], @"is_comparable": @"", @"is_filterable": @NO, @"is_filterable_in_grid": @NO, @"is_filterable_in_search": @NO, @"is_html_allowed_on_front": @NO, @"is_required": @NO, @"is_searchable": @"", @"is_unique": @"", @"is_used_for_promo_rules": @"", @"is_used_in_grid": @NO, @"is_user_defined": @NO, @"is_visible": @NO, @"is_visible_in_advanced_search": @"", @"is_visible_in_grid": @NO, @"is_visible_on_front": @"", @"is_wysiwyg_enabled": @NO, @"note": @"", @"options": @[ @{ @"is_default": @NO, @"label": @"", @"sort_order": @0, @"store_labels": @[ @{ @"label": @"", @"store_id": @0 } ], @"value": @"" } ], @"position": @0, @"scope": @"", @"source_model": @"", @"used_for_sort_by": @NO, @"used_in_product_listing": @"", @"validation_rules": @[ @{ @"key": @"", @"value": @"" } ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attributes/:attributeCode"]
                                                       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}}/V1/products/attributes/:attributeCode" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attributes/:attributeCode",
  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([
    'attribute' => [
        'apply_to' => [
                
        ],
        'attribute_code' => '',
        'attribute_id' => 0,
        'backend_model' => '',
        'backend_type' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'default_frontend_label' => '',
        'default_value' => '',
        'entity_type_id' => '',
        'extension_attributes' => [
                
        ],
        'frontend_class' => '',
        'frontend_input' => '',
        'frontend_labels' => [
                [
                                'label' => '',
                                'store_id' => 0
                ]
        ],
        'is_comparable' => '',
        'is_filterable' => null,
        'is_filterable_in_grid' => null,
        'is_filterable_in_search' => null,
        'is_html_allowed_on_front' => null,
        'is_required' => null,
        'is_searchable' => '',
        'is_unique' => '',
        'is_used_for_promo_rules' => '',
        'is_used_in_grid' => null,
        'is_user_defined' => null,
        'is_visible' => null,
        'is_visible_in_advanced_search' => '',
        'is_visible_in_grid' => null,
        'is_visible_on_front' => '',
        'is_wysiwyg_enabled' => null,
        'note' => '',
        'options' => [
                [
                                'is_default' => null,
                                'label' => '',
                                'sort_order' => 0,
                                'store_labels' => [
                                                                [
                                                                                                                                'label' => '',
                                                                                                                                'store_id' => 0
                                                                ]
                                ],
                                'value' => ''
                ]
        ],
        'position' => 0,
        'scope' => '',
        'source_model' => '',
        'used_for_sort_by' => null,
        'used_in_product_listing' => '',
        'validation_rules' => [
                [
                                'key' => '',
                                'value' => ''
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/products/attributes/:attributeCode', [
  'body' => '{
  "attribute": {
    "apply_to": [],
    "attribute_code": "",
    "attribute_id": 0,
    "backend_model": "",
    "backend_type": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "default_frontend_label": "",
    "default_value": "",
    "entity_type_id": "",
    "extension_attributes": {},
    "frontend_class": "",
    "frontend_input": "",
    "frontend_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "is_comparable": "",
    "is_filterable": false,
    "is_filterable_in_grid": false,
    "is_filterable_in_search": false,
    "is_html_allowed_on_front": false,
    "is_required": false,
    "is_searchable": "",
    "is_unique": "",
    "is_used_for_promo_rules": "",
    "is_used_in_grid": false,
    "is_user_defined": false,
    "is_visible": false,
    "is_visible_in_advanced_search": "",
    "is_visible_in_grid": false,
    "is_visible_on_front": "",
    "is_wysiwyg_enabled": false,
    "note": "",
    "options": [
      {
        "is_default": false,
        "label": "",
        "sort_order": 0,
        "store_labels": [
          {
            "label": "",
            "store_id": 0
          }
        ],
        "value": ""
      }
    ],
    "position": 0,
    "scope": "",
    "source_model": "",
    "used_for_sort_by": false,
    "used_in_product_listing": "",
    "validation_rules": [
      {
        "key": "",
        "value": ""
      }
    ]
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attributes/:attributeCode');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attribute' => [
    'apply_to' => [
        
    ],
    'attribute_code' => '',
    'attribute_id' => 0,
    'backend_model' => '',
    'backend_type' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'default_frontend_label' => '',
    'default_value' => '',
    'entity_type_id' => '',
    'extension_attributes' => [
        
    ],
    'frontend_class' => '',
    'frontend_input' => '',
    'frontend_labels' => [
        [
                'label' => '',
                'store_id' => 0
        ]
    ],
    'is_comparable' => '',
    'is_filterable' => null,
    'is_filterable_in_grid' => null,
    'is_filterable_in_search' => null,
    'is_html_allowed_on_front' => null,
    'is_required' => null,
    'is_searchable' => '',
    'is_unique' => '',
    'is_used_for_promo_rules' => '',
    'is_used_in_grid' => null,
    'is_user_defined' => null,
    'is_visible' => null,
    'is_visible_in_advanced_search' => '',
    'is_visible_in_grid' => null,
    'is_visible_on_front' => '',
    'is_wysiwyg_enabled' => null,
    'note' => '',
    'options' => [
        [
                'is_default' => null,
                'label' => '',
                'sort_order' => 0,
                'store_labels' => [
                                [
                                                                'label' => '',
                                                                'store_id' => 0
                                ]
                ],
                'value' => ''
        ]
    ],
    'position' => 0,
    'scope' => '',
    'source_model' => '',
    'used_for_sort_by' => null,
    'used_in_product_listing' => '',
    'validation_rules' => [
        [
                'key' => '',
                'value' => ''
        ]
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attribute' => [
    'apply_to' => [
        
    ],
    'attribute_code' => '',
    'attribute_id' => 0,
    'backend_model' => '',
    'backend_type' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'default_frontend_label' => '',
    'default_value' => '',
    'entity_type_id' => '',
    'extension_attributes' => [
        
    ],
    'frontend_class' => '',
    'frontend_input' => '',
    'frontend_labels' => [
        [
                'label' => '',
                'store_id' => 0
        ]
    ],
    'is_comparable' => '',
    'is_filterable' => null,
    'is_filterable_in_grid' => null,
    'is_filterable_in_search' => null,
    'is_html_allowed_on_front' => null,
    'is_required' => null,
    'is_searchable' => '',
    'is_unique' => '',
    'is_used_for_promo_rules' => '',
    'is_used_in_grid' => null,
    'is_user_defined' => null,
    'is_visible' => null,
    'is_visible_in_advanced_search' => '',
    'is_visible_in_grid' => null,
    'is_visible_on_front' => '',
    'is_wysiwyg_enabled' => null,
    'note' => '',
    'options' => [
        [
                'is_default' => null,
                'label' => '',
                'sort_order' => 0,
                'store_labels' => [
                                [
                                                                'label' => '',
                                                                'store_id' => 0
                                ]
                ],
                'value' => ''
        ]
    ],
    'position' => 0,
    'scope' => '',
    'source_model' => '',
    'used_for_sort_by' => null,
    'used_in_product_listing' => '',
    'validation_rules' => [
        [
                'key' => '',
                'value' => ''
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/attributes/:attributeCode');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attributes/:attributeCode' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attribute": {
    "apply_to": [],
    "attribute_code": "",
    "attribute_id": 0,
    "backend_model": "",
    "backend_type": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "default_frontend_label": "",
    "default_value": "",
    "entity_type_id": "",
    "extension_attributes": {},
    "frontend_class": "",
    "frontend_input": "",
    "frontend_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "is_comparable": "",
    "is_filterable": false,
    "is_filterable_in_grid": false,
    "is_filterable_in_search": false,
    "is_html_allowed_on_front": false,
    "is_required": false,
    "is_searchable": "",
    "is_unique": "",
    "is_used_for_promo_rules": "",
    "is_used_in_grid": false,
    "is_user_defined": false,
    "is_visible": false,
    "is_visible_in_advanced_search": "",
    "is_visible_in_grid": false,
    "is_visible_on_front": "",
    "is_wysiwyg_enabled": false,
    "note": "",
    "options": [
      {
        "is_default": false,
        "label": "",
        "sort_order": 0,
        "store_labels": [
          {
            "label": "",
            "store_id": 0
          }
        ],
        "value": ""
      }
    ],
    "position": 0,
    "scope": "",
    "source_model": "",
    "used_for_sort_by": false,
    "used_in_product_listing": "",
    "validation_rules": [
      {
        "key": "",
        "value": ""
      }
    ]
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attributes/:attributeCode' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attribute": {
    "apply_to": [],
    "attribute_code": "",
    "attribute_id": 0,
    "backend_model": "",
    "backend_type": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "default_frontend_label": "",
    "default_value": "",
    "entity_type_id": "",
    "extension_attributes": {},
    "frontend_class": "",
    "frontend_input": "",
    "frontend_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "is_comparable": "",
    "is_filterable": false,
    "is_filterable_in_grid": false,
    "is_filterable_in_search": false,
    "is_html_allowed_on_front": false,
    "is_required": false,
    "is_searchable": "",
    "is_unique": "",
    "is_used_for_promo_rules": "",
    "is_used_in_grid": false,
    "is_user_defined": false,
    "is_visible": false,
    "is_visible_in_advanced_search": "",
    "is_visible_in_grid": false,
    "is_visible_on_front": "",
    "is_wysiwyg_enabled": false,
    "note": "",
    "options": [
      {
        "is_default": false,
        "label": "",
        "sort_order": 0,
        "store_labels": [
          {
            "label": "",
            "store_id": 0
          }
        ],
        "value": ""
      }
    ],
    "position": 0,
    "scope": "",
    "source_model": "",
    "used_for_sort_by": false,
    "used_in_product_listing": "",
    "validation_rules": [
      {
        "key": "",
        "value": ""
      }
    ]
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/products/attributes/:attributeCode", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attributes/:attributeCode"

payload = { "attribute": {
        "apply_to": [],
        "attribute_code": "",
        "attribute_id": 0,
        "backend_model": "",
        "backend_type": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "default_frontend_label": "",
        "default_value": "",
        "entity_type_id": "",
        "extension_attributes": {},
        "frontend_class": "",
        "frontend_input": "",
        "frontend_labels": [
            {
                "label": "",
                "store_id": 0
            }
        ],
        "is_comparable": "",
        "is_filterable": False,
        "is_filterable_in_grid": False,
        "is_filterable_in_search": False,
        "is_html_allowed_on_front": False,
        "is_required": False,
        "is_searchable": "",
        "is_unique": "",
        "is_used_for_promo_rules": "",
        "is_used_in_grid": False,
        "is_user_defined": False,
        "is_visible": False,
        "is_visible_in_advanced_search": "",
        "is_visible_in_grid": False,
        "is_visible_on_front": "",
        "is_wysiwyg_enabled": False,
        "note": "",
        "options": [
            {
                "is_default": False,
                "label": "",
                "sort_order": 0,
                "store_labels": [
                    {
                        "label": "",
                        "store_id": 0
                    }
                ],
                "value": ""
            }
        ],
        "position": 0,
        "scope": "",
        "source_model": "",
        "used_for_sort_by": False,
        "used_in_product_listing": "",
        "validation_rules": [
            {
                "key": "",
                "value": ""
            }
        ]
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attributes/:attributeCode"

payload <- "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attributes/:attributeCode")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/V1/products/attributes/:attributeCode') do |req|
  req.body = "{\n  \"attribute\": {\n    \"apply_to\": [],\n    \"attribute_code\": \"\",\n    \"attribute_id\": 0,\n    \"backend_model\": \"\",\n    \"backend_type\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"default_frontend_label\": \"\",\n    \"default_value\": \"\",\n    \"entity_type_id\": \"\",\n    \"extension_attributes\": {},\n    \"frontend_class\": \"\",\n    \"frontend_input\": \"\",\n    \"frontend_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"is_comparable\": \"\",\n    \"is_filterable\": false,\n    \"is_filterable_in_grid\": false,\n    \"is_filterable_in_search\": false,\n    \"is_html_allowed_on_front\": false,\n    \"is_required\": false,\n    \"is_searchable\": \"\",\n    \"is_unique\": \"\",\n    \"is_used_for_promo_rules\": \"\",\n    \"is_used_in_grid\": false,\n    \"is_user_defined\": false,\n    \"is_visible\": false,\n    \"is_visible_in_advanced_search\": \"\",\n    \"is_visible_in_grid\": false,\n    \"is_visible_on_front\": \"\",\n    \"is_wysiwyg_enabled\": false,\n    \"note\": \"\",\n    \"options\": [\n      {\n        \"is_default\": false,\n        \"label\": \"\",\n        \"sort_order\": 0,\n        \"store_labels\": [\n          {\n            \"label\": \"\",\n            \"store_id\": 0\n          }\n        ],\n        \"value\": \"\"\n      }\n    ],\n    \"position\": 0,\n    \"scope\": \"\",\n    \"source_model\": \"\",\n    \"used_for_sort_by\": false,\n    \"used_in_product_listing\": \"\",\n    \"validation_rules\": [\n      {\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  }\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/attributes/:attributeCode";

    let payload = json!({"attribute": json!({
            "apply_to": (),
            "attribute_code": "",
            "attribute_id": 0,
            "backend_model": "",
            "backend_type": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "default_frontend_label": "",
            "default_value": "",
            "entity_type_id": "",
            "extension_attributes": json!({}),
            "frontend_class": "",
            "frontend_input": "",
            "frontend_labels": (
                json!({
                    "label": "",
                    "store_id": 0
                })
            ),
            "is_comparable": "",
            "is_filterable": false,
            "is_filterable_in_grid": false,
            "is_filterable_in_search": false,
            "is_html_allowed_on_front": false,
            "is_required": false,
            "is_searchable": "",
            "is_unique": "",
            "is_used_for_promo_rules": "",
            "is_used_in_grid": false,
            "is_user_defined": false,
            "is_visible": false,
            "is_visible_in_advanced_search": "",
            "is_visible_in_grid": false,
            "is_visible_on_front": "",
            "is_wysiwyg_enabled": false,
            "note": "",
            "options": (
                json!({
                    "is_default": false,
                    "label": "",
                    "sort_order": 0,
                    "store_labels": (
                        json!({
                            "label": "",
                            "store_id": 0
                        })
                    ),
                    "value": ""
                })
            ),
            "position": 0,
            "scope": "",
            "source_model": "",
            "used_for_sort_by": false,
            "used_in_product_listing": "",
            "validation_rules": (
                json!({
                    "key": "",
                    "value": ""
                })
            )
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/products/attributes/:attributeCode \
  --header 'content-type: application/json' \
  --data '{
  "attribute": {
    "apply_to": [],
    "attribute_code": "",
    "attribute_id": 0,
    "backend_model": "",
    "backend_type": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "default_frontend_label": "",
    "default_value": "",
    "entity_type_id": "",
    "extension_attributes": {},
    "frontend_class": "",
    "frontend_input": "",
    "frontend_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "is_comparable": "",
    "is_filterable": false,
    "is_filterable_in_grid": false,
    "is_filterable_in_search": false,
    "is_html_allowed_on_front": false,
    "is_required": false,
    "is_searchable": "",
    "is_unique": "",
    "is_used_for_promo_rules": "",
    "is_used_in_grid": false,
    "is_user_defined": false,
    "is_visible": false,
    "is_visible_in_advanced_search": "",
    "is_visible_in_grid": false,
    "is_visible_on_front": "",
    "is_wysiwyg_enabled": false,
    "note": "",
    "options": [
      {
        "is_default": false,
        "label": "",
        "sort_order": 0,
        "store_labels": [
          {
            "label": "",
            "store_id": 0
          }
        ],
        "value": ""
      }
    ],
    "position": 0,
    "scope": "",
    "source_model": "",
    "used_for_sort_by": false,
    "used_in_product_listing": "",
    "validation_rules": [
      {
        "key": "",
        "value": ""
      }
    ]
  }
}'
echo '{
  "attribute": {
    "apply_to": [],
    "attribute_code": "",
    "attribute_id": 0,
    "backend_model": "",
    "backend_type": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "default_frontend_label": "",
    "default_value": "",
    "entity_type_id": "",
    "extension_attributes": {},
    "frontend_class": "",
    "frontend_input": "",
    "frontend_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "is_comparable": "",
    "is_filterable": false,
    "is_filterable_in_grid": false,
    "is_filterable_in_search": false,
    "is_html_allowed_on_front": false,
    "is_required": false,
    "is_searchable": "",
    "is_unique": "",
    "is_used_for_promo_rules": "",
    "is_used_in_grid": false,
    "is_user_defined": false,
    "is_visible": false,
    "is_visible_in_advanced_search": "",
    "is_visible_in_grid": false,
    "is_visible_on_front": "",
    "is_wysiwyg_enabled": false,
    "note": "",
    "options": [
      {
        "is_default": false,
        "label": "",
        "sort_order": 0,
        "store_labels": [
          {
            "label": "",
            "store_id": 0
          }
        ],
        "value": ""
      }
    ],
    "position": 0,
    "scope": "",
    "source_model": "",
    "used_for_sort_by": false,
    "used_in_product_listing": "",
    "validation_rules": [
      {
        "key": "",
        "value": ""
      }
    ]
  }
}' |  \
  http PUT {{baseUrl}}/V1/products/attributes/:attributeCode \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "attribute": {\n    "apply_to": [],\n    "attribute_code": "",\n    "attribute_id": 0,\n    "backend_model": "",\n    "backend_type": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "default_frontend_label": "",\n    "default_value": "",\n    "entity_type_id": "",\n    "extension_attributes": {},\n    "frontend_class": "",\n    "frontend_input": "",\n    "frontend_labels": [\n      {\n        "label": "",\n        "store_id": 0\n      }\n    ],\n    "is_comparable": "",\n    "is_filterable": false,\n    "is_filterable_in_grid": false,\n    "is_filterable_in_search": false,\n    "is_html_allowed_on_front": false,\n    "is_required": false,\n    "is_searchable": "",\n    "is_unique": "",\n    "is_used_for_promo_rules": "",\n    "is_used_in_grid": false,\n    "is_user_defined": false,\n    "is_visible": false,\n    "is_visible_in_advanced_search": "",\n    "is_visible_in_grid": false,\n    "is_visible_on_front": "",\n    "is_wysiwyg_enabled": false,\n    "note": "",\n    "options": [\n      {\n        "is_default": false,\n        "label": "",\n        "sort_order": 0,\n        "store_labels": [\n          {\n            "label": "",\n            "store_id": 0\n          }\n        ],\n        "value": ""\n      }\n    ],\n    "position": 0,\n    "scope": "",\n    "source_model": "",\n    "used_for_sort_by": false,\n    "used_in_product_listing": "",\n    "validation_rules": [\n      {\n        "key": "",\n        "value": ""\n      }\n    ]\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/attributes/:attributeCode
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["attribute": [
    "apply_to": [],
    "attribute_code": "",
    "attribute_id": 0,
    "backend_model": "",
    "backend_type": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "default_frontend_label": "",
    "default_value": "",
    "entity_type_id": "",
    "extension_attributes": [],
    "frontend_class": "",
    "frontend_input": "",
    "frontend_labels": [
      [
        "label": "",
        "store_id": 0
      ]
    ],
    "is_comparable": "",
    "is_filterable": false,
    "is_filterable_in_grid": false,
    "is_filterable_in_search": false,
    "is_html_allowed_on_front": false,
    "is_required": false,
    "is_searchable": "",
    "is_unique": "",
    "is_used_for_promo_rules": "",
    "is_used_in_grid": false,
    "is_user_defined": false,
    "is_visible": false,
    "is_visible_in_advanced_search": "",
    "is_visible_in_grid": false,
    "is_visible_on_front": "",
    "is_wysiwyg_enabled": false,
    "note": "",
    "options": [
      [
        "is_default": false,
        "label": "",
        "sort_order": 0,
        "store_labels": [
          [
            "label": "",
            "store_id": 0
          ]
        ],
        "value": ""
      ]
    ],
    "position": 0,
    "scope": "",
    "source_model": "",
    "used_for_sort_by": false,
    "used_in_product_listing": "",
    "validation_rules": [
      [
        "key": "",
        "value": ""
      ]
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attributes/:attributeCode")! 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()
DELETE products-attributes-{attributeCode}
{{baseUrl}}/V1/products/attributes/:attributeCode
QUERY PARAMS

attributeCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attributes/:attributeCode");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/products/attributes/:attributeCode")
require "http/client"

url = "{{baseUrl}}/V1/products/attributes/:attributeCode"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/products/attributes/:attributeCode"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/attributes/:attributeCode");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attributes/:attributeCode"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/products/attributes/:attributeCode HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/products/attributes/:attributeCode")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attributes/:attributeCode"))
    .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}}/V1/products/attributes/:attributeCode")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/products/attributes/:attributeCode")
  .asString();
const 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}}/V1/products/attributes/:attributeCode');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attributes/:attributeCode';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attributes/:attributeCode")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attributes/:attributeCode',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/products/attributes/:attributeCode');

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}}/V1/products/attributes/:attributeCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attributes/:attributeCode';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attributes/:attributeCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/attributes/:attributeCode" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attributes/:attributeCode",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/products/attributes/:attributeCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attributes/:attributeCode');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/attributes/:attributeCode');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attributes/:attributeCode' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attributes/:attributeCode' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/products/attributes/:attributeCode")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attributes/:attributeCode"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attributes/:attributeCode"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attributes/:attributeCode")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/products/attributes/:attributeCode') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/attributes/:attributeCode";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/products/attributes/:attributeCode
http DELETE {{baseUrl}}/V1/products/attributes/:attributeCode
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/products/attributes/:attributeCode
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attributes/:attributeCode")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST products-attributes-{attributeCode}-options (POST)
{{baseUrl}}/V1/products/attributes/:attributeCode/options
QUERY PARAMS

attributeCode
BODY json

{
  "option": {
    "is_default": false,
    "label": "",
    "sort_order": 0,
    "store_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "value": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attributes/:attributeCode/options");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"option\": {\n    \"is_default\": false,\n    \"label\": \"\",\n    \"sort_order\": 0,\n    \"store_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"value\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/attributes/:attributeCode/options" {:content-type :json
                                                                                          :form-params {:option {:is_default false
                                                                                                                 :label ""
                                                                                                                 :sort_order 0
                                                                                                                 :store_labels [{:label ""
                                                                                                                                 :store_id 0}]
                                                                                                                 :value ""}}})
require "http/client"

url = "{{baseUrl}}/V1/products/attributes/:attributeCode/options"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"option\": {\n    \"is_default\": false,\n    \"label\": \"\",\n    \"sort_order\": 0,\n    \"store_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\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}}/V1/products/attributes/:attributeCode/options"),
    Content = new StringContent("{\n  \"option\": {\n    \"is_default\": false,\n    \"label\": \"\",\n    \"sort_order\": 0,\n    \"store_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\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}}/V1/products/attributes/:attributeCode/options");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"option\": {\n    \"is_default\": false,\n    \"label\": \"\",\n    \"sort_order\": 0,\n    \"store_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"value\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attributes/:attributeCode/options"

	payload := strings.NewReader("{\n  \"option\": {\n    \"is_default\": false,\n    \"label\": \"\",\n    \"sort_order\": 0,\n    \"store_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"value\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/attributes/:attributeCode/options HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 188

{
  "option": {
    "is_default": false,
    "label": "",
    "sort_order": 0,
    "store_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "value": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/attributes/:attributeCode/options")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"option\": {\n    \"is_default\": false,\n    \"label\": \"\",\n    \"sort_order\": 0,\n    \"store_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"value\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attributes/:attributeCode/options"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"option\": {\n    \"is_default\": false,\n    \"label\": \"\",\n    \"sort_order\": 0,\n    \"store_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\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  \"option\": {\n    \"is_default\": false,\n    \"label\": \"\",\n    \"sort_order\": 0,\n    \"store_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"value\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/attributes/:attributeCode/options")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/attributes/:attributeCode/options")
  .header("content-type", "application/json")
  .body("{\n  \"option\": {\n    \"is_default\": false,\n    \"label\": \"\",\n    \"sort_order\": 0,\n    \"store_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"value\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  option: {
    is_default: false,
    label: '',
    sort_order: 0,
    store_labels: [
      {
        label: '',
        store_id: 0
      }
    ],
    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}}/V1/products/attributes/:attributeCode/options');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode/options',
  headers: {'content-type': 'application/json'},
  data: {
    option: {
      is_default: false,
      label: '',
      sort_order: 0,
      store_labels: [{label: '', store_id: 0}],
      value: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attributes/:attributeCode/options';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"option":{"is_default":false,"label":"","sort_order":0,"store_labels":[{"label":"","store_id":0}],"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}}/V1/products/attributes/:attributeCode/options',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "option": {\n    "is_default": false,\n    "label": "",\n    "sort_order": 0,\n    "store_labels": [\n      {\n        "label": "",\n        "store_id": 0\n      }\n    ],\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  \"option\": {\n    \"is_default\": false,\n    \"label\": \"\",\n    \"sort_order\": 0,\n    \"store_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"value\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attributes/:attributeCode/options")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attributes/:attributeCode/options',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  option: {
    is_default: false,
    label: '',
    sort_order: 0,
    store_labels: [{label: '', store_id: 0}],
    value: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode/options',
  headers: {'content-type': 'application/json'},
  body: {
    option: {
      is_default: false,
      label: '',
      sort_order: 0,
      store_labels: [{label: '', store_id: 0}],
      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}}/V1/products/attributes/:attributeCode/options');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  option: {
    is_default: false,
    label: '',
    sort_order: 0,
    store_labels: [
      {
        label: '',
        store_id: 0
      }
    ],
    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}}/V1/products/attributes/:attributeCode/options',
  headers: {'content-type': 'application/json'},
  data: {
    option: {
      is_default: false,
      label: '',
      sort_order: 0,
      store_labels: [{label: '', store_id: 0}],
      value: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attributes/:attributeCode/options';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"option":{"is_default":false,"label":"","sort_order":0,"store_labels":[{"label":"","store_id":0}],"value":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"option": @{ @"is_default": @NO, @"label": @"", @"sort_order": @0, @"store_labels": @[ @{ @"label": @"", @"store_id": @0 } ], @"value": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attributes/:attributeCode/options"]
                                                       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}}/V1/products/attributes/:attributeCode/options" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"option\": {\n    \"is_default\": false,\n    \"label\": \"\",\n    \"sort_order\": 0,\n    \"store_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"value\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attributes/:attributeCode/options",
  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([
    'option' => [
        'is_default' => null,
        'label' => '',
        'sort_order' => 0,
        'store_labels' => [
                [
                                'label' => '',
                                'store_id' => 0
                ]
        ],
        'value' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/attributes/:attributeCode/options', [
  'body' => '{
  "option": {
    "is_default": false,
    "label": "",
    "sort_order": 0,
    "store_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "value": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attributes/:attributeCode/options');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'option' => [
    'is_default' => null,
    'label' => '',
    'sort_order' => 0,
    'store_labels' => [
        [
                'label' => '',
                'store_id' => 0
        ]
    ],
    'value' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'option' => [
    'is_default' => null,
    'label' => '',
    'sort_order' => 0,
    'store_labels' => [
        [
                'label' => '',
                'store_id' => 0
        ]
    ],
    'value' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/attributes/:attributeCode/options');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attributes/:attributeCode/options' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "option": {
    "is_default": false,
    "label": "",
    "sort_order": 0,
    "store_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "value": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attributes/:attributeCode/options' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "option": {
    "is_default": false,
    "label": "",
    "sort_order": 0,
    "store_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "value": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"option\": {\n    \"is_default\": false,\n    \"label\": \"\",\n    \"sort_order\": 0,\n    \"store_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"value\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/attributes/:attributeCode/options", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attributes/:attributeCode/options"

payload = { "option": {
        "is_default": False,
        "label": "",
        "sort_order": 0,
        "store_labels": [
            {
                "label": "",
                "store_id": 0
            }
        ],
        "value": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attributes/:attributeCode/options"

payload <- "{\n  \"option\": {\n    \"is_default\": false,\n    \"label\": \"\",\n    \"sort_order\": 0,\n    \"store_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"value\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attributes/:attributeCode/options")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"option\": {\n    \"is_default\": false,\n    \"label\": \"\",\n    \"sort_order\": 0,\n    \"store_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\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/V1/products/attributes/:attributeCode/options') do |req|
  req.body = "{\n  \"option\": {\n    \"is_default\": false,\n    \"label\": \"\",\n    \"sort_order\": 0,\n    \"store_labels\": [\n      {\n        \"label\": \"\",\n        \"store_id\": 0\n      }\n    ],\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}}/V1/products/attributes/:attributeCode/options";

    let payload = json!({"option": json!({
            "is_default": false,
            "label": "",
            "sort_order": 0,
            "store_labels": (
                json!({
                    "label": "",
                    "store_id": 0
                })
            ),
            "value": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/attributes/:attributeCode/options \
  --header 'content-type: application/json' \
  --data '{
  "option": {
    "is_default": false,
    "label": "",
    "sort_order": 0,
    "store_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "value": ""
  }
}'
echo '{
  "option": {
    "is_default": false,
    "label": "",
    "sort_order": 0,
    "store_labels": [
      {
        "label": "",
        "store_id": 0
      }
    ],
    "value": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/products/attributes/:attributeCode/options \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "option": {\n    "is_default": false,\n    "label": "",\n    "sort_order": 0,\n    "store_labels": [\n      {\n        "label": "",\n        "store_id": 0\n      }\n    ],\n    "value": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/attributes/:attributeCode/options
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["option": [
    "is_default": false,
    "label": "",
    "sort_order": 0,
    "store_labels": [
      [
        "label": "",
        "store_id": 0
      ]
    ],
    "value": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attributes/:attributeCode/options")! 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 products-attributes-{attributeCode}-options
{{baseUrl}}/V1/products/attributes/:attributeCode/options
QUERY PARAMS

attributeCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attributes/:attributeCode/options");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/attributes/:attributeCode/options")
require "http/client"

url = "{{baseUrl}}/V1/products/attributes/:attributeCode/options"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/attributes/:attributeCode/options"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/attributes/:attributeCode/options");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attributes/:attributeCode/options"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/attributes/:attributeCode/options HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/attributes/:attributeCode/options")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attributes/:attributeCode/options"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/attributes/:attributeCode/options")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/attributes/:attributeCode/options")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/attributes/:attributeCode/options');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode/options'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attributes/:attributeCode/options';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode/options',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attributes/:attributeCode/options")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attributes/:attributeCode/options',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode/options'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/attributes/:attributeCode/options');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode/options'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attributes/:attributeCode/options';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attributes/:attributeCode/options"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/attributes/:attributeCode/options" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attributes/:attributeCode/options",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/attributes/:attributeCode/options');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attributes/:attributeCode/options');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/attributes/:attributeCode/options');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attributes/:attributeCode/options' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attributes/:attributeCode/options' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/attributes/:attributeCode/options")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attributes/:attributeCode/options"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attributes/:attributeCode/options"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attributes/:attributeCode/options")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/attributes/:attributeCode/options') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/attributes/:attributeCode/options";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/attributes/:attributeCode/options
http GET {{baseUrl}}/V1/products/attributes/:attributeCode/options
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/attributes/:attributeCode/options
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attributes/:attributeCode/options")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE products-attributes-{attributeCode}-options-{optionId}
{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId
QUERY PARAMS

attributeCode
optionId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId")
require "http/client"

url = "{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/products/attributes/:attributeCode/options/:optionId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId"))
    .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}}/V1/products/attributes/:attributeCode/options/:optionId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId")
  .asString();
const 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}}/V1/products/attributes/:attributeCode/options/:optionId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attributes/:attributeCode/options/:optionId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId');

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}}/V1/products/attributes/:attributeCode/options/:optionId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/products/attributes/:attributeCode/options/:optionId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/products/attributes/:attributeCode/options/:optionId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId
http DELETE {{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attributes/:attributeCode/options/:optionId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET products-attributes-types
{{baseUrl}}/V1/products/attributes/types
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/attributes/types");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/attributes/types")
require "http/client"

url = "{{baseUrl}}/V1/products/attributes/types"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/attributes/types"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/attributes/types");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/attributes/types"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/attributes/types HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/attributes/types")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/attributes/types"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/attributes/types")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/attributes/types")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/attributes/types');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/attributes/types'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/attributes/types';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/attributes/types',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/attributes/types")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/attributes/types',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/attributes/types'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/attributes/types');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/attributes/types'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/attributes/types';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/attributes/types"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/attributes/types" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/attributes/types",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/attributes/types');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/attributes/types');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/attributes/types');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/attributes/types' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/attributes/types' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/attributes/types")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/attributes/types"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/attributes/types"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/attributes/types")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/attributes/types') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/attributes/types";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/attributes/types
http GET {{baseUrl}}/V1/products/attributes/types
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/attributes/types
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/attributes/types")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST products-base-prices
{{baseUrl}}/V1/products/base-prices
BODY json

{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "sku": "",
      "store_id": 0
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/base-prices");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/base-prices" {:content-type :json
                                                                    :form-params {:prices [{:extension_attributes {}
                                                                                            :price ""
                                                                                            :sku ""
                                                                                            :store_id 0}]}})
require "http/client"

url = "{{baseUrl}}/V1/products/base-prices"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\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}}/V1/products/base-prices"),
    Content = new StringContent("{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\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}}/V1/products/base-prices");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/base-prices"

	payload := strings.NewReader("{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/base-prices HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 123

{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "sku": "",
      "store_id": 0
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/base-prices")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/base-prices"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\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  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/base-prices")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/base-prices")
  .header("content-type", "application/json")
  .body("{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  prices: [
    {
      extension_attributes: {},
      price: '',
      sku: '',
      store_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}}/V1/products/base-prices');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/base-prices',
  headers: {'content-type': 'application/json'},
  data: {prices: [{extension_attributes: {}, price: '', sku: '', store_id: 0}]}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/base-prices';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"prices":[{"extension_attributes":{},"price":"","sku":"","store_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}}/V1/products/base-prices',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "prices": [\n    {\n      "extension_attributes": {},\n      "price": "",\n      "sku": "",\n      "store_id": 0\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  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/base-prices")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/base-prices',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({prices: [{extension_attributes: {}, price: '', sku: '', store_id: 0}]}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/base-prices',
  headers: {'content-type': 'application/json'},
  body: {prices: [{extension_attributes: {}, price: '', sku: '', store_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}}/V1/products/base-prices');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  prices: [
    {
      extension_attributes: {},
      price: '',
      sku: '',
      store_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}}/V1/products/base-prices',
  headers: {'content-type': 'application/json'},
  data: {prices: [{extension_attributes: {}, price: '', sku: '', store_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}}/V1/products/base-prices';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"prices":[{"extension_attributes":{},"price":"","sku":"","store_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 = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"prices": @[ @{ @"extension_attributes": @{  }, @"price": @"", @"sku": @"", @"store_id": @0 } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/base-prices"]
                                                       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}}/V1/products/base-prices" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/base-prices",
  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([
    'prices' => [
        [
                'extension_attributes' => [
                                
                ],
                'price' => '',
                'sku' => '',
                'store_id' => 0
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/base-prices', [
  'body' => '{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "sku": "",
      "store_id": 0
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/base-prices');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'prices' => [
    [
        'extension_attributes' => [
                
        ],
        'price' => '',
        'sku' => '',
        'store_id' => 0
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'prices' => [
    [
        'extension_attributes' => [
                
        ],
        'price' => '',
        'sku' => '',
        'store_id' => 0
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/base-prices');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/base-prices' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "sku": "",
      "store_id": 0
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/base-prices' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "sku": "",
      "store_id": 0
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/base-prices", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/base-prices"

payload = { "prices": [
        {
            "extension_attributes": {},
            "price": "",
            "sku": "",
            "store_id": 0
        }
    ] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/base-prices"

payload <- "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/base-prices")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\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/V1/products/base-prices') do |req|
  req.body = "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\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}}/V1/products/base-prices";

    let payload = json!({"prices": (
            json!({
                "extension_attributes": json!({}),
                "price": "",
                "sku": "",
                "store_id": 0
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/base-prices \
  --header 'content-type: application/json' \
  --data '{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "sku": "",
      "store_id": 0
    }
  ]
}'
echo '{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "sku": "",
      "store_id": 0
    }
  ]
}' |  \
  http POST {{baseUrl}}/V1/products/base-prices \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "prices": [\n    {\n      "extension_attributes": {},\n      "price": "",\n      "sku": "",\n      "store_id": 0\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/base-prices
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["prices": [
    [
      "extension_attributes": [],
      "price": "",
      "sku": "",
      "store_id": 0
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/base-prices")! 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 products-base-prices-information
{{baseUrl}}/V1/products/base-prices-information
BODY json

{
  "skus": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/base-prices-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"skus\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/base-prices-information" {:content-type :json
                                                                                :form-params {:skus []}})
require "http/client"

url = "{{baseUrl}}/V1/products/base-prices-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"skus\": []\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}}/V1/products/base-prices-information"),
    Content = new StringContent("{\n  \"skus\": []\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}}/V1/products/base-prices-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"skus\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/base-prices-information"

	payload := strings.NewReader("{\n  \"skus\": []\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/base-prices-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 16

{
  "skus": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/base-prices-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"skus\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/base-prices-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"skus\": []\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  \"skus\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/base-prices-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/base-prices-information")
  .header("content-type", "application/json")
  .body("{\n  \"skus\": []\n}")
  .asString();
const data = JSON.stringify({
  skus: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/products/base-prices-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/base-prices-information',
  headers: {'content-type': 'application/json'},
  data: {skus: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/base-prices-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"skus":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/base-prices-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "skus": []\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"skus\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/base-prices-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/base-prices-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({skus: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/base-prices-information',
  headers: {'content-type': 'application/json'},
  body: {skus: []},
  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}}/V1/products/base-prices-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  skus: []
});

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}}/V1/products/base-prices-information',
  headers: {'content-type': 'application/json'},
  data: {skus: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/base-prices-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"skus":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"skus": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/base-prices-information"]
                                                       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}}/V1/products/base-prices-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"skus\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/base-prices-information",
  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([
    'skus' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/base-prices-information', [
  'body' => '{
  "skus": []
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/base-prices-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'skus' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'skus' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/base-prices-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/base-prices-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "skus": []
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/base-prices-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "skus": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"skus\": []\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/base-prices-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/base-prices-information"

payload = { "skus": [] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/base-prices-information"

payload <- "{\n  \"skus\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/base-prices-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"skus\": []\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/V1/products/base-prices-information') do |req|
  req.body = "{\n  \"skus\": []\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/base-prices-information";

    let payload = json!({"skus": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/base-prices-information \
  --header 'content-type: application/json' \
  --data '{
  "skus": []
}'
echo '{
  "skus": []
}' |  \
  http POST {{baseUrl}}/V1/products/base-prices-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "skus": []\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/base-prices-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["skus": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/base-prices-information")! 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 products-cost
{{baseUrl}}/V1/products/cost
BODY json

{
  "prices": [
    {
      "cost": "",
      "extension_attributes": {},
      "sku": "",
      "store_id": 0
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/cost");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"prices\": [\n    {\n      \"cost\": \"\",\n      \"extension_attributes\": {},\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/cost" {:content-type :json
                                                             :form-params {:prices [{:cost ""
                                                                                     :extension_attributes {}
                                                                                     :sku ""
                                                                                     :store_id 0}]}})
require "http/client"

url = "{{baseUrl}}/V1/products/cost"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"prices\": [\n    {\n      \"cost\": \"\",\n      \"extension_attributes\": {},\n      \"sku\": \"\",\n      \"store_id\": 0\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}}/V1/products/cost"),
    Content = new StringContent("{\n  \"prices\": [\n    {\n      \"cost\": \"\",\n      \"extension_attributes\": {},\n      \"sku\": \"\",\n      \"store_id\": 0\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}}/V1/products/cost");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"prices\": [\n    {\n      \"cost\": \"\",\n      \"extension_attributes\": {},\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/cost"

	payload := strings.NewReader("{\n  \"prices\": [\n    {\n      \"cost\": \"\",\n      \"extension_attributes\": {},\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/cost HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 122

{
  "prices": [
    {
      "cost": "",
      "extension_attributes": {},
      "sku": "",
      "store_id": 0
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/cost")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"prices\": [\n    {\n      \"cost\": \"\",\n      \"extension_attributes\": {},\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/cost"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"prices\": [\n    {\n      \"cost\": \"\",\n      \"extension_attributes\": {},\n      \"sku\": \"\",\n      \"store_id\": 0\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  \"prices\": [\n    {\n      \"cost\": \"\",\n      \"extension_attributes\": {},\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/cost")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/cost")
  .header("content-type", "application/json")
  .body("{\n  \"prices\": [\n    {\n      \"cost\": \"\",\n      \"extension_attributes\": {},\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  prices: [
    {
      cost: '',
      extension_attributes: {},
      sku: '',
      store_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}}/V1/products/cost');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/cost',
  headers: {'content-type': 'application/json'},
  data: {prices: [{cost: '', extension_attributes: {}, sku: '', store_id: 0}]}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/cost';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"prices":[{"cost":"","extension_attributes":{},"sku":"","store_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}}/V1/products/cost',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "prices": [\n    {\n      "cost": "",\n      "extension_attributes": {},\n      "sku": "",\n      "store_id": 0\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  \"prices\": [\n    {\n      \"cost\": \"\",\n      \"extension_attributes\": {},\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/cost")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/cost',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({prices: [{cost: '', extension_attributes: {}, sku: '', store_id: 0}]}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/cost',
  headers: {'content-type': 'application/json'},
  body: {prices: [{cost: '', extension_attributes: {}, sku: '', store_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}}/V1/products/cost');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  prices: [
    {
      cost: '',
      extension_attributes: {},
      sku: '',
      store_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}}/V1/products/cost',
  headers: {'content-type': 'application/json'},
  data: {prices: [{cost: '', extension_attributes: {}, sku: '', store_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}}/V1/products/cost';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"prices":[{"cost":"","extension_attributes":{},"sku":"","store_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 = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"prices": @[ @{ @"cost": @"", @"extension_attributes": @{  }, @"sku": @"", @"store_id": @0 } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/cost"]
                                                       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}}/V1/products/cost" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"prices\": [\n    {\n      \"cost\": \"\",\n      \"extension_attributes\": {},\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/cost",
  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([
    'prices' => [
        [
                'cost' => '',
                'extension_attributes' => [
                                
                ],
                'sku' => '',
                'store_id' => 0
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/cost', [
  'body' => '{
  "prices": [
    {
      "cost": "",
      "extension_attributes": {},
      "sku": "",
      "store_id": 0
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/cost');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'prices' => [
    [
        'cost' => '',
        'extension_attributes' => [
                
        ],
        'sku' => '',
        'store_id' => 0
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'prices' => [
    [
        'cost' => '',
        'extension_attributes' => [
                
        ],
        'sku' => '',
        'store_id' => 0
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/cost');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/cost' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "prices": [
    {
      "cost": "",
      "extension_attributes": {},
      "sku": "",
      "store_id": 0
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/cost' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "prices": [
    {
      "cost": "",
      "extension_attributes": {},
      "sku": "",
      "store_id": 0
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"prices\": [\n    {\n      \"cost\": \"\",\n      \"extension_attributes\": {},\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/cost", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/cost"

payload = { "prices": [
        {
            "cost": "",
            "extension_attributes": {},
            "sku": "",
            "store_id": 0
        }
    ] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/cost"

payload <- "{\n  \"prices\": [\n    {\n      \"cost\": \"\",\n      \"extension_attributes\": {},\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/cost")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"prices\": [\n    {\n      \"cost\": \"\",\n      \"extension_attributes\": {},\n      \"sku\": \"\",\n      \"store_id\": 0\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/V1/products/cost') do |req|
  req.body = "{\n  \"prices\": [\n    {\n      \"cost\": \"\",\n      \"extension_attributes\": {},\n      \"sku\": \"\",\n      \"store_id\": 0\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}}/V1/products/cost";

    let payload = json!({"prices": (
            json!({
                "cost": "",
                "extension_attributes": json!({}),
                "sku": "",
                "store_id": 0
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/cost \
  --header 'content-type: application/json' \
  --data '{
  "prices": [
    {
      "cost": "",
      "extension_attributes": {},
      "sku": "",
      "store_id": 0
    }
  ]
}'
echo '{
  "prices": [
    {
      "cost": "",
      "extension_attributes": {},
      "sku": "",
      "store_id": 0
    }
  ]
}' |  \
  http POST {{baseUrl}}/V1/products/cost \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "prices": [\n    {\n      "cost": "",\n      "extension_attributes": {},\n      "sku": "",\n      "store_id": 0\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/cost
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["prices": [
    [
      "cost": "",
      "extension_attributes": [],
      "sku": "",
      "store_id": 0
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/cost")! 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 products-cost-delete
{{baseUrl}}/V1/products/cost-delete
BODY json

{
  "skus": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/cost-delete");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"skus\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/cost-delete" {:content-type :json
                                                                    :form-params {:skus []}})
require "http/client"

url = "{{baseUrl}}/V1/products/cost-delete"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"skus\": []\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}}/V1/products/cost-delete"),
    Content = new StringContent("{\n  \"skus\": []\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}}/V1/products/cost-delete");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"skus\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/cost-delete"

	payload := strings.NewReader("{\n  \"skus\": []\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/cost-delete HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 16

{
  "skus": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/cost-delete")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"skus\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/cost-delete"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"skus\": []\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  \"skus\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/cost-delete")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/cost-delete")
  .header("content-type", "application/json")
  .body("{\n  \"skus\": []\n}")
  .asString();
const data = JSON.stringify({
  skus: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/products/cost-delete');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/cost-delete',
  headers: {'content-type': 'application/json'},
  data: {skus: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/cost-delete';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"skus":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/cost-delete',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "skus": []\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"skus\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/cost-delete")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/cost-delete',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({skus: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/cost-delete',
  headers: {'content-type': 'application/json'},
  body: {skus: []},
  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}}/V1/products/cost-delete');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  skus: []
});

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}}/V1/products/cost-delete',
  headers: {'content-type': 'application/json'},
  data: {skus: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/cost-delete';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"skus":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"skus": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/cost-delete"]
                                                       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}}/V1/products/cost-delete" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"skus\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/cost-delete",
  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([
    'skus' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/cost-delete', [
  'body' => '{
  "skus": []
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/cost-delete');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'skus' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'skus' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/cost-delete');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/cost-delete' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "skus": []
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/cost-delete' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "skus": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"skus\": []\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/cost-delete", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/cost-delete"

payload = { "skus": [] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/cost-delete"

payload <- "{\n  \"skus\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/cost-delete")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"skus\": []\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/V1/products/cost-delete') do |req|
  req.body = "{\n  \"skus\": []\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/cost-delete";

    let payload = json!({"skus": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/cost-delete \
  --header 'content-type: application/json' \
  --data '{
  "skus": []
}'
echo '{
  "skus": []
}' |  \
  http POST {{baseUrl}}/V1/products/cost-delete \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "skus": []\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/cost-delete
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["skus": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/cost-delete")! 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 products-cost-information
{{baseUrl}}/V1/products/cost-information
BODY json

{
  "skus": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/cost-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"skus\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/cost-information" {:content-type :json
                                                                         :form-params {:skus []}})
require "http/client"

url = "{{baseUrl}}/V1/products/cost-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"skus\": []\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}}/V1/products/cost-information"),
    Content = new StringContent("{\n  \"skus\": []\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}}/V1/products/cost-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"skus\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/cost-information"

	payload := strings.NewReader("{\n  \"skus\": []\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/cost-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 16

{
  "skus": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/cost-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"skus\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/cost-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"skus\": []\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  \"skus\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/cost-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/cost-information")
  .header("content-type", "application/json")
  .body("{\n  \"skus\": []\n}")
  .asString();
const data = JSON.stringify({
  skus: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/products/cost-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/cost-information',
  headers: {'content-type': 'application/json'},
  data: {skus: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/cost-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"skus":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/cost-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "skus": []\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"skus\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/cost-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/cost-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({skus: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/cost-information',
  headers: {'content-type': 'application/json'},
  body: {skus: []},
  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}}/V1/products/cost-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  skus: []
});

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}}/V1/products/cost-information',
  headers: {'content-type': 'application/json'},
  data: {skus: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/cost-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"skus":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"skus": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/cost-information"]
                                                       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}}/V1/products/cost-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"skus\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/cost-information",
  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([
    'skus' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/cost-information', [
  'body' => '{
  "skus": []
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/cost-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'skus' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'skus' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/cost-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/cost-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "skus": []
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/cost-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "skus": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"skus\": []\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/cost-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/cost-information"

payload = { "skus": [] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/cost-information"

payload <- "{\n  \"skus\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/cost-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"skus\": []\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/V1/products/cost-information') do |req|
  req.body = "{\n  \"skus\": []\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/cost-information";

    let payload = json!({"skus": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/cost-information \
  --header 'content-type: application/json' \
  --data '{
  "skus": []
}'
echo '{
  "skus": []
}' |  \
  http POST {{baseUrl}}/V1/products/cost-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "skus": []\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/cost-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["skus": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/cost-information")! 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, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/downloadable-links/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/products/downloadable-links/:id")
require "http/client"

url = "{{baseUrl}}/V1/products/downloadable-links/:id"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/products/downloadable-links/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/downloadable-links/:id");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/downloadable-links/:id"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/products/downloadable-links/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/products/downloadable-links/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/downloadable-links/:id"))
    .method("DELETE", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/downloadable-links/:id")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/products/downloadable-links/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/V1/products/downloadable-links/:id');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/downloadable-links/:id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/downloadable-links/:id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/downloadable-links/:id',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/downloadable-links/:id")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/downloadable-links/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/downloadable-links/:id'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/products/downloadable-links/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/downloadable-links/:id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/downloadable-links/:id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/downloadable-links/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/downloadable-links/:id" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/downloadable-links/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/products/downloadable-links/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/downloadable-links/:id');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/downloadable-links/:id');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/downloadable-links/:id' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/downloadable-links/:id' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/products/downloadable-links/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/downloadable-links/:id"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/downloadable-links/:id"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/downloadable-links/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/products/downloadable-links/:id') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/downloadable-links/:id";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/products/downloadable-links/:id
http DELETE {{baseUrl}}/V1/products/downloadable-links/:id
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/products/downloadable-links/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/downloadable-links/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/downloadable-links/samples/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/products/downloadable-links/samples/:id")
require "http/client"

url = "{{baseUrl}}/V1/products/downloadable-links/samples/:id"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/products/downloadable-links/samples/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/downloadable-links/samples/:id");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/downloadable-links/samples/:id"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/products/downloadable-links/samples/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/products/downloadable-links/samples/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/downloadable-links/samples/:id"))
    .method("DELETE", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/downloadable-links/samples/:id")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/products/downloadable-links/samples/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/V1/products/downloadable-links/samples/:id');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/downloadable-links/samples/:id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/downloadable-links/samples/:id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/downloadable-links/samples/:id',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/downloadable-links/samples/:id")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/downloadable-links/samples/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/downloadable-links/samples/:id'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/products/downloadable-links/samples/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/products/downloadable-links/samples/:id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/downloadable-links/samples/:id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/downloadable-links/samples/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/downloadable-links/samples/:id" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/downloadable-links/samples/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/products/downloadable-links/samples/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/downloadable-links/samples/:id');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/downloadable-links/samples/:id');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/downloadable-links/samples/:id' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/downloadable-links/samples/:id' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/products/downloadable-links/samples/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/downloadable-links/samples/:id"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/downloadable-links/samples/:id"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/downloadable-links/samples/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/products/downloadable-links/samples/:id') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/downloadable-links/samples/:id";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/products/downloadable-links/samples/:id
http DELETE {{baseUrl}}/V1/products/downloadable-links/samples/:id
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/products/downloadable-links/samples/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/downloadable-links/samples/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/links/:type/attributes");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/links/:type/attributes")
require "http/client"

url = "{{baseUrl}}/V1/products/links/:type/attributes"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/links/:type/attributes"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/links/:type/attributes");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/links/:type/attributes"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/links/:type/attributes HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/links/:type/attributes")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/links/:type/attributes"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/links/:type/attributes")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/links/:type/attributes")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/links/:type/attributes');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/links/:type/attributes'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/links/:type/attributes';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/links/:type/attributes',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/links/:type/attributes")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/links/:type/attributes',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/links/:type/attributes'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/links/:type/attributes');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/links/:type/attributes'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/links/:type/attributes';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/links/:type/attributes"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/links/:type/attributes" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/links/:type/attributes",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/links/:type/attributes');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/links/:type/attributes');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/links/:type/attributes');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/links/:type/attributes' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/links/:type/attributes' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/links/:type/attributes")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/links/:type/attributes"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/links/:type/attributes"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/links/:type/attributes")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/links/:type/attributes') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/links/:type/attributes";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/links/:type/attributes
http GET {{baseUrl}}/V1/products/links/:type/attributes
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/links/:type/attributes
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/links/:type/attributes")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/links/types");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/links/types")
require "http/client"

url = "{{baseUrl}}/V1/products/links/types"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/links/types"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/links/types");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/links/types"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/links/types HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/links/types")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/links/types"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/links/types")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/links/types")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/links/types');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/links/types'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/links/types';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/links/types',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/links/types")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/links/types',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/links/types'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/links/types');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/links/types'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/links/types';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/links/types"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/links/types" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/links/types",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/links/types');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/links/types');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/links/types');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/links/types' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/links/types' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/links/types")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/links/types"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/links/types"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/links/types")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/links/types') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/links/types";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/links/types
http GET {{baseUrl}}/V1/products/links/types
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/links/types
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/links/types")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET products-media-types-{attributeSetName}
{{baseUrl}}/V1/products/media/types/:attributeSetName
QUERY PARAMS

attributeSetName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/media/types/:attributeSetName");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/media/types/:attributeSetName")
require "http/client"

url = "{{baseUrl}}/V1/products/media/types/:attributeSetName"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/media/types/:attributeSetName"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/media/types/:attributeSetName");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/media/types/:attributeSetName"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/media/types/:attributeSetName HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/media/types/:attributeSetName")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/media/types/:attributeSetName"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/media/types/:attributeSetName")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/media/types/:attributeSetName")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/media/types/:attributeSetName');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/media/types/:attributeSetName'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/media/types/:attributeSetName';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/media/types/:attributeSetName',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/media/types/:attributeSetName")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/media/types/:attributeSetName',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/media/types/:attributeSetName'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/media/types/:attributeSetName');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products/media/types/:attributeSetName'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/media/types/:attributeSetName';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/media/types/:attributeSetName"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/media/types/:attributeSetName" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/media/types/:attributeSetName",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/media/types/:attributeSetName');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/media/types/:attributeSetName');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/media/types/:attributeSetName');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/media/types/:attributeSetName' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/media/types/:attributeSetName' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/media/types/:attributeSetName")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/media/types/:attributeSetName"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/media/types/:attributeSetName"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/media/types/:attributeSetName")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/media/types/:attributeSetName') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/media/types/:attributeSetName";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/media/types/:attributeSetName
http GET {{baseUrl}}/V1/products/media/types/:attributeSetName
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/media/types/:attributeSetName
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/media/types/:attributeSetName")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST products-options
{{baseUrl}}/V1/products/options
BODY json

{
  "option": {
    "extension_attributes": {
      "vertex_flex_field": ""
    },
    "file_extension": "",
    "image_size_x": 0,
    "image_size_y": 0,
    "is_require": false,
    "max_characters": 0,
    "option_id": 0,
    "price": "",
    "price_type": "",
    "product_sku": "",
    "sku": "",
    "sort_order": 0,
    "title": "",
    "type": "",
    "values": [
      {
        "option_type_id": 0,
        "price": "",
        "price_type": "",
        "sku": "",
        "sort_order": 0,
        "title": ""
      }
    ]
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/options");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/options" {:content-type :json
                                                                :form-params {:option {:extension_attributes {:vertex_flex_field ""}
                                                                                       :file_extension ""
                                                                                       :image_size_x 0
                                                                                       :image_size_y 0
                                                                                       :is_require false
                                                                                       :max_characters 0
                                                                                       :option_id 0
                                                                                       :price ""
                                                                                       :price_type ""
                                                                                       :product_sku ""
                                                                                       :sku ""
                                                                                       :sort_order 0
                                                                                       :title ""
                                                                                       :type ""
                                                                                       :values [{:option_type_id 0
                                                                                                 :price ""
                                                                                                 :price_type ""
                                                                                                 :sku ""
                                                                                                 :sort_order 0
                                                                                                 :title ""}]}}})
require "http/client"

url = "{{baseUrl}}/V1/products/options"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\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}}/V1/products/options"),
    Content = new StringContent("{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/options");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/options"

	payload := strings.NewReader("{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/options HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 539

{
  "option": {
    "extension_attributes": {
      "vertex_flex_field": ""
    },
    "file_extension": "",
    "image_size_x": 0,
    "image_size_y": 0,
    "is_require": false,
    "max_characters": 0,
    "option_id": 0,
    "price": "",
    "price_type": "",
    "product_sku": "",
    "sku": "",
    "sort_order": 0,
    "title": "",
    "type": "",
    "values": [
      {
        "option_type_id": 0,
        "price": "",
        "price_type": "",
        "sku": "",
        "sort_order": 0,
        "title": ""
      }
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/options")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/options"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/options")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/options")
  .header("content-type", "application/json")
  .body("{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}")
  .asString();
const data = JSON.stringify({
  option: {
    extension_attributes: {
      vertex_flex_field: ''
    },
    file_extension: '',
    image_size_x: 0,
    image_size_y: 0,
    is_require: false,
    max_characters: 0,
    option_id: 0,
    price: '',
    price_type: '',
    product_sku: '',
    sku: '',
    sort_order: 0,
    title: '',
    type: '',
    values: [
      {
        option_type_id: 0,
        price: '',
        price_type: '',
        sku: '',
        sort_order: 0,
        title: ''
      }
    ]
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/products/options');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/options',
  headers: {'content-type': 'application/json'},
  data: {
    option: {
      extension_attributes: {vertex_flex_field: ''},
      file_extension: '',
      image_size_x: 0,
      image_size_y: 0,
      is_require: false,
      max_characters: 0,
      option_id: 0,
      price: '',
      price_type: '',
      product_sku: '',
      sku: '',
      sort_order: 0,
      title: '',
      type: '',
      values: [
        {
          option_type_id: 0,
          price: '',
          price_type: '',
          sku: '',
          sort_order: 0,
          title: ''
        }
      ]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/options';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"option":{"extension_attributes":{"vertex_flex_field":""},"file_extension":"","image_size_x":0,"image_size_y":0,"is_require":false,"max_characters":0,"option_id":0,"price":"","price_type":"","product_sku":"","sku":"","sort_order":0,"title":"","type":"","values":[{"option_type_id":0,"price":"","price_type":"","sku":"","sort_order":0,"title":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/options',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "option": {\n    "extension_attributes": {\n      "vertex_flex_field": ""\n    },\n    "file_extension": "",\n    "image_size_x": 0,\n    "image_size_y": 0,\n    "is_require": false,\n    "max_characters": 0,\n    "option_id": 0,\n    "price": "",\n    "price_type": "",\n    "product_sku": "",\n    "sku": "",\n    "sort_order": 0,\n    "title": "",\n    "type": "",\n    "values": [\n      {\n        "option_type_id": 0,\n        "price": "",\n        "price_type": "",\n        "sku": "",\n        "sort_order": 0,\n        "title": ""\n      }\n    ]\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/options")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/options',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  option: {
    extension_attributes: {vertex_flex_field: ''},
    file_extension: '',
    image_size_x: 0,
    image_size_y: 0,
    is_require: false,
    max_characters: 0,
    option_id: 0,
    price: '',
    price_type: '',
    product_sku: '',
    sku: '',
    sort_order: 0,
    title: '',
    type: '',
    values: [
      {
        option_type_id: 0,
        price: '',
        price_type: '',
        sku: '',
        sort_order: 0,
        title: ''
      }
    ]
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/options',
  headers: {'content-type': 'application/json'},
  body: {
    option: {
      extension_attributes: {vertex_flex_field: ''},
      file_extension: '',
      image_size_x: 0,
      image_size_y: 0,
      is_require: false,
      max_characters: 0,
      option_id: 0,
      price: '',
      price_type: '',
      product_sku: '',
      sku: '',
      sort_order: 0,
      title: '',
      type: '',
      values: [
        {
          option_type_id: 0,
          price: '',
          price_type: '',
          sku: '',
          sort_order: 0,
          title: ''
        }
      ]
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/products/options');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  option: {
    extension_attributes: {
      vertex_flex_field: ''
    },
    file_extension: '',
    image_size_x: 0,
    image_size_y: 0,
    is_require: false,
    max_characters: 0,
    option_id: 0,
    price: '',
    price_type: '',
    product_sku: '',
    sku: '',
    sort_order: 0,
    title: '',
    type: '',
    values: [
      {
        option_type_id: 0,
        price: '',
        price_type: '',
        sku: '',
        sort_order: 0,
        title: ''
      }
    ]
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/options',
  headers: {'content-type': 'application/json'},
  data: {
    option: {
      extension_attributes: {vertex_flex_field: ''},
      file_extension: '',
      image_size_x: 0,
      image_size_y: 0,
      is_require: false,
      max_characters: 0,
      option_id: 0,
      price: '',
      price_type: '',
      product_sku: '',
      sku: '',
      sort_order: 0,
      title: '',
      type: '',
      values: [
        {
          option_type_id: 0,
          price: '',
          price_type: '',
          sku: '',
          sort_order: 0,
          title: ''
        }
      ]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/options';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"option":{"extension_attributes":{"vertex_flex_field":""},"file_extension":"","image_size_x":0,"image_size_y":0,"is_require":false,"max_characters":0,"option_id":0,"price":"","price_type":"","product_sku":"","sku":"","sort_order":0,"title":"","type":"","values":[{"option_type_id":0,"price":"","price_type":"","sku":"","sort_order":0,"title":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"option": @{ @"extension_attributes": @{ @"vertex_flex_field": @"" }, @"file_extension": @"", @"image_size_x": @0, @"image_size_y": @0, @"is_require": @NO, @"max_characters": @0, @"option_id": @0, @"price": @"", @"price_type": @"", @"product_sku": @"", @"sku": @"", @"sort_order": @0, @"title": @"", @"type": @"", @"values": @[ @{ @"option_type_id": @0, @"price": @"", @"price_type": @"", @"sku": @"", @"sort_order": @0, @"title": @"" } ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/options"]
                                                       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}}/V1/products/options" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/options",
  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([
    'option' => [
        'extension_attributes' => [
                'vertex_flex_field' => ''
        ],
        'file_extension' => '',
        'image_size_x' => 0,
        'image_size_y' => 0,
        'is_require' => null,
        'max_characters' => 0,
        'option_id' => 0,
        'price' => '',
        'price_type' => '',
        'product_sku' => '',
        'sku' => '',
        'sort_order' => 0,
        'title' => '',
        'type' => '',
        'values' => [
                [
                                'option_type_id' => 0,
                                'price' => '',
                                'price_type' => '',
                                'sku' => '',
                                'sort_order' => 0,
                                'title' => ''
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/options', [
  'body' => '{
  "option": {
    "extension_attributes": {
      "vertex_flex_field": ""
    },
    "file_extension": "",
    "image_size_x": 0,
    "image_size_y": 0,
    "is_require": false,
    "max_characters": 0,
    "option_id": 0,
    "price": "",
    "price_type": "",
    "product_sku": "",
    "sku": "",
    "sort_order": 0,
    "title": "",
    "type": "",
    "values": [
      {
        "option_type_id": 0,
        "price": "",
        "price_type": "",
        "sku": "",
        "sort_order": 0,
        "title": ""
      }
    ]
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/options');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'option' => [
    'extension_attributes' => [
        'vertex_flex_field' => ''
    ],
    'file_extension' => '',
    'image_size_x' => 0,
    'image_size_y' => 0,
    'is_require' => null,
    'max_characters' => 0,
    'option_id' => 0,
    'price' => '',
    'price_type' => '',
    'product_sku' => '',
    'sku' => '',
    'sort_order' => 0,
    'title' => '',
    'type' => '',
    'values' => [
        [
                'option_type_id' => 0,
                'price' => '',
                'price_type' => '',
                'sku' => '',
                'sort_order' => 0,
                'title' => ''
        ]
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'option' => [
    'extension_attributes' => [
        'vertex_flex_field' => ''
    ],
    'file_extension' => '',
    'image_size_x' => 0,
    'image_size_y' => 0,
    'is_require' => null,
    'max_characters' => 0,
    'option_id' => 0,
    'price' => '',
    'price_type' => '',
    'product_sku' => '',
    'sku' => '',
    'sort_order' => 0,
    'title' => '',
    'type' => '',
    'values' => [
        [
                'option_type_id' => 0,
                'price' => '',
                'price_type' => '',
                'sku' => '',
                'sort_order' => 0,
                'title' => ''
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/options');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/options' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "option": {
    "extension_attributes": {
      "vertex_flex_field": ""
    },
    "file_extension": "",
    "image_size_x": 0,
    "image_size_y": 0,
    "is_require": false,
    "max_characters": 0,
    "option_id": 0,
    "price": "",
    "price_type": "",
    "product_sku": "",
    "sku": "",
    "sort_order": 0,
    "title": "",
    "type": "",
    "values": [
      {
        "option_type_id": 0,
        "price": "",
        "price_type": "",
        "sku": "",
        "sort_order": 0,
        "title": ""
      }
    ]
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/options' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "option": {
    "extension_attributes": {
      "vertex_flex_field": ""
    },
    "file_extension": "",
    "image_size_x": 0,
    "image_size_y": 0,
    "is_require": false,
    "max_characters": 0,
    "option_id": 0,
    "price": "",
    "price_type": "",
    "product_sku": "",
    "sku": "",
    "sort_order": 0,
    "title": "",
    "type": "",
    "values": [
      {
        "option_type_id": 0,
        "price": "",
        "price_type": "",
        "sku": "",
        "sort_order": 0,
        "title": ""
      }
    ]
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/options", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/options"

payload = { "option": {
        "extension_attributes": { "vertex_flex_field": "" },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": False,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
            {
                "option_type_id": 0,
                "price": "",
                "price_type": "",
                "sku": "",
                "sort_order": 0,
                "title": ""
            }
        ]
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/options"

payload <- "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/options")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/V1/products/options') do |req|
  req.body = "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\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}}/V1/products/options";

    let payload = json!({"option": json!({
            "extension_attributes": json!({"vertex_flex_field": ""}),
            "file_extension": "",
            "image_size_x": 0,
            "image_size_y": 0,
            "is_require": false,
            "max_characters": 0,
            "option_id": 0,
            "price": "",
            "price_type": "",
            "product_sku": "",
            "sku": "",
            "sort_order": 0,
            "title": "",
            "type": "",
            "values": (
                json!({
                    "option_type_id": 0,
                    "price": "",
                    "price_type": "",
                    "sku": "",
                    "sort_order": 0,
                    "title": ""
                })
            )
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/options \
  --header 'content-type: application/json' \
  --data '{
  "option": {
    "extension_attributes": {
      "vertex_flex_field": ""
    },
    "file_extension": "",
    "image_size_x": 0,
    "image_size_y": 0,
    "is_require": false,
    "max_characters": 0,
    "option_id": 0,
    "price": "",
    "price_type": "",
    "product_sku": "",
    "sku": "",
    "sort_order": 0,
    "title": "",
    "type": "",
    "values": [
      {
        "option_type_id": 0,
        "price": "",
        "price_type": "",
        "sku": "",
        "sort_order": 0,
        "title": ""
      }
    ]
  }
}'
echo '{
  "option": {
    "extension_attributes": {
      "vertex_flex_field": ""
    },
    "file_extension": "",
    "image_size_x": 0,
    "image_size_y": 0,
    "is_require": false,
    "max_characters": 0,
    "option_id": 0,
    "price": "",
    "price_type": "",
    "product_sku": "",
    "sku": "",
    "sort_order": 0,
    "title": "",
    "type": "",
    "values": [
      {
        "option_type_id": 0,
        "price": "",
        "price_type": "",
        "sku": "",
        "sort_order": 0,
        "title": ""
      }
    ]
  }
}' |  \
  http POST {{baseUrl}}/V1/products/options \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "option": {\n    "extension_attributes": {\n      "vertex_flex_field": ""\n    },\n    "file_extension": "",\n    "image_size_x": 0,\n    "image_size_y": 0,\n    "is_require": false,\n    "max_characters": 0,\n    "option_id": 0,\n    "price": "",\n    "price_type": "",\n    "product_sku": "",\n    "sku": "",\n    "sort_order": 0,\n    "title": "",\n    "type": "",\n    "values": [\n      {\n        "option_type_id": 0,\n        "price": "",\n        "price_type": "",\n        "sku": "",\n        "sort_order": 0,\n        "title": ""\n      }\n    ]\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/options
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["option": [
    "extension_attributes": ["vertex_flex_field": ""],
    "file_extension": "",
    "image_size_x": 0,
    "image_size_y": 0,
    "is_require": false,
    "max_characters": 0,
    "option_id": 0,
    "price": "",
    "price_type": "",
    "product_sku": "",
    "sku": "",
    "sort_order": 0,
    "title": "",
    "type": "",
    "values": [
      [
        "option_type_id": 0,
        "price": "",
        "price_type": "",
        "sku": "",
        "sort_order": 0,
        "title": ""
      ]
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/options")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT products-options-{optionId}
{{baseUrl}}/V1/products/options/:optionId
QUERY PARAMS

optionId
BODY json

{
  "option": {
    "extension_attributes": {
      "vertex_flex_field": ""
    },
    "file_extension": "",
    "image_size_x": 0,
    "image_size_y": 0,
    "is_require": false,
    "max_characters": 0,
    "option_id": 0,
    "price": "",
    "price_type": "",
    "product_sku": "",
    "sku": "",
    "sort_order": 0,
    "title": "",
    "type": "",
    "values": [
      {
        "option_type_id": 0,
        "price": "",
        "price_type": "",
        "sku": "",
        "sort_order": 0,
        "title": ""
      }
    ]
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/options/:optionId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/products/options/:optionId" {:content-type :json
                                                                         :form-params {:option {:extension_attributes {:vertex_flex_field ""}
                                                                                                :file_extension ""
                                                                                                :image_size_x 0
                                                                                                :image_size_y 0
                                                                                                :is_require false
                                                                                                :max_characters 0
                                                                                                :option_id 0
                                                                                                :price ""
                                                                                                :price_type ""
                                                                                                :product_sku ""
                                                                                                :sku ""
                                                                                                :sort_order 0
                                                                                                :title ""
                                                                                                :type ""
                                                                                                :values [{:option_type_id 0
                                                                                                          :price ""
                                                                                                          :price_type ""
                                                                                                          :sku ""
                                                                                                          :sort_order 0
                                                                                                          :title ""}]}}})
require "http/client"

url = "{{baseUrl}}/V1/products/options/:optionId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/V1/products/options/:optionId"),
    Content = new StringContent("{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/options/:optionId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/options/:optionId"

	payload := strings.NewReader("{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/products/options/:optionId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 539

{
  "option": {
    "extension_attributes": {
      "vertex_flex_field": ""
    },
    "file_extension": "",
    "image_size_x": 0,
    "image_size_y": 0,
    "is_require": false,
    "max_characters": 0,
    "option_id": 0,
    "price": "",
    "price_type": "",
    "product_sku": "",
    "sku": "",
    "sort_order": 0,
    "title": "",
    "type": "",
    "values": [
      {
        "option_type_id": 0,
        "price": "",
        "price_type": "",
        "sku": "",
        "sort_order": 0,
        "title": ""
      }
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/products/options/:optionId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/options/:optionId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/options/:optionId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/products/options/:optionId")
  .header("content-type", "application/json")
  .body("{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}")
  .asString();
const data = JSON.stringify({
  option: {
    extension_attributes: {
      vertex_flex_field: ''
    },
    file_extension: '',
    image_size_x: 0,
    image_size_y: 0,
    is_require: false,
    max_characters: 0,
    option_id: 0,
    price: '',
    price_type: '',
    product_sku: '',
    sku: '',
    sort_order: 0,
    title: '',
    type: '',
    values: [
      {
        option_type_id: 0,
        price: '',
        price_type: '',
        sku: '',
        sort_order: 0,
        title: ''
      }
    ]
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/products/options/:optionId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/options/:optionId',
  headers: {'content-type': 'application/json'},
  data: {
    option: {
      extension_attributes: {vertex_flex_field: ''},
      file_extension: '',
      image_size_x: 0,
      image_size_y: 0,
      is_require: false,
      max_characters: 0,
      option_id: 0,
      price: '',
      price_type: '',
      product_sku: '',
      sku: '',
      sort_order: 0,
      title: '',
      type: '',
      values: [
        {
          option_type_id: 0,
          price: '',
          price_type: '',
          sku: '',
          sort_order: 0,
          title: ''
        }
      ]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/options/:optionId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"option":{"extension_attributes":{"vertex_flex_field":""},"file_extension":"","image_size_x":0,"image_size_y":0,"is_require":false,"max_characters":0,"option_id":0,"price":"","price_type":"","product_sku":"","sku":"","sort_order":0,"title":"","type":"","values":[{"option_type_id":0,"price":"","price_type":"","sku":"","sort_order":0,"title":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/options/:optionId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "option": {\n    "extension_attributes": {\n      "vertex_flex_field": ""\n    },\n    "file_extension": "",\n    "image_size_x": 0,\n    "image_size_y": 0,\n    "is_require": false,\n    "max_characters": 0,\n    "option_id": 0,\n    "price": "",\n    "price_type": "",\n    "product_sku": "",\n    "sku": "",\n    "sort_order": 0,\n    "title": "",\n    "type": "",\n    "values": [\n      {\n        "option_type_id": 0,\n        "price": "",\n        "price_type": "",\n        "sku": "",\n        "sort_order": 0,\n        "title": ""\n      }\n    ]\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/options/:optionId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/options/:optionId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  option: {
    extension_attributes: {vertex_flex_field: ''},
    file_extension: '',
    image_size_x: 0,
    image_size_y: 0,
    is_require: false,
    max_characters: 0,
    option_id: 0,
    price: '',
    price_type: '',
    product_sku: '',
    sku: '',
    sort_order: 0,
    title: '',
    type: '',
    values: [
      {
        option_type_id: 0,
        price: '',
        price_type: '',
        sku: '',
        sort_order: 0,
        title: ''
      }
    ]
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/options/:optionId',
  headers: {'content-type': 'application/json'},
  body: {
    option: {
      extension_attributes: {vertex_flex_field: ''},
      file_extension: '',
      image_size_x: 0,
      image_size_y: 0,
      is_require: false,
      max_characters: 0,
      option_id: 0,
      price: '',
      price_type: '',
      product_sku: '',
      sku: '',
      sort_order: 0,
      title: '',
      type: '',
      values: [
        {
          option_type_id: 0,
          price: '',
          price_type: '',
          sku: '',
          sort_order: 0,
          title: ''
        }
      ]
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/products/options/:optionId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  option: {
    extension_attributes: {
      vertex_flex_field: ''
    },
    file_extension: '',
    image_size_x: 0,
    image_size_y: 0,
    is_require: false,
    max_characters: 0,
    option_id: 0,
    price: '',
    price_type: '',
    product_sku: '',
    sku: '',
    sort_order: 0,
    title: '',
    type: '',
    values: [
      {
        option_type_id: 0,
        price: '',
        price_type: '',
        sku: '',
        sort_order: 0,
        title: ''
      }
    ]
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/options/:optionId',
  headers: {'content-type': 'application/json'},
  data: {
    option: {
      extension_attributes: {vertex_flex_field: ''},
      file_extension: '',
      image_size_x: 0,
      image_size_y: 0,
      is_require: false,
      max_characters: 0,
      option_id: 0,
      price: '',
      price_type: '',
      product_sku: '',
      sku: '',
      sort_order: 0,
      title: '',
      type: '',
      values: [
        {
          option_type_id: 0,
          price: '',
          price_type: '',
          sku: '',
          sort_order: 0,
          title: ''
        }
      ]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/options/:optionId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"option":{"extension_attributes":{"vertex_flex_field":""},"file_extension":"","image_size_x":0,"image_size_y":0,"is_require":false,"max_characters":0,"option_id":0,"price":"","price_type":"","product_sku":"","sku":"","sort_order":0,"title":"","type":"","values":[{"option_type_id":0,"price":"","price_type":"","sku":"","sort_order":0,"title":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"option": @{ @"extension_attributes": @{ @"vertex_flex_field": @"" }, @"file_extension": @"", @"image_size_x": @0, @"image_size_y": @0, @"is_require": @NO, @"max_characters": @0, @"option_id": @0, @"price": @"", @"price_type": @"", @"product_sku": @"", @"sku": @"", @"sort_order": @0, @"title": @"", @"type": @"", @"values": @[ @{ @"option_type_id": @0, @"price": @"", @"price_type": @"", @"sku": @"", @"sort_order": @0, @"title": @"" } ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/options/:optionId"]
                                                       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}}/V1/products/options/:optionId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/options/:optionId",
  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([
    'option' => [
        'extension_attributes' => [
                'vertex_flex_field' => ''
        ],
        'file_extension' => '',
        'image_size_x' => 0,
        'image_size_y' => 0,
        'is_require' => null,
        'max_characters' => 0,
        'option_id' => 0,
        'price' => '',
        'price_type' => '',
        'product_sku' => '',
        'sku' => '',
        'sort_order' => 0,
        'title' => '',
        'type' => '',
        'values' => [
                [
                                'option_type_id' => 0,
                                'price' => '',
                                'price_type' => '',
                                'sku' => '',
                                'sort_order' => 0,
                                'title' => ''
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/products/options/:optionId', [
  'body' => '{
  "option": {
    "extension_attributes": {
      "vertex_flex_field": ""
    },
    "file_extension": "",
    "image_size_x": 0,
    "image_size_y": 0,
    "is_require": false,
    "max_characters": 0,
    "option_id": 0,
    "price": "",
    "price_type": "",
    "product_sku": "",
    "sku": "",
    "sort_order": 0,
    "title": "",
    "type": "",
    "values": [
      {
        "option_type_id": 0,
        "price": "",
        "price_type": "",
        "sku": "",
        "sort_order": 0,
        "title": ""
      }
    ]
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/options/:optionId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'option' => [
    'extension_attributes' => [
        'vertex_flex_field' => ''
    ],
    'file_extension' => '',
    'image_size_x' => 0,
    'image_size_y' => 0,
    'is_require' => null,
    'max_characters' => 0,
    'option_id' => 0,
    'price' => '',
    'price_type' => '',
    'product_sku' => '',
    'sku' => '',
    'sort_order' => 0,
    'title' => '',
    'type' => '',
    'values' => [
        [
                'option_type_id' => 0,
                'price' => '',
                'price_type' => '',
                'sku' => '',
                'sort_order' => 0,
                'title' => ''
        ]
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'option' => [
    'extension_attributes' => [
        'vertex_flex_field' => ''
    ],
    'file_extension' => '',
    'image_size_x' => 0,
    'image_size_y' => 0,
    'is_require' => null,
    'max_characters' => 0,
    'option_id' => 0,
    'price' => '',
    'price_type' => '',
    'product_sku' => '',
    'sku' => '',
    'sort_order' => 0,
    'title' => '',
    'type' => '',
    'values' => [
        [
                'option_type_id' => 0,
                'price' => '',
                'price_type' => '',
                'sku' => '',
                'sort_order' => 0,
                'title' => ''
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/options/:optionId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/options/:optionId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "option": {
    "extension_attributes": {
      "vertex_flex_field": ""
    },
    "file_extension": "",
    "image_size_x": 0,
    "image_size_y": 0,
    "is_require": false,
    "max_characters": 0,
    "option_id": 0,
    "price": "",
    "price_type": "",
    "product_sku": "",
    "sku": "",
    "sort_order": 0,
    "title": "",
    "type": "",
    "values": [
      {
        "option_type_id": 0,
        "price": "",
        "price_type": "",
        "sku": "",
        "sort_order": 0,
        "title": ""
      }
    ]
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/options/:optionId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "option": {
    "extension_attributes": {
      "vertex_flex_field": ""
    },
    "file_extension": "",
    "image_size_x": 0,
    "image_size_y": 0,
    "is_require": false,
    "max_characters": 0,
    "option_id": 0,
    "price": "",
    "price_type": "",
    "product_sku": "",
    "sku": "",
    "sort_order": 0,
    "title": "",
    "type": "",
    "values": [
      {
        "option_type_id": 0,
        "price": "",
        "price_type": "",
        "sku": "",
        "sort_order": 0,
        "title": ""
      }
    ]
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/products/options/:optionId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/options/:optionId"

payload = { "option": {
        "extension_attributes": { "vertex_flex_field": "" },
        "file_extension": "",
        "image_size_x": 0,
        "image_size_y": 0,
        "is_require": False,
        "max_characters": 0,
        "option_id": 0,
        "price": "",
        "price_type": "",
        "product_sku": "",
        "sku": "",
        "sort_order": 0,
        "title": "",
        "type": "",
        "values": [
            {
                "option_type_id": 0,
                "price": "",
                "price_type": "",
                "sku": "",
                "sort_order": 0,
                "title": ""
            }
        ]
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/options/:optionId"

payload <- "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/options/:optionId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/V1/products/options/:optionId') do |req|
  req.body = "{\n  \"option\": {\n    \"extension_attributes\": {\n      \"vertex_flex_field\": \"\"\n    },\n    \"file_extension\": \"\",\n    \"image_size_x\": 0,\n    \"image_size_y\": 0,\n    \"is_require\": false,\n    \"max_characters\": 0,\n    \"option_id\": 0,\n    \"price\": \"\",\n    \"price_type\": \"\",\n    \"product_sku\": \"\",\n    \"sku\": \"\",\n    \"sort_order\": 0,\n    \"title\": \"\",\n    \"type\": \"\",\n    \"values\": [\n      {\n        \"option_type_id\": 0,\n        \"price\": \"\",\n        \"price_type\": \"\",\n        \"sku\": \"\",\n        \"sort_order\": 0,\n        \"title\": \"\"\n      }\n    ]\n  }\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/options/:optionId";

    let payload = json!({"option": json!({
            "extension_attributes": json!({"vertex_flex_field": ""}),
            "file_extension": "",
            "image_size_x": 0,
            "image_size_y": 0,
            "is_require": false,
            "max_characters": 0,
            "option_id": 0,
            "price": "",
            "price_type": "",
            "product_sku": "",
            "sku": "",
            "sort_order": 0,
            "title": "",
            "type": "",
            "values": (
                json!({
                    "option_type_id": 0,
                    "price": "",
                    "price_type": "",
                    "sku": "",
                    "sort_order": 0,
                    "title": ""
                })
            )
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/products/options/:optionId \
  --header 'content-type: application/json' \
  --data '{
  "option": {
    "extension_attributes": {
      "vertex_flex_field": ""
    },
    "file_extension": "",
    "image_size_x": 0,
    "image_size_y": 0,
    "is_require": false,
    "max_characters": 0,
    "option_id": 0,
    "price": "",
    "price_type": "",
    "product_sku": "",
    "sku": "",
    "sort_order": 0,
    "title": "",
    "type": "",
    "values": [
      {
        "option_type_id": 0,
        "price": "",
        "price_type": "",
        "sku": "",
        "sort_order": 0,
        "title": ""
      }
    ]
  }
}'
echo '{
  "option": {
    "extension_attributes": {
      "vertex_flex_field": ""
    },
    "file_extension": "",
    "image_size_x": 0,
    "image_size_y": 0,
    "is_require": false,
    "max_characters": 0,
    "option_id": 0,
    "price": "",
    "price_type": "",
    "product_sku": "",
    "sku": "",
    "sort_order": 0,
    "title": "",
    "type": "",
    "values": [
      {
        "option_type_id": 0,
        "price": "",
        "price_type": "",
        "sku": "",
        "sort_order": 0,
        "title": ""
      }
    ]
  }
}' |  \
  http PUT {{baseUrl}}/V1/products/options/:optionId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "option": {\n    "extension_attributes": {\n      "vertex_flex_field": ""\n    },\n    "file_extension": "",\n    "image_size_x": 0,\n    "image_size_y": 0,\n    "is_require": false,\n    "max_characters": 0,\n    "option_id": 0,\n    "price": "",\n    "price_type": "",\n    "product_sku": "",\n    "sku": "",\n    "sort_order": 0,\n    "title": "",\n    "type": "",\n    "values": [\n      {\n        "option_type_id": 0,\n        "price": "",\n        "price_type": "",\n        "sku": "",\n        "sort_order": 0,\n        "title": ""\n      }\n    ]\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/options/:optionId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["option": [
    "extension_attributes": ["vertex_flex_field": ""],
    "file_extension": "",
    "image_size_x": 0,
    "image_size_y": 0,
    "is_require": false,
    "max_characters": 0,
    "option_id": 0,
    "price": "",
    "price_type": "",
    "product_sku": "",
    "sku": "",
    "sort_order": 0,
    "title": "",
    "type": "",
    "values": [
      [
        "option_type_id": 0,
        "price": "",
        "price_type": "",
        "sku": "",
        "sort_order": 0,
        "title": ""
      ]
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/options/:optionId")! 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 products-options-types
{{baseUrl}}/V1/products/options/types
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/options/types");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/options/types")
require "http/client"

url = "{{baseUrl}}/V1/products/options/types"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/options/types"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/options/types");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/options/types"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/options/types HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/options/types")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/options/types"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/options/types")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/options/types")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/options/types');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/options/types'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/options/types';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/options/types',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/options/types")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/options/types',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/options/types'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/options/types');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/options/types'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/options/types';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/options/types"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/options/types" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/options/types",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/options/types');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/options/types');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/options/types');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/options/types' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/options/types' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/options/types")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/options/types"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/options/types"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/options/types")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/options/types') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/options/types";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/options/types
http GET {{baseUrl}}/V1/products/options/types
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/options/types
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/options/types")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET products-render-info
{{baseUrl}}/V1/products-render-info
QUERY PARAMS

storeId
currencyCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products-render-info?storeId=¤cyCode=");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products-render-info" {:query-params {:storeId ""
                                                                                  :currencyCode ""}})
require "http/client"

url = "{{baseUrl}}/V1/products-render-info?storeId=¤cyCode="

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products-render-info?storeId=¤cyCode="),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products-render-info?storeId=¤cyCode=");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products-render-info?storeId=¤cyCode="

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products-render-info?storeId=¤cyCode= HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products-render-info?storeId=¤cyCode=")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products-render-info?storeId=¤cyCode="))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products-render-info?storeId=¤cyCode=")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products-render-info?storeId=¤cyCode=")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products-render-info?storeId=¤cyCode=');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products-render-info',
  params: {storeId: '', currencyCode: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products-render-info?storeId=¤cyCode=';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products-render-info?storeId=¤cyCode=',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products-render-info?storeId=¤cyCode=")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products-render-info?storeId=¤cyCode=',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products-render-info',
  qs: {storeId: '', currencyCode: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products-render-info');

req.query({
  storeId: '',
  currencyCode: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/products-render-info',
  params: {storeId: '', currencyCode: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products-render-info?storeId=¤cyCode=';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products-render-info?storeId=¤cyCode="]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products-render-info?storeId=¤cyCode=" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products-render-info?storeId=¤cyCode=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products-render-info?storeId=¤cyCode=');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products-render-info');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'storeId' => '',
  'currencyCode' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products-render-info');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'storeId' => '',
  'currencyCode' => ''
]));

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products-render-info?storeId=¤cyCode=' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products-render-info?storeId=¤cyCode=' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products-render-info?storeId=¤cyCode=")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products-render-info"

querystring = {"storeId":"","currencyCode":""}

response = requests.get(url, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products-render-info"

queryString <- list(
  storeId = "",
  currencyCode = ""
)

response <- VERB("GET", url, query = queryString, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products-render-info?storeId=¤cyCode=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products-render-info') do |req|
  req.params['storeId'] = ''
  req.params['currencyCode'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products-render-info";

    let querystring = [
        ("storeId", ""),
        ("currencyCode", ""),
    ];

    let client = reqwest::Client::new();
    let response = client.get(url)
        .query(&querystring)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url '{{baseUrl}}/V1/products-render-info?storeId=¤cyCode='
http GET '{{baseUrl}}/V1/products-render-info?storeId=¤cyCode='
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/V1/products-render-info?storeId=¤cyCode='
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products-render-info?storeId=¤cyCode=")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST products-special-price
{{baseUrl}}/V1/products/special-price
BODY json

{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "price_from": "",
      "price_to": "",
      "sku": "",
      "store_id": 0
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/special-price");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/special-price" {:content-type :json
                                                                      :form-params {:prices [{:extension_attributes {}
                                                                                              :price ""
                                                                                              :price_from ""
                                                                                              :price_to ""
                                                                                              :sku ""
                                                                                              :store_id 0}]}})
require "http/client"

url = "{{baseUrl}}/V1/products/special-price"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\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}}/V1/products/special-price"),
    Content = new StringContent("{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\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}}/V1/products/special-price");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/special-price"

	payload := strings.NewReader("{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/special-price HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 169

{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "price_from": "",
      "price_to": "",
      "sku": "",
      "store_id": 0
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/special-price")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/special-price"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\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  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/special-price")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/special-price")
  .header("content-type", "application/json")
  .body("{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  prices: [
    {
      extension_attributes: {},
      price: '',
      price_from: '',
      price_to: '',
      sku: '',
      store_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}}/V1/products/special-price');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/special-price',
  headers: {'content-type': 'application/json'},
  data: {
    prices: [
      {
        extension_attributes: {},
        price: '',
        price_from: '',
        price_to: '',
        sku: '',
        store_id: 0
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/special-price';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"prices":[{"extension_attributes":{},"price":"","price_from":"","price_to":"","sku":"","store_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}}/V1/products/special-price',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "prices": [\n    {\n      "extension_attributes": {},\n      "price": "",\n      "price_from": "",\n      "price_to": "",\n      "sku": "",\n      "store_id": 0\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  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/special-price")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/special-price',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  prices: [
    {
      extension_attributes: {},
      price: '',
      price_from: '',
      price_to: '',
      sku: '',
      store_id: 0
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/special-price',
  headers: {'content-type': 'application/json'},
  body: {
    prices: [
      {
        extension_attributes: {},
        price: '',
        price_from: '',
        price_to: '',
        sku: '',
        store_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}}/V1/products/special-price');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  prices: [
    {
      extension_attributes: {},
      price: '',
      price_from: '',
      price_to: '',
      sku: '',
      store_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}}/V1/products/special-price',
  headers: {'content-type': 'application/json'},
  data: {
    prices: [
      {
        extension_attributes: {},
        price: '',
        price_from: '',
        price_to: '',
        sku: '',
        store_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}}/V1/products/special-price';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"prices":[{"extension_attributes":{},"price":"","price_from":"","price_to":"","sku":"","store_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 = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"prices": @[ @{ @"extension_attributes": @{  }, @"price": @"", @"price_from": @"", @"price_to": @"", @"sku": @"", @"store_id": @0 } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/special-price"]
                                                       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}}/V1/products/special-price" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/special-price",
  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([
    'prices' => [
        [
                'extension_attributes' => [
                                
                ],
                'price' => '',
                'price_from' => '',
                'price_to' => '',
                'sku' => '',
                'store_id' => 0
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/special-price', [
  'body' => '{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "price_from": "",
      "price_to": "",
      "sku": "",
      "store_id": 0
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/special-price');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'prices' => [
    [
        'extension_attributes' => [
                
        ],
        'price' => '',
        'price_from' => '',
        'price_to' => '',
        'sku' => '',
        'store_id' => 0
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'prices' => [
    [
        'extension_attributes' => [
                
        ],
        'price' => '',
        'price_from' => '',
        'price_to' => '',
        'sku' => '',
        'store_id' => 0
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/special-price');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/special-price' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "price_from": "",
      "price_to": "",
      "sku": "",
      "store_id": 0
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/special-price' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "price_from": "",
      "price_to": "",
      "sku": "",
      "store_id": 0
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/special-price", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/special-price"

payload = { "prices": [
        {
            "extension_attributes": {},
            "price": "",
            "price_from": "",
            "price_to": "",
            "sku": "",
            "store_id": 0
        }
    ] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/special-price"

payload <- "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/special-price")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\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/V1/products/special-price') do |req|
  req.body = "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\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}}/V1/products/special-price";

    let payload = json!({"prices": (
            json!({
                "extension_attributes": json!({}),
                "price": "",
                "price_from": "",
                "price_to": "",
                "sku": "",
                "store_id": 0
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/special-price \
  --header 'content-type: application/json' \
  --data '{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "price_from": "",
      "price_to": "",
      "sku": "",
      "store_id": 0
    }
  ]
}'
echo '{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "price_from": "",
      "price_to": "",
      "sku": "",
      "store_id": 0
    }
  ]
}' |  \
  http POST {{baseUrl}}/V1/products/special-price \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "prices": [\n    {\n      "extension_attributes": {},\n      "price": "",\n      "price_from": "",\n      "price_to": "",\n      "sku": "",\n      "store_id": 0\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/special-price
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["prices": [
    [
      "extension_attributes": [],
      "price": "",
      "price_from": "",
      "price_to": "",
      "sku": "",
      "store_id": 0
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/special-price")! 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 products-special-price-delete
{{baseUrl}}/V1/products/special-price-delete
BODY json

{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "price_from": "",
      "price_to": "",
      "sku": "",
      "store_id": 0
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/special-price-delete");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/special-price-delete" {:content-type :json
                                                                             :form-params {:prices [{:extension_attributes {}
                                                                                                     :price ""
                                                                                                     :price_from ""
                                                                                                     :price_to ""
                                                                                                     :sku ""
                                                                                                     :store_id 0}]}})
require "http/client"

url = "{{baseUrl}}/V1/products/special-price-delete"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\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}}/V1/products/special-price-delete"),
    Content = new StringContent("{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\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}}/V1/products/special-price-delete");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/special-price-delete"

	payload := strings.NewReader("{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/special-price-delete HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 169

{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "price_from": "",
      "price_to": "",
      "sku": "",
      "store_id": 0
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/special-price-delete")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/special-price-delete"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\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  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/special-price-delete")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/special-price-delete")
  .header("content-type", "application/json")
  .body("{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  prices: [
    {
      extension_attributes: {},
      price: '',
      price_from: '',
      price_to: '',
      sku: '',
      store_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}}/V1/products/special-price-delete');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/special-price-delete',
  headers: {'content-type': 'application/json'},
  data: {
    prices: [
      {
        extension_attributes: {},
        price: '',
        price_from: '',
        price_to: '',
        sku: '',
        store_id: 0
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/special-price-delete';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"prices":[{"extension_attributes":{},"price":"","price_from":"","price_to":"","sku":"","store_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}}/V1/products/special-price-delete',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "prices": [\n    {\n      "extension_attributes": {},\n      "price": "",\n      "price_from": "",\n      "price_to": "",\n      "sku": "",\n      "store_id": 0\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  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/special-price-delete")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/special-price-delete',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  prices: [
    {
      extension_attributes: {},
      price: '',
      price_from: '',
      price_to: '',
      sku: '',
      store_id: 0
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/special-price-delete',
  headers: {'content-type': 'application/json'},
  body: {
    prices: [
      {
        extension_attributes: {},
        price: '',
        price_from: '',
        price_to: '',
        sku: '',
        store_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}}/V1/products/special-price-delete');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  prices: [
    {
      extension_attributes: {},
      price: '',
      price_from: '',
      price_to: '',
      sku: '',
      store_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}}/V1/products/special-price-delete',
  headers: {'content-type': 'application/json'},
  data: {
    prices: [
      {
        extension_attributes: {},
        price: '',
        price_from: '',
        price_to: '',
        sku: '',
        store_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}}/V1/products/special-price-delete';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"prices":[{"extension_attributes":{},"price":"","price_from":"","price_to":"","sku":"","store_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 = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"prices": @[ @{ @"extension_attributes": @{  }, @"price": @"", @"price_from": @"", @"price_to": @"", @"sku": @"", @"store_id": @0 } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/special-price-delete"]
                                                       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}}/V1/products/special-price-delete" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/special-price-delete",
  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([
    'prices' => [
        [
                'extension_attributes' => [
                                
                ],
                'price' => '',
                'price_from' => '',
                'price_to' => '',
                'sku' => '',
                'store_id' => 0
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/special-price-delete', [
  'body' => '{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "price_from": "",
      "price_to": "",
      "sku": "",
      "store_id": 0
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/special-price-delete');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'prices' => [
    [
        'extension_attributes' => [
                
        ],
        'price' => '',
        'price_from' => '',
        'price_to' => '',
        'sku' => '',
        'store_id' => 0
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'prices' => [
    [
        'extension_attributes' => [
                
        ],
        'price' => '',
        'price_from' => '',
        'price_to' => '',
        'sku' => '',
        'store_id' => 0
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/special-price-delete');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/special-price-delete' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "price_from": "",
      "price_to": "",
      "sku": "",
      "store_id": 0
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/special-price-delete' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "price_from": "",
      "price_to": "",
      "sku": "",
      "store_id": 0
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/special-price-delete", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/special-price-delete"

payload = { "prices": [
        {
            "extension_attributes": {},
            "price": "",
            "price_from": "",
            "price_to": "",
            "sku": "",
            "store_id": 0
        }
    ] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/special-price-delete"

payload <- "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/special-price-delete")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\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/V1/products/special-price-delete') do |req|
  req.body = "{\n  \"prices\": [\n    {\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_from\": \"\",\n      \"price_to\": \"\",\n      \"sku\": \"\",\n      \"store_id\": 0\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}}/V1/products/special-price-delete";

    let payload = json!({"prices": (
            json!({
                "extension_attributes": json!({}),
                "price": "",
                "price_from": "",
                "price_to": "",
                "sku": "",
                "store_id": 0
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/special-price-delete \
  --header 'content-type: application/json' \
  --data '{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "price_from": "",
      "price_to": "",
      "sku": "",
      "store_id": 0
    }
  ]
}'
echo '{
  "prices": [
    {
      "extension_attributes": {},
      "price": "",
      "price_from": "",
      "price_to": "",
      "sku": "",
      "store_id": 0
    }
  ]
}' |  \
  http POST {{baseUrl}}/V1/products/special-price-delete \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "prices": [\n    {\n      "extension_attributes": {},\n      "price": "",\n      "price_from": "",\n      "price_to": "",\n      "sku": "",\n      "store_id": 0\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/special-price-delete
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["prices": [
    [
      "extension_attributes": [],
      "price": "",
      "price_from": "",
      "price_to": "",
      "sku": "",
      "store_id": 0
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/special-price-delete")! 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 products-special-price-information
{{baseUrl}}/V1/products/special-price-information
BODY json

{
  "skus": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/special-price-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"skus\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/special-price-information" {:content-type :json
                                                                                  :form-params {:skus []}})
require "http/client"

url = "{{baseUrl}}/V1/products/special-price-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"skus\": []\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}}/V1/products/special-price-information"),
    Content = new StringContent("{\n  \"skus\": []\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}}/V1/products/special-price-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"skus\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/special-price-information"

	payload := strings.NewReader("{\n  \"skus\": []\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/special-price-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 16

{
  "skus": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/special-price-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"skus\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/special-price-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"skus\": []\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  \"skus\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/special-price-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/special-price-information")
  .header("content-type", "application/json")
  .body("{\n  \"skus\": []\n}")
  .asString();
const data = JSON.stringify({
  skus: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/products/special-price-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/special-price-information',
  headers: {'content-type': 'application/json'},
  data: {skus: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/special-price-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"skus":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/special-price-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "skus": []\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"skus\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/special-price-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/special-price-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({skus: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/special-price-information',
  headers: {'content-type': 'application/json'},
  body: {skus: []},
  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}}/V1/products/special-price-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  skus: []
});

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}}/V1/products/special-price-information',
  headers: {'content-type': 'application/json'},
  data: {skus: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/special-price-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"skus":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"skus": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/special-price-information"]
                                                       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}}/V1/products/special-price-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"skus\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/special-price-information",
  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([
    'skus' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/special-price-information', [
  'body' => '{
  "skus": []
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/special-price-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'skus' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'skus' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/special-price-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/special-price-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "skus": []
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/special-price-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "skus": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"skus\": []\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/special-price-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/special-price-information"

payload = { "skus": [] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/special-price-information"

payload <- "{\n  \"skus\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/special-price-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"skus\": []\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/V1/products/special-price-information') do |req|
  req.body = "{\n  \"skus\": []\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/special-price-information";

    let payload = json!({"skus": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/special-price-information \
  --header 'content-type: application/json' \
  --data '{
  "skus": []
}'
echo '{
  "skus": []
}' |  \
  http POST {{baseUrl}}/V1/products/special-price-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "skus": []\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/special-price-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["skus": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/special-price-information")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT products-tier-prices (PUT)
{{baseUrl}}/V1/products/tier-prices
BODY json

{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/tier-prices");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/products/tier-prices" {:content-type :json
                                                                   :form-params {:prices [{:customer_group ""
                                                                                           :extension_attributes {}
                                                                                           :price ""
                                                                                           :price_type ""
                                                                                           :quantity ""
                                                                                           :sku ""
                                                                                           :website_id 0}]}})
require "http/client"

url = "{{baseUrl}}/V1/products/tier-prices"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/V1/products/tier-prices"),
    Content = new StringContent("{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\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}}/V1/products/tier-prices");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/tier-prices"

	payload := strings.NewReader("{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/products/tier-prices HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 199

{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/products/tier-prices")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/tier-prices"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\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  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/tier-prices")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/products/tier-prices")
  .header("content-type", "application/json")
  .body("{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  prices: [
    {
      customer_group: '',
      extension_attributes: {},
      price: '',
      price_type: '',
      quantity: '',
      sku: '',
      website_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}}/V1/products/tier-prices');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/tier-prices',
  headers: {'content-type': 'application/json'},
  data: {
    prices: [
      {
        customer_group: '',
        extension_attributes: {},
        price: '',
        price_type: '',
        quantity: '',
        sku: '',
        website_id: 0
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/tier-prices';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"prices":[{"customer_group":"","extension_attributes":{},"price":"","price_type":"","quantity":"","sku":"","website_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}}/V1/products/tier-prices',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "prices": [\n    {\n      "customer_group": "",\n      "extension_attributes": {},\n      "price": "",\n      "price_type": "",\n      "quantity": "",\n      "sku": "",\n      "website_id": 0\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  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/tier-prices")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/tier-prices',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  prices: [
    {
      customer_group: '',
      extension_attributes: {},
      price: '',
      price_type: '',
      quantity: '',
      sku: '',
      website_id: 0
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/products/tier-prices',
  headers: {'content-type': 'application/json'},
  body: {
    prices: [
      {
        customer_group: '',
        extension_attributes: {},
        price: '',
        price_type: '',
        quantity: '',
        sku: '',
        website_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}}/V1/products/tier-prices');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  prices: [
    {
      customer_group: '',
      extension_attributes: {},
      price: '',
      price_type: '',
      quantity: '',
      sku: '',
      website_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}}/V1/products/tier-prices',
  headers: {'content-type': 'application/json'},
  data: {
    prices: [
      {
        customer_group: '',
        extension_attributes: {},
        price: '',
        price_type: '',
        quantity: '',
        sku: '',
        website_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}}/V1/products/tier-prices';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"prices":[{"customer_group":"","extension_attributes":{},"price":"","price_type":"","quantity":"","sku":"","website_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 = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"prices": @[ @{ @"customer_group": @"", @"extension_attributes": @{  }, @"price": @"", @"price_type": @"", @"quantity": @"", @"sku": @"", @"website_id": @0 } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/tier-prices"]
                                                       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}}/V1/products/tier-prices" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/tier-prices",
  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([
    'prices' => [
        [
                'customer_group' => '',
                'extension_attributes' => [
                                
                ],
                'price' => '',
                'price_type' => '',
                'quantity' => '',
                'sku' => '',
                'website_id' => 0
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/products/tier-prices', [
  'body' => '{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/tier-prices');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'prices' => [
    [
        'customer_group' => '',
        'extension_attributes' => [
                
        ],
        'price' => '',
        'price_type' => '',
        'quantity' => '',
        'sku' => '',
        'website_id' => 0
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'prices' => [
    [
        'customer_group' => '',
        'extension_attributes' => [
                
        ],
        'price' => '',
        'price_type' => '',
        'quantity' => '',
        'sku' => '',
        'website_id' => 0
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/tier-prices');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/tier-prices' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/tier-prices' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/products/tier-prices", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/tier-prices"

payload = { "prices": [
        {
            "customer_group": "",
            "extension_attributes": {},
            "price": "",
            "price_type": "",
            "quantity": "",
            "sku": "",
            "website_id": 0
        }
    ] }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/tier-prices"

payload <- "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/tier-prices")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/V1/products/tier-prices') do |req|
  req.body = "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/tier-prices";

    let payload = json!({"prices": (
            json!({
                "customer_group": "",
                "extension_attributes": json!({}),
                "price": "",
                "price_type": "",
                "quantity": "",
                "sku": "",
                "website_id": 0
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/products/tier-prices \
  --header 'content-type: application/json' \
  --data '{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}'
echo '{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}' |  \
  http PUT {{baseUrl}}/V1/products/tier-prices \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "prices": [\n    {\n      "customer_group": "",\n      "extension_attributes": {},\n      "price": "",\n      "price_type": "",\n      "quantity": "",\n      "sku": "",\n      "website_id": 0\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/tier-prices
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["prices": [
    [
      "customer_group": "",
      "extension_attributes": [],
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/tier-prices")! 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 products-tier-prices
{{baseUrl}}/V1/products/tier-prices
BODY json

{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/tier-prices");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/tier-prices" {:content-type :json
                                                                    :form-params {:prices [{:customer_group ""
                                                                                            :extension_attributes {}
                                                                                            :price ""
                                                                                            :price_type ""
                                                                                            :quantity ""
                                                                                            :sku ""
                                                                                            :website_id 0}]}})
require "http/client"

url = "{{baseUrl}}/V1/products/tier-prices"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\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}}/V1/products/tier-prices"),
    Content = new StringContent("{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\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}}/V1/products/tier-prices");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/tier-prices"

	payload := strings.NewReader("{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/tier-prices HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 199

{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/tier-prices")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/tier-prices"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\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  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/tier-prices")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/tier-prices")
  .header("content-type", "application/json")
  .body("{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  prices: [
    {
      customer_group: '',
      extension_attributes: {},
      price: '',
      price_type: '',
      quantity: '',
      sku: '',
      website_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}}/V1/products/tier-prices');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/tier-prices',
  headers: {'content-type': 'application/json'},
  data: {
    prices: [
      {
        customer_group: '',
        extension_attributes: {},
        price: '',
        price_type: '',
        quantity: '',
        sku: '',
        website_id: 0
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/tier-prices';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"prices":[{"customer_group":"","extension_attributes":{},"price":"","price_type":"","quantity":"","sku":"","website_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}}/V1/products/tier-prices',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "prices": [\n    {\n      "customer_group": "",\n      "extension_attributes": {},\n      "price": "",\n      "price_type": "",\n      "quantity": "",\n      "sku": "",\n      "website_id": 0\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  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/tier-prices")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/tier-prices',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  prices: [
    {
      customer_group: '',
      extension_attributes: {},
      price: '',
      price_type: '',
      quantity: '',
      sku: '',
      website_id: 0
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/tier-prices',
  headers: {'content-type': 'application/json'},
  body: {
    prices: [
      {
        customer_group: '',
        extension_attributes: {},
        price: '',
        price_type: '',
        quantity: '',
        sku: '',
        website_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}}/V1/products/tier-prices');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  prices: [
    {
      customer_group: '',
      extension_attributes: {},
      price: '',
      price_type: '',
      quantity: '',
      sku: '',
      website_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}}/V1/products/tier-prices',
  headers: {'content-type': 'application/json'},
  data: {
    prices: [
      {
        customer_group: '',
        extension_attributes: {},
        price: '',
        price_type: '',
        quantity: '',
        sku: '',
        website_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}}/V1/products/tier-prices';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"prices":[{"customer_group":"","extension_attributes":{},"price":"","price_type":"","quantity":"","sku":"","website_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 = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"prices": @[ @{ @"customer_group": @"", @"extension_attributes": @{  }, @"price": @"", @"price_type": @"", @"quantity": @"", @"sku": @"", @"website_id": @0 } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/tier-prices"]
                                                       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}}/V1/products/tier-prices" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/tier-prices",
  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([
    'prices' => [
        [
                'customer_group' => '',
                'extension_attributes' => [
                                
                ],
                'price' => '',
                'price_type' => '',
                'quantity' => '',
                'sku' => '',
                'website_id' => 0
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/tier-prices', [
  'body' => '{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/tier-prices');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'prices' => [
    [
        'customer_group' => '',
        'extension_attributes' => [
                
        ],
        'price' => '',
        'price_type' => '',
        'quantity' => '',
        'sku' => '',
        'website_id' => 0
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'prices' => [
    [
        'customer_group' => '',
        'extension_attributes' => [
                
        ],
        'price' => '',
        'price_type' => '',
        'quantity' => '',
        'sku' => '',
        'website_id' => 0
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/tier-prices');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/tier-prices' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/tier-prices' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/tier-prices", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/tier-prices"

payload = { "prices": [
        {
            "customer_group": "",
            "extension_attributes": {},
            "price": "",
            "price_type": "",
            "quantity": "",
            "sku": "",
            "website_id": 0
        }
    ] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/tier-prices"

payload <- "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/tier-prices")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\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/V1/products/tier-prices') do |req|
  req.body = "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\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}}/V1/products/tier-prices";

    let payload = json!({"prices": (
            json!({
                "customer_group": "",
                "extension_attributes": json!({}),
                "price": "",
                "price_type": "",
                "quantity": "",
                "sku": "",
                "website_id": 0
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/tier-prices \
  --header 'content-type: application/json' \
  --data '{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}'
echo '{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}' |  \
  http POST {{baseUrl}}/V1/products/tier-prices \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "prices": [\n    {\n      "customer_group": "",\n      "extension_attributes": {},\n      "price": "",\n      "price_type": "",\n      "quantity": "",\n      "sku": "",\n      "website_id": 0\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/tier-prices
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["prices": [
    [
      "customer_group": "",
      "extension_attributes": [],
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/tier-prices")! 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 products-tier-prices-delete
{{baseUrl}}/V1/products/tier-prices-delete
BODY json

{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/tier-prices-delete");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/tier-prices-delete" {:content-type :json
                                                                           :form-params {:prices [{:customer_group ""
                                                                                                   :extension_attributes {}
                                                                                                   :price ""
                                                                                                   :price_type ""
                                                                                                   :quantity ""
                                                                                                   :sku ""
                                                                                                   :website_id 0}]}})
require "http/client"

url = "{{baseUrl}}/V1/products/tier-prices-delete"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\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}}/V1/products/tier-prices-delete"),
    Content = new StringContent("{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\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}}/V1/products/tier-prices-delete");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/tier-prices-delete"

	payload := strings.NewReader("{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/tier-prices-delete HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 199

{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/tier-prices-delete")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/tier-prices-delete"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\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  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/tier-prices-delete")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/tier-prices-delete")
  .header("content-type", "application/json")
  .body("{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  prices: [
    {
      customer_group: '',
      extension_attributes: {},
      price: '',
      price_type: '',
      quantity: '',
      sku: '',
      website_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}}/V1/products/tier-prices-delete');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/tier-prices-delete',
  headers: {'content-type': 'application/json'},
  data: {
    prices: [
      {
        customer_group: '',
        extension_attributes: {},
        price: '',
        price_type: '',
        quantity: '',
        sku: '',
        website_id: 0
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/tier-prices-delete';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"prices":[{"customer_group":"","extension_attributes":{},"price":"","price_type":"","quantity":"","sku":"","website_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}}/V1/products/tier-prices-delete',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "prices": [\n    {\n      "customer_group": "",\n      "extension_attributes": {},\n      "price": "",\n      "price_type": "",\n      "quantity": "",\n      "sku": "",\n      "website_id": 0\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  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/tier-prices-delete")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/tier-prices-delete',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  prices: [
    {
      customer_group: '',
      extension_attributes: {},
      price: '',
      price_type: '',
      quantity: '',
      sku: '',
      website_id: 0
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/tier-prices-delete',
  headers: {'content-type': 'application/json'},
  body: {
    prices: [
      {
        customer_group: '',
        extension_attributes: {},
        price: '',
        price_type: '',
        quantity: '',
        sku: '',
        website_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}}/V1/products/tier-prices-delete');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  prices: [
    {
      customer_group: '',
      extension_attributes: {},
      price: '',
      price_type: '',
      quantity: '',
      sku: '',
      website_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}}/V1/products/tier-prices-delete',
  headers: {'content-type': 'application/json'},
  data: {
    prices: [
      {
        customer_group: '',
        extension_attributes: {},
        price: '',
        price_type: '',
        quantity: '',
        sku: '',
        website_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}}/V1/products/tier-prices-delete';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"prices":[{"customer_group":"","extension_attributes":{},"price":"","price_type":"","quantity":"","sku":"","website_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 = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"prices": @[ @{ @"customer_group": @"", @"extension_attributes": @{  }, @"price": @"", @"price_type": @"", @"quantity": @"", @"sku": @"", @"website_id": @0 } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/tier-prices-delete"]
                                                       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}}/V1/products/tier-prices-delete" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/tier-prices-delete",
  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([
    'prices' => [
        [
                'customer_group' => '',
                'extension_attributes' => [
                                
                ],
                'price' => '',
                'price_type' => '',
                'quantity' => '',
                'sku' => '',
                'website_id' => 0
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/tier-prices-delete', [
  'body' => '{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/tier-prices-delete');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'prices' => [
    [
        'customer_group' => '',
        'extension_attributes' => [
                
        ],
        'price' => '',
        'price_type' => '',
        'quantity' => '',
        'sku' => '',
        'website_id' => 0
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'prices' => [
    [
        'customer_group' => '',
        'extension_attributes' => [
                
        ],
        'price' => '',
        'price_type' => '',
        'quantity' => '',
        'sku' => '',
        'website_id' => 0
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/tier-prices-delete');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/tier-prices-delete' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/tier-prices-delete' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/tier-prices-delete", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/tier-prices-delete"

payload = { "prices": [
        {
            "customer_group": "",
            "extension_attributes": {},
            "price": "",
            "price_type": "",
            "quantity": "",
            "sku": "",
            "website_id": 0
        }
    ] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/tier-prices-delete"

payload <- "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/tier-prices-delete")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\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/V1/products/tier-prices-delete') do |req|
  req.body = "{\n  \"prices\": [\n    {\n      \"customer_group\": \"\",\n      \"extension_attributes\": {},\n      \"price\": \"\",\n      \"price_type\": \"\",\n      \"quantity\": \"\",\n      \"sku\": \"\",\n      \"website_id\": 0\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}}/V1/products/tier-prices-delete";

    let payload = json!({"prices": (
            json!({
                "customer_group": "",
                "extension_attributes": json!({}),
                "price": "",
                "price_type": "",
                "quantity": "",
                "sku": "",
                "website_id": 0
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/tier-prices-delete \
  --header 'content-type: application/json' \
  --data '{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}'
echo '{
  "prices": [
    {
      "customer_group": "",
      "extension_attributes": {},
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    }
  ]
}' |  \
  http POST {{baseUrl}}/V1/products/tier-prices-delete \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "prices": [\n    {\n      "customer_group": "",\n      "extension_attributes": {},\n      "price": "",\n      "price_type": "",\n      "quantity": "",\n      "sku": "",\n      "website_id": 0\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/tier-prices-delete
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["prices": [
    [
      "customer_group": "",
      "extension_attributes": [],
      "price": "",
      "price_type": "",
      "quantity": "",
      "sku": "",
      "website_id": 0
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/tier-prices-delete")! 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 products-tier-prices-information
{{baseUrl}}/V1/products/tier-prices-information
BODY json

{
  "skus": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/tier-prices-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"skus\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/products/tier-prices-information" {:content-type :json
                                                                                :form-params {:skus []}})
require "http/client"

url = "{{baseUrl}}/V1/products/tier-prices-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"skus\": []\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}}/V1/products/tier-prices-information"),
    Content = new StringContent("{\n  \"skus\": []\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}}/V1/products/tier-prices-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"skus\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/tier-prices-information"

	payload := strings.NewReader("{\n  \"skus\": []\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/products/tier-prices-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 16

{
  "skus": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/products/tier-prices-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"skus\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/tier-prices-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"skus\": []\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  \"skus\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/tier-prices-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/products/tier-prices-information")
  .header("content-type", "application/json")
  .body("{\n  \"skus\": []\n}")
  .asString();
const data = JSON.stringify({
  skus: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/products/tier-prices-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/tier-prices-information',
  headers: {'content-type': 'application/json'},
  data: {skus: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/tier-prices-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"skus":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/tier-prices-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "skus": []\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"skus\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/tier-prices-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/tier-prices-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({skus: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/products/tier-prices-information',
  headers: {'content-type': 'application/json'},
  body: {skus: []},
  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}}/V1/products/tier-prices-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  skus: []
});

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}}/V1/products/tier-prices-information',
  headers: {'content-type': 'application/json'},
  data: {skus: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/tier-prices-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"skus":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"skus": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/tier-prices-information"]
                                                       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}}/V1/products/tier-prices-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"skus\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/tier-prices-information",
  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([
    'skus' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/products/tier-prices-information', [
  'body' => '{
  "skus": []
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/tier-prices-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'skus' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'skus' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/products/tier-prices-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/tier-prices-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "skus": []
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/tier-prices-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "skus": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"skus\": []\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/products/tier-prices-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/tier-prices-information"

payload = { "skus": [] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/tier-prices-information"

payload <- "{\n  \"skus\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/tier-prices-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"skus\": []\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/V1/products/tier-prices-information') do |req|
  req.body = "{\n  \"skus\": []\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/tier-prices-information";

    let payload = json!({"skus": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/products/tier-prices-information \
  --header 'content-type: application/json' \
  --data '{
  "skus": []
}'
echo '{
  "skus": []
}' |  \
  http POST {{baseUrl}}/V1/products/tier-prices-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "skus": []\n}' \
  --output-document \
  - {{baseUrl}}/V1/products/tier-prices-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["skus": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/tier-prices-information")! 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 products-types
{{baseUrl}}/V1/products/types
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/products/types");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/products/types")
require "http/client"

url = "{{baseUrl}}/V1/products/types"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/products/types"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/products/types");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/products/types"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/products/types HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/products/types")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/products/types"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/products/types")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/products/types")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/products/types');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/types'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/products/types';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/products/types',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/products/types")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/products/types',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/types'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/products/types');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/products/types'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/products/types';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/products/types"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/products/types" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/products/types",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/products/types');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/products/types');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/products/types');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/products/types' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/products/types' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/products/types")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/products/types"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/products/types"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/products/types")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/products/types') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/products/types";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/products/types
http GET {{baseUrl}}/V1/products/types
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/products/types
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/products/types")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST requisition_lists
{{baseUrl}}/V1/requisition_lists
BODY json

{
  "requisitionList": {
    "customer_id": 0,
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "items": [
      {
        "added_at": "",
        "extension_attributes": {},
        "id": 0,
        "options": [],
        "qty": "",
        "requisition_list_id": 0,
        "sku": "",
        "store_id": 0
      }
    ],
    "name": "",
    "updated_at": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/requisition_lists");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"requisitionList\": {\n    \"customer_id\": 0,\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"items\": [\n      {\n        \"added_at\": \"\",\n        \"extension_attributes\": {},\n        \"id\": 0,\n        \"options\": [],\n        \"qty\": \"\",\n        \"requisition_list_id\": 0,\n        \"sku\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"name\": \"\",\n    \"updated_at\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/requisition_lists" {:content-type :json
                                                                 :form-params {:requisitionList {:customer_id 0
                                                                                                 :description ""
                                                                                                 :extension_attributes {}
                                                                                                 :id 0
                                                                                                 :items [{:added_at ""
                                                                                                          :extension_attributes {}
                                                                                                          :id 0
                                                                                                          :options []
                                                                                                          :qty ""
                                                                                                          :requisition_list_id 0
                                                                                                          :sku ""
                                                                                                          :store_id 0}]
                                                                                                 :name ""
                                                                                                 :updated_at ""}}})
require "http/client"

url = "{{baseUrl}}/V1/requisition_lists"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"requisitionList\": {\n    \"customer_id\": 0,\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"items\": [\n      {\n        \"added_at\": \"\",\n        \"extension_attributes\": {},\n        \"id\": 0,\n        \"options\": [],\n        \"qty\": \"\",\n        \"requisition_list_id\": 0,\n        \"sku\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"name\": \"\",\n    \"updated_at\": \"\"\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}}/V1/requisition_lists"),
    Content = new StringContent("{\n  \"requisitionList\": {\n    \"customer_id\": 0,\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"items\": [\n      {\n        \"added_at\": \"\",\n        \"extension_attributes\": {},\n        \"id\": 0,\n        \"options\": [],\n        \"qty\": \"\",\n        \"requisition_list_id\": 0,\n        \"sku\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"name\": \"\",\n    \"updated_at\": \"\"\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}}/V1/requisition_lists");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"requisitionList\": {\n    \"customer_id\": 0,\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"items\": [\n      {\n        \"added_at\": \"\",\n        \"extension_attributes\": {},\n        \"id\": 0,\n        \"options\": [],\n        \"qty\": \"\",\n        \"requisition_list_id\": 0,\n        \"sku\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"name\": \"\",\n    \"updated_at\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/requisition_lists"

	payload := strings.NewReader("{\n  \"requisitionList\": {\n    \"customer_id\": 0,\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"items\": [\n      {\n        \"added_at\": \"\",\n        \"extension_attributes\": {},\n        \"id\": 0,\n        \"options\": [],\n        \"qty\": \"\",\n        \"requisition_list_id\": 0,\n        \"sku\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"name\": \"\",\n    \"updated_at\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/requisition_lists HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 389

{
  "requisitionList": {
    "customer_id": 0,
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "items": [
      {
        "added_at": "",
        "extension_attributes": {},
        "id": 0,
        "options": [],
        "qty": "",
        "requisition_list_id": 0,
        "sku": "",
        "store_id": 0
      }
    ],
    "name": "",
    "updated_at": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/requisition_lists")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"requisitionList\": {\n    \"customer_id\": 0,\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"items\": [\n      {\n        \"added_at\": \"\",\n        \"extension_attributes\": {},\n        \"id\": 0,\n        \"options\": [],\n        \"qty\": \"\",\n        \"requisition_list_id\": 0,\n        \"sku\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"name\": \"\",\n    \"updated_at\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/requisition_lists"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"requisitionList\": {\n    \"customer_id\": 0,\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"items\": [\n      {\n        \"added_at\": \"\",\n        \"extension_attributes\": {},\n        \"id\": 0,\n        \"options\": [],\n        \"qty\": \"\",\n        \"requisition_list_id\": 0,\n        \"sku\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"name\": \"\",\n    \"updated_at\": \"\"\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  \"requisitionList\": {\n    \"customer_id\": 0,\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"items\": [\n      {\n        \"added_at\": \"\",\n        \"extension_attributes\": {},\n        \"id\": 0,\n        \"options\": [],\n        \"qty\": \"\",\n        \"requisition_list_id\": 0,\n        \"sku\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"name\": \"\",\n    \"updated_at\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/requisition_lists")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/requisition_lists")
  .header("content-type", "application/json")
  .body("{\n  \"requisitionList\": {\n    \"customer_id\": 0,\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"items\": [\n      {\n        \"added_at\": \"\",\n        \"extension_attributes\": {},\n        \"id\": 0,\n        \"options\": [],\n        \"qty\": \"\",\n        \"requisition_list_id\": 0,\n        \"sku\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"name\": \"\",\n    \"updated_at\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  requisitionList: {
    customer_id: 0,
    description: '',
    extension_attributes: {},
    id: 0,
    items: [
      {
        added_at: '',
        extension_attributes: {},
        id: 0,
        options: [],
        qty: '',
        requisition_list_id: 0,
        sku: '',
        store_id: 0
      }
    ],
    name: '',
    updated_at: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/requisition_lists');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/requisition_lists',
  headers: {'content-type': 'application/json'},
  data: {
    requisitionList: {
      customer_id: 0,
      description: '',
      extension_attributes: {},
      id: 0,
      items: [
        {
          added_at: '',
          extension_attributes: {},
          id: 0,
          options: [],
          qty: '',
          requisition_list_id: 0,
          sku: '',
          store_id: 0
        }
      ],
      name: '',
      updated_at: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/requisition_lists';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"requisitionList":{"customer_id":0,"description":"","extension_attributes":{},"id":0,"items":[{"added_at":"","extension_attributes":{},"id":0,"options":[],"qty":"","requisition_list_id":0,"sku":"","store_id":0}],"name":"","updated_at":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/requisition_lists',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "requisitionList": {\n    "customer_id": 0,\n    "description": "",\n    "extension_attributes": {},\n    "id": 0,\n    "items": [\n      {\n        "added_at": "",\n        "extension_attributes": {},\n        "id": 0,\n        "options": [],\n        "qty": "",\n        "requisition_list_id": 0,\n        "sku": "",\n        "store_id": 0\n      }\n    ],\n    "name": "",\n    "updated_at": ""\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  \"requisitionList\": {\n    \"customer_id\": 0,\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"items\": [\n      {\n        \"added_at\": \"\",\n        \"extension_attributes\": {},\n        \"id\": 0,\n        \"options\": [],\n        \"qty\": \"\",\n        \"requisition_list_id\": 0,\n        \"sku\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"name\": \"\",\n    \"updated_at\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/requisition_lists")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/requisition_lists',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  requisitionList: {
    customer_id: 0,
    description: '',
    extension_attributes: {},
    id: 0,
    items: [
      {
        added_at: '',
        extension_attributes: {},
        id: 0,
        options: [],
        qty: '',
        requisition_list_id: 0,
        sku: '',
        store_id: 0
      }
    ],
    name: '',
    updated_at: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/requisition_lists',
  headers: {'content-type': 'application/json'},
  body: {
    requisitionList: {
      customer_id: 0,
      description: '',
      extension_attributes: {},
      id: 0,
      items: [
        {
          added_at: '',
          extension_attributes: {},
          id: 0,
          options: [],
          qty: '',
          requisition_list_id: 0,
          sku: '',
          store_id: 0
        }
      ],
      name: '',
      updated_at: ''
    }
  },
  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}}/V1/requisition_lists');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  requisitionList: {
    customer_id: 0,
    description: '',
    extension_attributes: {},
    id: 0,
    items: [
      {
        added_at: '',
        extension_attributes: {},
        id: 0,
        options: [],
        qty: '',
        requisition_list_id: 0,
        sku: '',
        store_id: 0
      }
    ],
    name: '',
    updated_at: ''
  }
});

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}}/V1/requisition_lists',
  headers: {'content-type': 'application/json'},
  data: {
    requisitionList: {
      customer_id: 0,
      description: '',
      extension_attributes: {},
      id: 0,
      items: [
        {
          added_at: '',
          extension_attributes: {},
          id: 0,
          options: [],
          qty: '',
          requisition_list_id: 0,
          sku: '',
          store_id: 0
        }
      ],
      name: '',
      updated_at: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/requisition_lists';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"requisitionList":{"customer_id":0,"description":"","extension_attributes":{},"id":0,"items":[{"added_at":"","extension_attributes":{},"id":0,"options":[],"qty":"","requisition_list_id":0,"sku":"","store_id":0}],"name":"","updated_at":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"requisitionList": @{ @"customer_id": @0, @"description": @"", @"extension_attributes": @{  }, @"id": @0, @"items": @[ @{ @"added_at": @"", @"extension_attributes": @{  }, @"id": @0, @"options": @[  ], @"qty": @"", @"requisition_list_id": @0, @"sku": @"", @"store_id": @0 } ], @"name": @"", @"updated_at": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/requisition_lists"]
                                                       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}}/V1/requisition_lists" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"requisitionList\": {\n    \"customer_id\": 0,\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"items\": [\n      {\n        \"added_at\": \"\",\n        \"extension_attributes\": {},\n        \"id\": 0,\n        \"options\": [],\n        \"qty\": \"\",\n        \"requisition_list_id\": 0,\n        \"sku\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"name\": \"\",\n    \"updated_at\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/requisition_lists",
  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([
    'requisitionList' => [
        'customer_id' => 0,
        'description' => '',
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'items' => [
                [
                                'added_at' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'id' => 0,
                                'options' => [
                                                                
                                ],
                                'qty' => '',
                                'requisition_list_id' => 0,
                                'sku' => '',
                                'store_id' => 0
                ]
        ],
        'name' => '',
        'updated_at' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/requisition_lists', [
  'body' => '{
  "requisitionList": {
    "customer_id": 0,
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "items": [
      {
        "added_at": "",
        "extension_attributes": {},
        "id": 0,
        "options": [],
        "qty": "",
        "requisition_list_id": 0,
        "sku": "",
        "store_id": 0
      }
    ],
    "name": "",
    "updated_at": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/requisition_lists');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'requisitionList' => [
    'customer_id' => 0,
    'description' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'items' => [
        [
                'added_at' => '',
                'extension_attributes' => [
                                
                ],
                'id' => 0,
                'options' => [
                                
                ],
                'qty' => '',
                'requisition_list_id' => 0,
                'sku' => '',
                'store_id' => 0
        ]
    ],
    'name' => '',
    'updated_at' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'requisitionList' => [
    'customer_id' => 0,
    'description' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'items' => [
        [
                'added_at' => '',
                'extension_attributes' => [
                                
                ],
                'id' => 0,
                'options' => [
                                
                ],
                'qty' => '',
                'requisition_list_id' => 0,
                'sku' => '',
                'store_id' => 0
        ]
    ],
    'name' => '',
    'updated_at' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/requisition_lists');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/requisition_lists' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "requisitionList": {
    "customer_id": 0,
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "items": [
      {
        "added_at": "",
        "extension_attributes": {},
        "id": 0,
        "options": [],
        "qty": "",
        "requisition_list_id": 0,
        "sku": "",
        "store_id": 0
      }
    ],
    "name": "",
    "updated_at": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/requisition_lists' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "requisitionList": {
    "customer_id": 0,
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "items": [
      {
        "added_at": "",
        "extension_attributes": {},
        "id": 0,
        "options": [],
        "qty": "",
        "requisition_list_id": 0,
        "sku": "",
        "store_id": 0
      }
    ],
    "name": "",
    "updated_at": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"requisitionList\": {\n    \"customer_id\": 0,\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"items\": [\n      {\n        \"added_at\": \"\",\n        \"extension_attributes\": {},\n        \"id\": 0,\n        \"options\": [],\n        \"qty\": \"\",\n        \"requisition_list_id\": 0,\n        \"sku\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"name\": \"\",\n    \"updated_at\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/requisition_lists", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/requisition_lists"

payload = { "requisitionList": {
        "customer_id": 0,
        "description": "",
        "extension_attributes": {},
        "id": 0,
        "items": [
            {
                "added_at": "",
                "extension_attributes": {},
                "id": 0,
                "options": [],
                "qty": "",
                "requisition_list_id": 0,
                "sku": "",
                "store_id": 0
            }
        ],
        "name": "",
        "updated_at": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/requisition_lists"

payload <- "{\n  \"requisitionList\": {\n    \"customer_id\": 0,\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"items\": [\n      {\n        \"added_at\": \"\",\n        \"extension_attributes\": {},\n        \"id\": 0,\n        \"options\": [],\n        \"qty\": \"\",\n        \"requisition_list_id\": 0,\n        \"sku\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"name\": \"\",\n    \"updated_at\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/requisition_lists")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"requisitionList\": {\n    \"customer_id\": 0,\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"items\": [\n      {\n        \"added_at\": \"\",\n        \"extension_attributes\": {},\n        \"id\": 0,\n        \"options\": [],\n        \"qty\": \"\",\n        \"requisition_list_id\": 0,\n        \"sku\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"name\": \"\",\n    \"updated_at\": \"\"\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/V1/requisition_lists') do |req|
  req.body = "{\n  \"requisitionList\": {\n    \"customer_id\": 0,\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"items\": [\n      {\n        \"added_at\": \"\",\n        \"extension_attributes\": {},\n        \"id\": 0,\n        \"options\": [],\n        \"qty\": \"\",\n        \"requisition_list_id\": 0,\n        \"sku\": \"\",\n        \"store_id\": 0\n      }\n    ],\n    \"name\": \"\",\n    \"updated_at\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/requisition_lists";

    let payload = json!({"requisitionList": json!({
            "customer_id": 0,
            "description": "",
            "extension_attributes": json!({}),
            "id": 0,
            "items": (
                json!({
                    "added_at": "",
                    "extension_attributes": json!({}),
                    "id": 0,
                    "options": (),
                    "qty": "",
                    "requisition_list_id": 0,
                    "sku": "",
                    "store_id": 0
                })
            ),
            "name": "",
            "updated_at": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/requisition_lists \
  --header 'content-type: application/json' \
  --data '{
  "requisitionList": {
    "customer_id": 0,
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "items": [
      {
        "added_at": "",
        "extension_attributes": {},
        "id": 0,
        "options": [],
        "qty": "",
        "requisition_list_id": 0,
        "sku": "",
        "store_id": 0
      }
    ],
    "name": "",
    "updated_at": ""
  }
}'
echo '{
  "requisitionList": {
    "customer_id": 0,
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "items": [
      {
        "added_at": "",
        "extension_attributes": {},
        "id": 0,
        "options": [],
        "qty": "",
        "requisition_list_id": 0,
        "sku": "",
        "store_id": 0
      }
    ],
    "name": "",
    "updated_at": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/requisition_lists \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "requisitionList": {\n    "customer_id": 0,\n    "description": "",\n    "extension_attributes": {},\n    "id": 0,\n    "items": [\n      {\n        "added_at": "",\n        "extension_attributes": {},\n        "id": 0,\n        "options": [],\n        "qty": "",\n        "requisition_list_id": 0,\n        "sku": "",\n        "store_id": 0\n      }\n    ],\n    "name": "",\n    "updated_at": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/requisition_lists
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["requisitionList": [
    "customer_id": 0,
    "description": "",
    "extension_attributes": [],
    "id": 0,
    "items": [
      [
        "added_at": "",
        "extension_attributes": [],
        "id": 0,
        "options": [],
        "qty": "",
        "requisition_list_id": 0,
        "sku": "",
        "store_id": 0
      ]
    ],
    "name": "",
    "updated_at": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/requisition_lists")! 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 returns (POST)
{{baseUrl}}/V1/returns
BODY json

{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/returns");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/returns" {:content-type :json
                                                       :form-params {:rmaDataObject {:comments [{:admin false
                                                                                                 :comment ""
                                                                                                 :created_at ""
                                                                                                 :custom_attributes [{:attribute_code ""
                                                                                                                      :value ""}]
                                                                                                 :customer_notified false
                                                                                                 :entity_id 0
                                                                                                 :extension_attributes {}
                                                                                                 :rma_entity_id 0
                                                                                                 :status ""
                                                                                                 :visible_on_front false}]
                                                                                     :custom_attributes [{}]
                                                                                     :customer_custom_email ""
                                                                                     :customer_id 0
                                                                                     :date_requested ""
                                                                                     :entity_id 0
                                                                                     :extension_attributes {}
                                                                                     :increment_id ""
                                                                                     :items [{:condition ""
                                                                                              :entity_id 0
                                                                                              :extension_attributes {}
                                                                                              :order_item_id 0
                                                                                              :qty_approved 0
                                                                                              :qty_authorized 0
                                                                                              :qty_requested 0
                                                                                              :qty_returned 0
                                                                                              :reason ""
                                                                                              :resolution ""
                                                                                              :rma_entity_id 0
                                                                                              :status ""}]
                                                                                     :order_id 0
                                                                                     :order_increment_id ""
                                                                                     :status ""
                                                                                     :store_id 0
                                                                                     :tracks [{:carrier_code ""
                                                                                               :carrier_title ""
                                                                                               :entity_id 0
                                                                                               :extension_attributes {}
                                                                                               :rma_entity_id 0
                                                                                               :track_number ""}]}}})
require "http/client"

url = "{{baseUrl}}/V1/returns"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\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}}/V1/returns"),
    Content = new StringContent("{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/returns");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/returns"

	payload := strings.NewReader("{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/returns HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1301

{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/returns")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/returns"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/returns")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/returns")
  .header("content-type", "application/json")
  .body("{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}")
  .asString();
const data = JSON.stringify({
  rmaDataObject: {
    comments: [
      {
        admin: false,
        comment: '',
        created_at: '',
        custom_attributes: [
          {
            attribute_code: '',
            value: ''
          }
        ],
        customer_notified: false,
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        status: '',
        visible_on_front: false
      }
    ],
    custom_attributes: [
      {}
    ],
    customer_custom_email: '',
    customer_id: 0,
    date_requested: '',
    entity_id: 0,
    extension_attributes: {},
    increment_id: '',
    items: [
      {
        condition: '',
        entity_id: 0,
        extension_attributes: {},
        order_item_id: 0,
        qty_approved: 0,
        qty_authorized: 0,
        qty_requested: 0,
        qty_returned: 0,
        reason: '',
        resolution: '',
        rma_entity_id: 0,
        status: ''
      }
    ],
    order_id: 0,
    order_increment_id: '',
    status: '',
    store_id: 0,
    tracks: [
      {
        carrier_code: '',
        carrier_title: '',
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        track_number: ''
      }
    ]
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/returns');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/returns',
  headers: {'content-type': 'application/json'},
  data: {
    rmaDataObject: {
      comments: [
        {
          admin: false,
          comment: '',
          created_at: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_notified: false,
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          status: '',
          visible_on_front: false
        }
      ],
      custom_attributes: [{}],
      customer_custom_email: '',
      customer_id: 0,
      date_requested: '',
      entity_id: 0,
      extension_attributes: {},
      increment_id: '',
      items: [
        {
          condition: '',
          entity_id: 0,
          extension_attributes: {},
          order_item_id: 0,
          qty_approved: 0,
          qty_authorized: 0,
          qty_requested: 0,
          qty_returned: 0,
          reason: '',
          resolution: '',
          rma_entity_id: 0,
          status: ''
        }
      ],
      order_id: 0,
      order_increment_id: '',
      status: '',
      store_id: 0,
      tracks: [
        {
          carrier_code: '',
          carrier_title: '',
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          track_number: ''
        }
      ]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/returns';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"rmaDataObject":{"comments":[{"admin":false,"comment":"","created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_notified":false,"entity_id":0,"extension_attributes":{},"rma_entity_id":0,"status":"","visible_on_front":false}],"custom_attributes":[{}],"customer_custom_email":"","customer_id":0,"date_requested":"","entity_id":0,"extension_attributes":{},"increment_id":"","items":[{"condition":"","entity_id":0,"extension_attributes":{},"order_item_id":0,"qty_approved":0,"qty_authorized":0,"qty_requested":0,"qty_returned":0,"reason":"","resolution":"","rma_entity_id":0,"status":""}],"order_id":0,"order_increment_id":"","status":"","store_id":0,"tracks":[{"carrier_code":"","carrier_title":"","entity_id":0,"extension_attributes":{},"rma_entity_id":0,"track_number":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/returns',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "rmaDataObject": {\n    "comments": [\n      {\n        "admin": false,\n        "comment": "",\n        "created_at": "",\n        "custom_attributes": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ],\n        "customer_notified": false,\n        "entity_id": 0,\n        "extension_attributes": {},\n        "rma_entity_id": 0,\n        "status": "",\n        "visible_on_front": false\n      }\n    ],\n    "custom_attributes": [\n      {}\n    ],\n    "customer_custom_email": "",\n    "customer_id": 0,\n    "date_requested": "",\n    "entity_id": 0,\n    "extension_attributes": {},\n    "increment_id": "",\n    "items": [\n      {\n        "condition": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "order_item_id": 0,\n        "qty_approved": 0,\n        "qty_authorized": 0,\n        "qty_requested": 0,\n        "qty_returned": 0,\n        "reason": "",\n        "resolution": "",\n        "rma_entity_id": 0,\n        "status": ""\n      }\n    ],\n    "order_id": 0,\n    "order_increment_id": "",\n    "status": "",\n    "store_id": 0,\n    "tracks": [\n      {\n        "carrier_code": "",\n        "carrier_title": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "rma_entity_id": 0,\n        "track_number": ""\n      }\n    ]\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/returns")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/returns',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  rmaDataObject: {
    comments: [
      {
        admin: false,
        comment: '',
        created_at: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_notified: false,
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        status: '',
        visible_on_front: false
      }
    ],
    custom_attributes: [{}],
    customer_custom_email: '',
    customer_id: 0,
    date_requested: '',
    entity_id: 0,
    extension_attributes: {},
    increment_id: '',
    items: [
      {
        condition: '',
        entity_id: 0,
        extension_attributes: {},
        order_item_id: 0,
        qty_approved: 0,
        qty_authorized: 0,
        qty_requested: 0,
        qty_returned: 0,
        reason: '',
        resolution: '',
        rma_entity_id: 0,
        status: ''
      }
    ],
    order_id: 0,
    order_increment_id: '',
    status: '',
    store_id: 0,
    tracks: [
      {
        carrier_code: '',
        carrier_title: '',
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        track_number: ''
      }
    ]
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/returns',
  headers: {'content-type': 'application/json'},
  body: {
    rmaDataObject: {
      comments: [
        {
          admin: false,
          comment: '',
          created_at: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_notified: false,
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          status: '',
          visible_on_front: false
        }
      ],
      custom_attributes: [{}],
      customer_custom_email: '',
      customer_id: 0,
      date_requested: '',
      entity_id: 0,
      extension_attributes: {},
      increment_id: '',
      items: [
        {
          condition: '',
          entity_id: 0,
          extension_attributes: {},
          order_item_id: 0,
          qty_approved: 0,
          qty_authorized: 0,
          qty_requested: 0,
          qty_returned: 0,
          reason: '',
          resolution: '',
          rma_entity_id: 0,
          status: ''
        }
      ],
      order_id: 0,
      order_increment_id: '',
      status: '',
      store_id: 0,
      tracks: [
        {
          carrier_code: '',
          carrier_title: '',
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          track_number: ''
        }
      ]
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/returns');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  rmaDataObject: {
    comments: [
      {
        admin: false,
        comment: '',
        created_at: '',
        custom_attributes: [
          {
            attribute_code: '',
            value: ''
          }
        ],
        customer_notified: false,
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        status: '',
        visible_on_front: false
      }
    ],
    custom_attributes: [
      {}
    ],
    customer_custom_email: '',
    customer_id: 0,
    date_requested: '',
    entity_id: 0,
    extension_attributes: {},
    increment_id: '',
    items: [
      {
        condition: '',
        entity_id: 0,
        extension_attributes: {},
        order_item_id: 0,
        qty_approved: 0,
        qty_authorized: 0,
        qty_requested: 0,
        qty_returned: 0,
        reason: '',
        resolution: '',
        rma_entity_id: 0,
        status: ''
      }
    ],
    order_id: 0,
    order_increment_id: '',
    status: '',
    store_id: 0,
    tracks: [
      {
        carrier_code: '',
        carrier_title: '',
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        track_number: ''
      }
    ]
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/returns',
  headers: {'content-type': 'application/json'},
  data: {
    rmaDataObject: {
      comments: [
        {
          admin: false,
          comment: '',
          created_at: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_notified: false,
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          status: '',
          visible_on_front: false
        }
      ],
      custom_attributes: [{}],
      customer_custom_email: '',
      customer_id: 0,
      date_requested: '',
      entity_id: 0,
      extension_attributes: {},
      increment_id: '',
      items: [
        {
          condition: '',
          entity_id: 0,
          extension_attributes: {},
          order_item_id: 0,
          qty_approved: 0,
          qty_authorized: 0,
          qty_requested: 0,
          qty_returned: 0,
          reason: '',
          resolution: '',
          rma_entity_id: 0,
          status: ''
        }
      ],
      order_id: 0,
      order_increment_id: '',
      status: '',
      store_id: 0,
      tracks: [
        {
          carrier_code: '',
          carrier_title: '',
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          track_number: ''
        }
      ]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/returns';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"rmaDataObject":{"comments":[{"admin":false,"comment":"","created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_notified":false,"entity_id":0,"extension_attributes":{},"rma_entity_id":0,"status":"","visible_on_front":false}],"custom_attributes":[{}],"customer_custom_email":"","customer_id":0,"date_requested":"","entity_id":0,"extension_attributes":{},"increment_id":"","items":[{"condition":"","entity_id":0,"extension_attributes":{},"order_item_id":0,"qty_approved":0,"qty_authorized":0,"qty_requested":0,"qty_returned":0,"reason":"","resolution":"","rma_entity_id":0,"status":""}],"order_id":0,"order_increment_id":"","status":"","store_id":0,"tracks":[{"carrier_code":"","carrier_title":"","entity_id":0,"extension_attributes":{},"rma_entity_id":0,"track_number":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"rmaDataObject": @{ @"comments": @[ @{ @"admin": @NO, @"comment": @"", @"created_at": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_notified": @NO, @"entity_id": @0, @"extension_attributes": @{  }, @"rma_entity_id": @0, @"status": @"", @"visible_on_front": @NO } ], @"custom_attributes": @[ @{  } ], @"customer_custom_email": @"", @"customer_id": @0, @"date_requested": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"increment_id": @"", @"items": @[ @{ @"condition": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"order_item_id": @0, @"qty_approved": @0, @"qty_authorized": @0, @"qty_requested": @0, @"qty_returned": @0, @"reason": @"", @"resolution": @"", @"rma_entity_id": @0, @"status": @"" } ], @"order_id": @0, @"order_increment_id": @"", @"status": @"", @"store_id": @0, @"tracks": @[ @{ @"carrier_code": @"", @"carrier_title": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"rma_entity_id": @0, @"track_number": @"" } ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/returns"]
                                                       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}}/V1/returns" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/returns",
  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([
    'rmaDataObject' => [
        'comments' => [
                [
                                'admin' => null,
                                'comment' => '',
                                'created_at' => '',
                                'custom_attributes' => [
                                                                [
                                                                                                                                'attribute_code' => '',
                                                                                                                                'value' => ''
                                                                ]
                                ],
                                'customer_notified' => null,
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'rma_entity_id' => 0,
                                'status' => '',
                                'visible_on_front' => null
                ]
        ],
        'custom_attributes' => [
                [
                                
                ]
        ],
        'customer_custom_email' => '',
        'customer_id' => 0,
        'date_requested' => '',
        'entity_id' => 0,
        'extension_attributes' => [
                
        ],
        'increment_id' => '',
        'items' => [
                [
                                'condition' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'order_item_id' => 0,
                                'qty_approved' => 0,
                                'qty_authorized' => 0,
                                'qty_requested' => 0,
                                'qty_returned' => 0,
                                'reason' => '',
                                'resolution' => '',
                                'rma_entity_id' => 0,
                                'status' => ''
                ]
        ],
        'order_id' => 0,
        'order_increment_id' => '',
        'status' => '',
        'store_id' => 0,
        'tracks' => [
                [
                                'carrier_code' => '',
                                'carrier_title' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'rma_entity_id' => 0,
                                'track_number' => ''
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/returns', [
  'body' => '{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/returns');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'rmaDataObject' => [
    'comments' => [
        [
                'admin' => null,
                'comment' => '',
                'created_at' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_notified' => null,
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'rma_entity_id' => 0,
                'status' => '',
                'visible_on_front' => null
        ]
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'customer_custom_email' => '',
    'customer_id' => 0,
    'date_requested' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'increment_id' => '',
    'items' => [
        [
                'condition' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'order_item_id' => 0,
                'qty_approved' => 0,
                'qty_authorized' => 0,
                'qty_requested' => 0,
                'qty_returned' => 0,
                'reason' => '',
                'resolution' => '',
                'rma_entity_id' => 0,
                'status' => ''
        ]
    ],
    'order_id' => 0,
    'order_increment_id' => '',
    'status' => '',
    'store_id' => 0,
    'tracks' => [
        [
                'carrier_code' => '',
                'carrier_title' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'rma_entity_id' => 0,
                'track_number' => ''
        ]
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'rmaDataObject' => [
    'comments' => [
        [
                'admin' => null,
                'comment' => '',
                'created_at' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_notified' => null,
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'rma_entity_id' => 0,
                'status' => '',
                'visible_on_front' => null
        ]
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'customer_custom_email' => '',
    'customer_id' => 0,
    'date_requested' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'increment_id' => '',
    'items' => [
        [
                'condition' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'order_item_id' => 0,
                'qty_approved' => 0,
                'qty_authorized' => 0,
                'qty_requested' => 0,
                'qty_returned' => 0,
                'reason' => '',
                'resolution' => '',
                'rma_entity_id' => 0,
                'status' => ''
        ]
    ],
    'order_id' => 0,
    'order_increment_id' => '',
    'status' => '',
    'store_id' => 0,
    'tracks' => [
        [
                'carrier_code' => '',
                'carrier_title' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'rma_entity_id' => 0,
                'track_number' => ''
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/returns');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/returns' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/returns' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/returns", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/returns"

payload = { "rmaDataObject": {
        "comments": [
            {
                "admin": False,
                "comment": "",
                "created_at": "",
                "custom_attributes": [
                    {
                        "attribute_code": "",
                        "value": ""
                    }
                ],
                "customer_notified": False,
                "entity_id": 0,
                "extension_attributes": {},
                "rma_entity_id": 0,
                "status": "",
                "visible_on_front": False
            }
        ],
        "custom_attributes": [{}],
        "customer_custom_email": "",
        "customer_id": 0,
        "date_requested": "",
        "entity_id": 0,
        "extension_attributes": {},
        "increment_id": "",
        "items": [
            {
                "condition": "",
                "entity_id": 0,
                "extension_attributes": {},
                "order_item_id": 0,
                "qty_approved": 0,
                "qty_authorized": 0,
                "qty_requested": 0,
                "qty_returned": 0,
                "reason": "",
                "resolution": "",
                "rma_entity_id": 0,
                "status": ""
            }
        ],
        "order_id": 0,
        "order_increment_id": "",
        "status": "",
        "store_id": 0,
        "tracks": [
            {
                "carrier_code": "",
                "carrier_title": "",
                "entity_id": 0,
                "extension_attributes": {},
                "rma_entity_id": 0,
                "track_number": ""
            }
        ]
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/returns"

payload <- "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/returns")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/V1/returns') do |req|
  req.body = "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\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}}/V1/returns";

    let payload = json!({"rmaDataObject": json!({
            "comments": (
                json!({
                    "admin": false,
                    "comment": "",
                    "created_at": "",
                    "custom_attributes": (
                        json!({
                            "attribute_code": "",
                            "value": ""
                        })
                    ),
                    "customer_notified": false,
                    "entity_id": 0,
                    "extension_attributes": json!({}),
                    "rma_entity_id": 0,
                    "status": "",
                    "visible_on_front": false
                })
            ),
            "custom_attributes": (json!({})),
            "customer_custom_email": "",
            "customer_id": 0,
            "date_requested": "",
            "entity_id": 0,
            "extension_attributes": json!({}),
            "increment_id": "",
            "items": (
                json!({
                    "condition": "",
                    "entity_id": 0,
                    "extension_attributes": json!({}),
                    "order_item_id": 0,
                    "qty_approved": 0,
                    "qty_authorized": 0,
                    "qty_requested": 0,
                    "qty_returned": 0,
                    "reason": "",
                    "resolution": "",
                    "rma_entity_id": 0,
                    "status": ""
                })
            ),
            "order_id": 0,
            "order_increment_id": "",
            "status": "",
            "store_id": 0,
            "tracks": (
                json!({
                    "carrier_code": "",
                    "carrier_title": "",
                    "entity_id": 0,
                    "extension_attributes": json!({}),
                    "rma_entity_id": 0,
                    "track_number": ""
                })
            )
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/returns \
  --header 'content-type: application/json' \
  --data '{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}'
echo '{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}' |  \
  http POST {{baseUrl}}/V1/returns \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "rmaDataObject": {\n    "comments": [\n      {\n        "admin": false,\n        "comment": "",\n        "created_at": "",\n        "custom_attributes": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ],\n        "customer_notified": false,\n        "entity_id": 0,\n        "extension_attributes": {},\n        "rma_entity_id": 0,\n        "status": "",\n        "visible_on_front": false\n      }\n    ],\n    "custom_attributes": [\n      {}\n    ],\n    "customer_custom_email": "",\n    "customer_id": 0,\n    "date_requested": "",\n    "entity_id": 0,\n    "extension_attributes": {},\n    "increment_id": "",\n    "items": [\n      {\n        "condition": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "order_item_id": 0,\n        "qty_approved": 0,\n        "qty_authorized": 0,\n        "qty_requested": 0,\n        "qty_returned": 0,\n        "reason": "",\n        "resolution": "",\n        "rma_entity_id": 0,\n        "status": ""\n      }\n    ],\n    "order_id": 0,\n    "order_increment_id": "",\n    "status": "",\n    "store_id": 0,\n    "tracks": [\n      {\n        "carrier_code": "",\n        "carrier_title": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "rma_entity_id": 0,\n        "track_number": ""\n      }\n    ]\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/returns
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["rmaDataObject": [
    "comments": [
      [
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          [
            "attribute_code": "",
            "value": ""
          ]
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": [],
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      ]
    ],
    "custom_attributes": [[]],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": [],
    "increment_id": "",
    "items": [
      [
        "condition": "",
        "entity_id": 0,
        "extension_attributes": [],
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      ]
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      [
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": [],
        "rma_entity_id": 0,
        "track_number": ""
      ]
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/returns")! 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 returns
{{baseUrl}}/V1/returns
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/returns");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/returns")
require "http/client"

url = "{{baseUrl}}/V1/returns"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/returns"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/returns");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/returns"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/returns HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/returns")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/returns"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/returns")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/returns")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/returns');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/returns'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/returns';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/returns',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/returns")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/returns',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/returns'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/returns');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/returns'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/returns';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/returns"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/returns" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/returns",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/returns');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/returns');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/returns');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/returns' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/returns' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/returns")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/returns"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/returns"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/returns")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/returns') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/returns";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/returns
http GET {{baseUrl}}/V1/returns
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/returns
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/returns")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET returns-{id} (GET)
{{baseUrl}}/V1/returns/:id
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/returns/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/returns/:id")
require "http/client"

url = "{{baseUrl}}/V1/returns/:id"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/returns/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/returns/:id");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/returns/:id"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/returns/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/returns/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/returns/:id"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/returns/:id")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/returns/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/returns/:id');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/returns/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/returns/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/returns/:id',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/returns/:id")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/returns/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/returns/:id'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/returns/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/returns/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/returns/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/returns/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/returns/:id" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/returns/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/returns/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/returns/:id');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/returns/:id');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/returns/:id' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/returns/:id' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/returns/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/returns/:id"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/returns/:id"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/returns/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/returns/:id') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/returns/:id";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/returns/:id
http GET {{baseUrl}}/V1/returns/:id
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/returns/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/returns/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT returns-{id} (PUT)
{{baseUrl}}/V1/returns/:id
QUERY PARAMS

id
BODY json

{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/returns/:id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/returns/:id" {:content-type :json
                                                          :form-params {:rmaDataObject {:comments [{:admin false
                                                                                                    :comment ""
                                                                                                    :created_at ""
                                                                                                    :custom_attributes [{:attribute_code ""
                                                                                                                         :value ""}]
                                                                                                    :customer_notified false
                                                                                                    :entity_id 0
                                                                                                    :extension_attributes {}
                                                                                                    :rma_entity_id 0
                                                                                                    :status ""
                                                                                                    :visible_on_front false}]
                                                                                        :custom_attributes [{}]
                                                                                        :customer_custom_email ""
                                                                                        :customer_id 0
                                                                                        :date_requested ""
                                                                                        :entity_id 0
                                                                                        :extension_attributes {}
                                                                                        :increment_id ""
                                                                                        :items [{:condition ""
                                                                                                 :entity_id 0
                                                                                                 :extension_attributes {}
                                                                                                 :order_item_id 0
                                                                                                 :qty_approved 0
                                                                                                 :qty_authorized 0
                                                                                                 :qty_requested 0
                                                                                                 :qty_returned 0
                                                                                                 :reason ""
                                                                                                 :resolution ""
                                                                                                 :rma_entity_id 0
                                                                                                 :status ""}]
                                                                                        :order_id 0
                                                                                        :order_increment_id ""
                                                                                        :status ""
                                                                                        :store_id 0
                                                                                        :tracks [{:carrier_code ""
                                                                                                  :carrier_title ""
                                                                                                  :entity_id 0
                                                                                                  :extension_attributes {}
                                                                                                  :rma_entity_id 0
                                                                                                  :track_number ""}]}}})
require "http/client"

url = "{{baseUrl}}/V1/returns/:id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/V1/returns/:id"),
    Content = new StringContent("{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/returns/:id");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/returns/:id"

	payload := strings.NewReader("{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/returns/:id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1301

{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/returns/:id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/returns/:id"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/returns/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/returns/:id")
  .header("content-type", "application/json")
  .body("{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}")
  .asString();
const data = JSON.stringify({
  rmaDataObject: {
    comments: [
      {
        admin: false,
        comment: '',
        created_at: '',
        custom_attributes: [
          {
            attribute_code: '',
            value: ''
          }
        ],
        customer_notified: false,
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        status: '',
        visible_on_front: false
      }
    ],
    custom_attributes: [
      {}
    ],
    customer_custom_email: '',
    customer_id: 0,
    date_requested: '',
    entity_id: 0,
    extension_attributes: {},
    increment_id: '',
    items: [
      {
        condition: '',
        entity_id: 0,
        extension_attributes: {},
        order_item_id: 0,
        qty_approved: 0,
        qty_authorized: 0,
        qty_requested: 0,
        qty_returned: 0,
        reason: '',
        resolution: '',
        rma_entity_id: 0,
        status: ''
      }
    ],
    order_id: 0,
    order_increment_id: '',
    status: '',
    store_id: 0,
    tracks: [
      {
        carrier_code: '',
        carrier_title: '',
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        track_number: ''
      }
    ]
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/returns/:id');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/returns/:id',
  headers: {'content-type': 'application/json'},
  data: {
    rmaDataObject: {
      comments: [
        {
          admin: false,
          comment: '',
          created_at: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_notified: false,
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          status: '',
          visible_on_front: false
        }
      ],
      custom_attributes: [{}],
      customer_custom_email: '',
      customer_id: 0,
      date_requested: '',
      entity_id: 0,
      extension_attributes: {},
      increment_id: '',
      items: [
        {
          condition: '',
          entity_id: 0,
          extension_attributes: {},
          order_item_id: 0,
          qty_approved: 0,
          qty_authorized: 0,
          qty_requested: 0,
          qty_returned: 0,
          reason: '',
          resolution: '',
          rma_entity_id: 0,
          status: ''
        }
      ],
      order_id: 0,
      order_increment_id: '',
      status: '',
      store_id: 0,
      tracks: [
        {
          carrier_code: '',
          carrier_title: '',
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          track_number: ''
        }
      ]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/returns/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"rmaDataObject":{"comments":[{"admin":false,"comment":"","created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_notified":false,"entity_id":0,"extension_attributes":{},"rma_entity_id":0,"status":"","visible_on_front":false}],"custom_attributes":[{}],"customer_custom_email":"","customer_id":0,"date_requested":"","entity_id":0,"extension_attributes":{},"increment_id":"","items":[{"condition":"","entity_id":0,"extension_attributes":{},"order_item_id":0,"qty_approved":0,"qty_authorized":0,"qty_requested":0,"qty_returned":0,"reason":"","resolution":"","rma_entity_id":0,"status":""}],"order_id":0,"order_increment_id":"","status":"","store_id":0,"tracks":[{"carrier_code":"","carrier_title":"","entity_id":0,"extension_attributes":{},"rma_entity_id":0,"track_number":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/returns/:id',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "rmaDataObject": {\n    "comments": [\n      {\n        "admin": false,\n        "comment": "",\n        "created_at": "",\n        "custom_attributes": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ],\n        "customer_notified": false,\n        "entity_id": 0,\n        "extension_attributes": {},\n        "rma_entity_id": 0,\n        "status": "",\n        "visible_on_front": false\n      }\n    ],\n    "custom_attributes": [\n      {}\n    ],\n    "customer_custom_email": "",\n    "customer_id": 0,\n    "date_requested": "",\n    "entity_id": 0,\n    "extension_attributes": {},\n    "increment_id": "",\n    "items": [\n      {\n        "condition": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "order_item_id": 0,\n        "qty_approved": 0,\n        "qty_authorized": 0,\n        "qty_requested": 0,\n        "qty_returned": 0,\n        "reason": "",\n        "resolution": "",\n        "rma_entity_id": 0,\n        "status": ""\n      }\n    ],\n    "order_id": 0,\n    "order_increment_id": "",\n    "status": "",\n    "store_id": 0,\n    "tracks": [\n      {\n        "carrier_code": "",\n        "carrier_title": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "rma_entity_id": 0,\n        "track_number": ""\n      }\n    ]\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/returns/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/returns/:id',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  rmaDataObject: {
    comments: [
      {
        admin: false,
        comment: '',
        created_at: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_notified: false,
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        status: '',
        visible_on_front: false
      }
    ],
    custom_attributes: [{}],
    customer_custom_email: '',
    customer_id: 0,
    date_requested: '',
    entity_id: 0,
    extension_attributes: {},
    increment_id: '',
    items: [
      {
        condition: '',
        entity_id: 0,
        extension_attributes: {},
        order_item_id: 0,
        qty_approved: 0,
        qty_authorized: 0,
        qty_requested: 0,
        qty_returned: 0,
        reason: '',
        resolution: '',
        rma_entity_id: 0,
        status: ''
      }
    ],
    order_id: 0,
    order_increment_id: '',
    status: '',
    store_id: 0,
    tracks: [
      {
        carrier_code: '',
        carrier_title: '',
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        track_number: ''
      }
    ]
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/returns/:id',
  headers: {'content-type': 'application/json'},
  body: {
    rmaDataObject: {
      comments: [
        {
          admin: false,
          comment: '',
          created_at: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_notified: false,
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          status: '',
          visible_on_front: false
        }
      ],
      custom_attributes: [{}],
      customer_custom_email: '',
      customer_id: 0,
      date_requested: '',
      entity_id: 0,
      extension_attributes: {},
      increment_id: '',
      items: [
        {
          condition: '',
          entity_id: 0,
          extension_attributes: {},
          order_item_id: 0,
          qty_approved: 0,
          qty_authorized: 0,
          qty_requested: 0,
          qty_returned: 0,
          reason: '',
          resolution: '',
          rma_entity_id: 0,
          status: ''
        }
      ],
      order_id: 0,
      order_increment_id: '',
      status: '',
      store_id: 0,
      tracks: [
        {
          carrier_code: '',
          carrier_title: '',
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          track_number: ''
        }
      ]
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/returns/:id');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  rmaDataObject: {
    comments: [
      {
        admin: false,
        comment: '',
        created_at: '',
        custom_attributes: [
          {
            attribute_code: '',
            value: ''
          }
        ],
        customer_notified: false,
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        status: '',
        visible_on_front: false
      }
    ],
    custom_attributes: [
      {}
    ],
    customer_custom_email: '',
    customer_id: 0,
    date_requested: '',
    entity_id: 0,
    extension_attributes: {},
    increment_id: '',
    items: [
      {
        condition: '',
        entity_id: 0,
        extension_attributes: {},
        order_item_id: 0,
        qty_approved: 0,
        qty_authorized: 0,
        qty_requested: 0,
        qty_returned: 0,
        reason: '',
        resolution: '',
        rma_entity_id: 0,
        status: ''
      }
    ],
    order_id: 0,
    order_increment_id: '',
    status: '',
    store_id: 0,
    tracks: [
      {
        carrier_code: '',
        carrier_title: '',
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        track_number: ''
      }
    ]
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/returns/:id',
  headers: {'content-type': 'application/json'},
  data: {
    rmaDataObject: {
      comments: [
        {
          admin: false,
          comment: '',
          created_at: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_notified: false,
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          status: '',
          visible_on_front: false
        }
      ],
      custom_attributes: [{}],
      customer_custom_email: '',
      customer_id: 0,
      date_requested: '',
      entity_id: 0,
      extension_attributes: {},
      increment_id: '',
      items: [
        {
          condition: '',
          entity_id: 0,
          extension_attributes: {},
          order_item_id: 0,
          qty_approved: 0,
          qty_authorized: 0,
          qty_requested: 0,
          qty_returned: 0,
          reason: '',
          resolution: '',
          rma_entity_id: 0,
          status: ''
        }
      ],
      order_id: 0,
      order_increment_id: '',
      status: '',
      store_id: 0,
      tracks: [
        {
          carrier_code: '',
          carrier_title: '',
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          track_number: ''
        }
      ]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/returns/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"rmaDataObject":{"comments":[{"admin":false,"comment":"","created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_notified":false,"entity_id":0,"extension_attributes":{},"rma_entity_id":0,"status":"","visible_on_front":false}],"custom_attributes":[{}],"customer_custom_email":"","customer_id":0,"date_requested":"","entity_id":0,"extension_attributes":{},"increment_id":"","items":[{"condition":"","entity_id":0,"extension_attributes":{},"order_item_id":0,"qty_approved":0,"qty_authorized":0,"qty_requested":0,"qty_returned":0,"reason":"","resolution":"","rma_entity_id":0,"status":""}],"order_id":0,"order_increment_id":"","status":"","store_id":0,"tracks":[{"carrier_code":"","carrier_title":"","entity_id":0,"extension_attributes":{},"rma_entity_id":0,"track_number":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"rmaDataObject": @{ @"comments": @[ @{ @"admin": @NO, @"comment": @"", @"created_at": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_notified": @NO, @"entity_id": @0, @"extension_attributes": @{  }, @"rma_entity_id": @0, @"status": @"", @"visible_on_front": @NO } ], @"custom_attributes": @[ @{  } ], @"customer_custom_email": @"", @"customer_id": @0, @"date_requested": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"increment_id": @"", @"items": @[ @{ @"condition": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"order_item_id": @0, @"qty_approved": @0, @"qty_authorized": @0, @"qty_requested": @0, @"qty_returned": @0, @"reason": @"", @"resolution": @"", @"rma_entity_id": @0, @"status": @"" } ], @"order_id": @0, @"order_increment_id": @"", @"status": @"", @"store_id": @0, @"tracks": @[ @{ @"carrier_code": @"", @"carrier_title": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"rma_entity_id": @0, @"track_number": @"" } ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/returns/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/returns/:id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/returns/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'rmaDataObject' => [
        'comments' => [
                [
                                'admin' => null,
                                'comment' => '',
                                'created_at' => '',
                                'custom_attributes' => [
                                                                [
                                                                                                                                'attribute_code' => '',
                                                                                                                                'value' => ''
                                                                ]
                                ],
                                'customer_notified' => null,
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'rma_entity_id' => 0,
                                'status' => '',
                                'visible_on_front' => null
                ]
        ],
        'custom_attributes' => [
                [
                                
                ]
        ],
        'customer_custom_email' => '',
        'customer_id' => 0,
        'date_requested' => '',
        'entity_id' => 0,
        'extension_attributes' => [
                
        ],
        'increment_id' => '',
        'items' => [
                [
                                'condition' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'order_item_id' => 0,
                                'qty_approved' => 0,
                                'qty_authorized' => 0,
                                'qty_requested' => 0,
                                'qty_returned' => 0,
                                'reason' => '',
                                'resolution' => '',
                                'rma_entity_id' => 0,
                                'status' => ''
                ]
        ],
        'order_id' => 0,
        'order_increment_id' => '',
        'status' => '',
        'store_id' => 0,
        'tracks' => [
                [
                                'carrier_code' => '',
                                'carrier_title' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'rma_entity_id' => 0,
                                'track_number' => ''
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/returns/:id', [
  'body' => '{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/returns/:id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'rmaDataObject' => [
    'comments' => [
        [
                'admin' => null,
                'comment' => '',
                'created_at' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_notified' => null,
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'rma_entity_id' => 0,
                'status' => '',
                'visible_on_front' => null
        ]
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'customer_custom_email' => '',
    'customer_id' => 0,
    'date_requested' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'increment_id' => '',
    'items' => [
        [
                'condition' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'order_item_id' => 0,
                'qty_approved' => 0,
                'qty_authorized' => 0,
                'qty_requested' => 0,
                'qty_returned' => 0,
                'reason' => '',
                'resolution' => '',
                'rma_entity_id' => 0,
                'status' => ''
        ]
    ],
    'order_id' => 0,
    'order_increment_id' => '',
    'status' => '',
    'store_id' => 0,
    'tracks' => [
        [
                'carrier_code' => '',
                'carrier_title' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'rma_entity_id' => 0,
                'track_number' => ''
        ]
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'rmaDataObject' => [
    'comments' => [
        [
                'admin' => null,
                'comment' => '',
                'created_at' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_notified' => null,
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'rma_entity_id' => 0,
                'status' => '',
                'visible_on_front' => null
        ]
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'customer_custom_email' => '',
    'customer_id' => 0,
    'date_requested' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'increment_id' => '',
    'items' => [
        [
                'condition' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'order_item_id' => 0,
                'qty_approved' => 0,
                'qty_authorized' => 0,
                'qty_requested' => 0,
                'qty_returned' => 0,
                'reason' => '',
                'resolution' => '',
                'rma_entity_id' => 0,
                'status' => ''
        ]
    ],
    'order_id' => 0,
    'order_increment_id' => '',
    'status' => '',
    'store_id' => 0,
    'tracks' => [
        [
                'carrier_code' => '',
                'carrier_title' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'rma_entity_id' => 0,
                'track_number' => ''
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/returns/:id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/returns/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/returns/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/returns/:id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/returns/:id"

payload = { "rmaDataObject": {
        "comments": [
            {
                "admin": False,
                "comment": "",
                "created_at": "",
                "custom_attributes": [
                    {
                        "attribute_code": "",
                        "value": ""
                    }
                ],
                "customer_notified": False,
                "entity_id": 0,
                "extension_attributes": {},
                "rma_entity_id": 0,
                "status": "",
                "visible_on_front": False
            }
        ],
        "custom_attributes": [{}],
        "customer_custom_email": "",
        "customer_id": 0,
        "date_requested": "",
        "entity_id": 0,
        "extension_attributes": {},
        "increment_id": "",
        "items": [
            {
                "condition": "",
                "entity_id": 0,
                "extension_attributes": {},
                "order_item_id": 0,
                "qty_approved": 0,
                "qty_authorized": 0,
                "qty_requested": 0,
                "qty_returned": 0,
                "reason": "",
                "resolution": "",
                "rma_entity_id": 0,
                "status": ""
            }
        ],
        "order_id": 0,
        "order_increment_id": "",
        "status": "",
        "store_id": 0,
        "tracks": [
            {
                "carrier_code": "",
                "carrier_title": "",
                "entity_id": 0,
                "extension_attributes": {},
                "rma_entity_id": 0,
                "track_number": ""
            }
        ]
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/returns/:id"

payload <- "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/returns/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/V1/returns/:id') do |req|
  req.body = "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/returns/:id";

    let payload = json!({"rmaDataObject": json!({
            "comments": (
                json!({
                    "admin": false,
                    "comment": "",
                    "created_at": "",
                    "custom_attributes": (
                        json!({
                            "attribute_code": "",
                            "value": ""
                        })
                    ),
                    "customer_notified": false,
                    "entity_id": 0,
                    "extension_attributes": json!({}),
                    "rma_entity_id": 0,
                    "status": "",
                    "visible_on_front": false
                })
            ),
            "custom_attributes": (json!({})),
            "customer_custom_email": "",
            "customer_id": 0,
            "date_requested": "",
            "entity_id": 0,
            "extension_attributes": json!({}),
            "increment_id": "",
            "items": (
                json!({
                    "condition": "",
                    "entity_id": 0,
                    "extension_attributes": json!({}),
                    "order_item_id": 0,
                    "qty_approved": 0,
                    "qty_authorized": 0,
                    "qty_requested": 0,
                    "qty_returned": 0,
                    "reason": "",
                    "resolution": "",
                    "rma_entity_id": 0,
                    "status": ""
                })
            ),
            "order_id": 0,
            "order_increment_id": "",
            "status": "",
            "store_id": 0,
            "tracks": (
                json!({
                    "carrier_code": "",
                    "carrier_title": "",
                    "entity_id": 0,
                    "extension_attributes": json!({}),
                    "rma_entity_id": 0,
                    "track_number": ""
                })
            )
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/returns/:id \
  --header 'content-type: application/json' \
  --data '{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}'
echo '{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}' |  \
  http PUT {{baseUrl}}/V1/returns/:id \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "rmaDataObject": {\n    "comments": [\n      {\n        "admin": false,\n        "comment": "",\n        "created_at": "",\n        "custom_attributes": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ],\n        "customer_notified": false,\n        "entity_id": 0,\n        "extension_attributes": {},\n        "rma_entity_id": 0,\n        "status": "",\n        "visible_on_front": false\n      }\n    ],\n    "custom_attributes": [\n      {}\n    ],\n    "customer_custom_email": "",\n    "customer_id": 0,\n    "date_requested": "",\n    "entity_id": 0,\n    "extension_attributes": {},\n    "increment_id": "",\n    "items": [\n      {\n        "condition": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "order_item_id": 0,\n        "qty_approved": 0,\n        "qty_authorized": 0,\n        "qty_requested": 0,\n        "qty_returned": 0,\n        "reason": "",\n        "resolution": "",\n        "rma_entity_id": 0,\n        "status": ""\n      }\n    ],\n    "order_id": 0,\n    "order_increment_id": "",\n    "status": "",\n    "store_id": 0,\n    "tracks": [\n      {\n        "carrier_code": "",\n        "carrier_title": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "rma_entity_id": 0,\n        "track_number": ""\n      }\n    ]\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/returns/:id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["rmaDataObject": [
    "comments": [
      [
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          [
            "attribute_code": "",
            "value": ""
          ]
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": [],
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      ]
    ],
    "custom_attributes": [[]],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": [],
    "increment_id": "",
    "items": [
      [
        "condition": "",
        "entity_id": 0,
        "extension_attributes": [],
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      ]
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      [
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": [],
        "rma_entity_id": 0,
        "track_number": ""
      ]
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/returns/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE returns-{id}
{{baseUrl}}/V1/returns/:id
QUERY PARAMS

id
BODY json

{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/returns/:id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/returns/:id" {:content-type :json
                                                             :form-params {:rmaDataObject {:comments [{:admin false
                                                                                                       :comment ""
                                                                                                       :created_at ""
                                                                                                       :custom_attributes [{:attribute_code ""
                                                                                                                            :value ""}]
                                                                                                       :customer_notified false
                                                                                                       :entity_id 0
                                                                                                       :extension_attributes {}
                                                                                                       :rma_entity_id 0
                                                                                                       :status ""
                                                                                                       :visible_on_front false}]
                                                                                           :custom_attributes [{}]
                                                                                           :customer_custom_email ""
                                                                                           :customer_id 0
                                                                                           :date_requested ""
                                                                                           :entity_id 0
                                                                                           :extension_attributes {}
                                                                                           :increment_id ""
                                                                                           :items [{:condition ""
                                                                                                    :entity_id 0
                                                                                                    :extension_attributes {}
                                                                                                    :order_item_id 0
                                                                                                    :qty_approved 0
                                                                                                    :qty_authorized 0
                                                                                                    :qty_requested 0
                                                                                                    :qty_returned 0
                                                                                                    :reason ""
                                                                                                    :resolution ""
                                                                                                    :rma_entity_id 0
                                                                                                    :status ""}]
                                                                                           :order_id 0
                                                                                           :order_increment_id ""
                                                                                           :status ""
                                                                                           :store_id 0
                                                                                           :tracks [{:carrier_code ""
                                                                                                     :carrier_title ""
                                                                                                     :entity_id 0
                                                                                                     :extension_attributes {}
                                                                                                     :rma_entity_id 0
                                                                                                     :track_number ""}]}}})
require "http/client"

url = "{{baseUrl}}/V1/returns/:id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}"

response = HTTP::Client.delete url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/returns/:id"),
    Content = new StringContent("{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/returns/:id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/returns/:id"

	payload := strings.NewReader("{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}")

	req, _ := http.NewRequest("DELETE", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/returns/:id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1301

{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/returns/:id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/returns/:id"))
    .header("content-type", "application/json")
    .method("DELETE", HttpRequest.BodyPublishers.ofString("{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/returns/:id")
  .delete(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/returns/:id")
  .header("content-type", "application/json")
  .body("{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}")
  .asString();
const data = JSON.stringify({
  rmaDataObject: {
    comments: [
      {
        admin: false,
        comment: '',
        created_at: '',
        custom_attributes: [
          {
            attribute_code: '',
            value: ''
          }
        ],
        customer_notified: false,
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        status: '',
        visible_on_front: false
      }
    ],
    custom_attributes: [
      {}
    ],
    customer_custom_email: '',
    customer_id: 0,
    date_requested: '',
    entity_id: 0,
    extension_attributes: {},
    increment_id: '',
    items: [
      {
        condition: '',
        entity_id: 0,
        extension_attributes: {},
        order_item_id: 0,
        qty_approved: 0,
        qty_authorized: 0,
        qty_requested: 0,
        qty_returned: 0,
        reason: '',
        resolution: '',
        rma_entity_id: 0,
        status: ''
      }
    ],
    order_id: 0,
    order_increment_id: '',
    status: '',
    store_id: 0,
    tracks: [
      {
        carrier_code: '',
        carrier_title: '',
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        track_number: ''
      }
    ]
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/V1/returns/:id');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/returns/:id',
  headers: {'content-type': 'application/json'},
  data: {
    rmaDataObject: {
      comments: [
        {
          admin: false,
          comment: '',
          created_at: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_notified: false,
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          status: '',
          visible_on_front: false
        }
      ],
      custom_attributes: [{}],
      customer_custom_email: '',
      customer_id: 0,
      date_requested: '',
      entity_id: 0,
      extension_attributes: {},
      increment_id: '',
      items: [
        {
          condition: '',
          entity_id: 0,
          extension_attributes: {},
          order_item_id: 0,
          qty_approved: 0,
          qty_authorized: 0,
          qty_requested: 0,
          qty_returned: 0,
          reason: '',
          resolution: '',
          rma_entity_id: 0,
          status: ''
        }
      ],
      order_id: 0,
      order_increment_id: '',
      status: '',
      store_id: 0,
      tracks: [
        {
          carrier_code: '',
          carrier_title: '',
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          track_number: ''
        }
      ]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/returns/:id';
const options = {
  method: 'DELETE',
  headers: {'content-type': 'application/json'},
  body: '{"rmaDataObject":{"comments":[{"admin":false,"comment":"","created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_notified":false,"entity_id":0,"extension_attributes":{},"rma_entity_id":0,"status":"","visible_on_front":false}],"custom_attributes":[{}],"customer_custom_email":"","customer_id":0,"date_requested":"","entity_id":0,"extension_attributes":{},"increment_id":"","items":[{"condition":"","entity_id":0,"extension_attributes":{},"order_item_id":0,"qty_approved":0,"qty_authorized":0,"qty_requested":0,"qty_returned":0,"reason":"","resolution":"","rma_entity_id":0,"status":""}],"order_id":0,"order_increment_id":"","status":"","store_id":0,"tracks":[{"carrier_code":"","carrier_title":"","entity_id":0,"extension_attributes":{},"rma_entity_id":0,"track_number":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/returns/:id',
  method: 'DELETE',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "rmaDataObject": {\n    "comments": [\n      {\n        "admin": false,\n        "comment": "",\n        "created_at": "",\n        "custom_attributes": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ],\n        "customer_notified": false,\n        "entity_id": 0,\n        "extension_attributes": {},\n        "rma_entity_id": 0,\n        "status": "",\n        "visible_on_front": false\n      }\n    ],\n    "custom_attributes": [\n      {}\n    ],\n    "customer_custom_email": "",\n    "customer_id": 0,\n    "date_requested": "",\n    "entity_id": 0,\n    "extension_attributes": {},\n    "increment_id": "",\n    "items": [\n      {\n        "condition": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "order_item_id": 0,\n        "qty_approved": 0,\n        "qty_authorized": 0,\n        "qty_requested": 0,\n        "qty_returned": 0,\n        "reason": "",\n        "resolution": "",\n        "rma_entity_id": 0,\n        "status": ""\n      }\n    ],\n    "order_id": 0,\n    "order_increment_id": "",\n    "status": "",\n    "store_id": 0,\n    "tracks": [\n      {\n        "carrier_code": "",\n        "carrier_title": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "rma_entity_id": 0,\n        "track_number": ""\n      }\n    ]\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/returns/:id")
  .delete(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/returns/:id',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  rmaDataObject: {
    comments: [
      {
        admin: false,
        comment: '',
        created_at: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        customer_notified: false,
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        status: '',
        visible_on_front: false
      }
    ],
    custom_attributes: [{}],
    customer_custom_email: '',
    customer_id: 0,
    date_requested: '',
    entity_id: 0,
    extension_attributes: {},
    increment_id: '',
    items: [
      {
        condition: '',
        entity_id: 0,
        extension_attributes: {},
        order_item_id: 0,
        qty_approved: 0,
        qty_authorized: 0,
        qty_requested: 0,
        qty_returned: 0,
        reason: '',
        resolution: '',
        rma_entity_id: 0,
        status: ''
      }
    ],
    order_id: 0,
    order_increment_id: '',
    status: '',
    store_id: 0,
    tracks: [
      {
        carrier_code: '',
        carrier_title: '',
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        track_number: ''
      }
    ]
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/returns/:id',
  headers: {'content-type': 'application/json'},
  body: {
    rmaDataObject: {
      comments: [
        {
          admin: false,
          comment: '',
          created_at: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_notified: false,
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          status: '',
          visible_on_front: false
        }
      ],
      custom_attributes: [{}],
      customer_custom_email: '',
      customer_id: 0,
      date_requested: '',
      entity_id: 0,
      extension_attributes: {},
      increment_id: '',
      items: [
        {
          condition: '',
          entity_id: 0,
          extension_attributes: {},
          order_item_id: 0,
          qty_approved: 0,
          qty_authorized: 0,
          qty_requested: 0,
          qty_returned: 0,
          reason: '',
          resolution: '',
          rma_entity_id: 0,
          status: ''
        }
      ],
      order_id: 0,
      order_increment_id: '',
      status: '',
      store_id: 0,
      tracks: [
        {
          carrier_code: '',
          carrier_title: '',
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          track_number: ''
        }
      ]
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/returns/:id');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  rmaDataObject: {
    comments: [
      {
        admin: false,
        comment: '',
        created_at: '',
        custom_attributes: [
          {
            attribute_code: '',
            value: ''
          }
        ],
        customer_notified: false,
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        status: '',
        visible_on_front: false
      }
    ],
    custom_attributes: [
      {}
    ],
    customer_custom_email: '',
    customer_id: 0,
    date_requested: '',
    entity_id: 0,
    extension_attributes: {},
    increment_id: '',
    items: [
      {
        condition: '',
        entity_id: 0,
        extension_attributes: {},
        order_item_id: 0,
        qty_approved: 0,
        qty_authorized: 0,
        qty_requested: 0,
        qty_returned: 0,
        reason: '',
        resolution: '',
        rma_entity_id: 0,
        status: ''
      }
    ],
    order_id: 0,
    order_increment_id: '',
    status: '',
    store_id: 0,
    tracks: [
      {
        carrier_code: '',
        carrier_title: '',
        entity_id: 0,
        extension_attributes: {},
        rma_entity_id: 0,
        track_number: ''
      }
    ]
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/returns/:id',
  headers: {'content-type': 'application/json'},
  data: {
    rmaDataObject: {
      comments: [
        {
          admin: false,
          comment: '',
          created_at: '',
          custom_attributes: [{attribute_code: '', value: ''}],
          customer_notified: false,
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          status: '',
          visible_on_front: false
        }
      ],
      custom_attributes: [{}],
      customer_custom_email: '',
      customer_id: 0,
      date_requested: '',
      entity_id: 0,
      extension_attributes: {},
      increment_id: '',
      items: [
        {
          condition: '',
          entity_id: 0,
          extension_attributes: {},
          order_item_id: 0,
          qty_approved: 0,
          qty_authorized: 0,
          qty_requested: 0,
          qty_returned: 0,
          reason: '',
          resolution: '',
          rma_entity_id: 0,
          status: ''
        }
      ],
      order_id: 0,
      order_increment_id: '',
      status: '',
      store_id: 0,
      tracks: [
        {
          carrier_code: '',
          carrier_title: '',
          entity_id: 0,
          extension_attributes: {},
          rma_entity_id: 0,
          track_number: ''
        }
      ]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/returns/:id';
const options = {
  method: 'DELETE',
  headers: {'content-type': 'application/json'},
  body: '{"rmaDataObject":{"comments":[{"admin":false,"comment":"","created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_notified":false,"entity_id":0,"extension_attributes":{},"rma_entity_id":0,"status":"","visible_on_front":false}],"custom_attributes":[{}],"customer_custom_email":"","customer_id":0,"date_requested":"","entity_id":0,"extension_attributes":{},"increment_id":"","items":[{"condition":"","entity_id":0,"extension_attributes":{},"order_item_id":0,"qty_approved":0,"qty_authorized":0,"qty_requested":0,"qty_returned":0,"reason":"","resolution":"","rma_entity_id":0,"status":""}],"order_id":0,"order_increment_id":"","status":"","store_id":0,"tracks":[{"carrier_code":"","carrier_title":"","entity_id":0,"extension_attributes":{},"rma_entity_id":0,"track_number":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"rmaDataObject": @{ @"comments": @[ @{ @"admin": @NO, @"comment": @"", @"created_at": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_notified": @NO, @"entity_id": @0, @"extension_attributes": @{  }, @"rma_entity_id": @0, @"status": @"", @"visible_on_front": @NO } ], @"custom_attributes": @[ @{  } ], @"customer_custom_email": @"", @"customer_id": @0, @"date_requested": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"increment_id": @"", @"items": @[ @{ @"condition": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"order_item_id": @0, @"qty_approved": @0, @"qty_authorized": @0, @"qty_requested": @0, @"qty_returned": @0, @"reason": @"", @"resolution": @"", @"rma_entity_id": @0, @"status": @"" } ], @"order_id": @0, @"order_increment_id": @"", @"status": @"", @"store_id": @0, @"tracks": @[ @{ @"carrier_code": @"", @"carrier_title": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"rma_entity_id": @0, @"track_number": @"" } ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/returns/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/returns/:id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}" in

Client.call ~headers ~body `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/returns/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_POSTFIELDS => json_encode([
    'rmaDataObject' => [
        'comments' => [
                [
                                'admin' => null,
                                'comment' => '',
                                'created_at' => '',
                                'custom_attributes' => [
                                                                [
                                                                                                                                'attribute_code' => '',
                                                                                                                                'value' => ''
                                                                ]
                                ],
                                'customer_notified' => null,
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'rma_entity_id' => 0,
                                'status' => '',
                                'visible_on_front' => null
                ]
        ],
        'custom_attributes' => [
                [
                                
                ]
        ],
        'customer_custom_email' => '',
        'customer_id' => 0,
        'date_requested' => '',
        'entity_id' => 0,
        'extension_attributes' => [
                
        ],
        'increment_id' => '',
        'items' => [
                [
                                'condition' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'order_item_id' => 0,
                                'qty_approved' => 0,
                                'qty_authorized' => 0,
                                'qty_requested' => 0,
                                'qty_returned' => 0,
                                'reason' => '',
                                'resolution' => '',
                                'rma_entity_id' => 0,
                                'status' => ''
                ]
        ],
        'order_id' => 0,
        'order_increment_id' => '',
        'status' => '',
        'store_id' => 0,
        'tracks' => [
                [
                                'carrier_code' => '',
                                'carrier_title' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'rma_entity_id' => 0,
                                'track_number' => ''
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/returns/:id', [
  'body' => '{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/returns/:id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'rmaDataObject' => [
    'comments' => [
        [
                'admin' => null,
                'comment' => '',
                'created_at' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_notified' => null,
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'rma_entity_id' => 0,
                'status' => '',
                'visible_on_front' => null
        ]
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'customer_custom_email' => '',
    'customer_id' => 0,
    'date_requested' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'increment_id' => '',
    'items' => [
        [
                'condition' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'order_item_id' => 0,
                'qty_approved' => 0,
                'qty_authorized' => 0,
                'qty_requested' => 0,
                'qty_returned' => 0,
                'reason' => '',
                'resolution' => '',
                'rma_entity_id' => 0,
                'status' => ''
        ]
    ],
    'order_id' => 0,
    'order_increment_id' => '',
    'status' => '',
    'store_id' => 0,
    'tracks' => [
        [
                'carrier_code' => '',
                'carrier_title' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'rma_entity_id' => 0,
                'track_number' => ''
        ]
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'rmaDataObject' => [
    'comments' => [
        [
                'admin' => null,
                'comment' => '',
                'created_at' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'customer_notified' => null,
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'rma_entity_id' => 0,
                'status' => '',
                'visible_on_front' => null
        ]
    ],
    'custom_attributes' => [
        [
                
        ]
    ],
    'customer_custom_email' => '',
    'customer_id' => 0,
    'date_requested' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'increment_id' => '',
    'items' => [
        [
                'condition' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'order_item_id' => 0,
                'qty_approved' => 0,
                'qty_authorized' => 0,
                'qty_requested' => 0,
                'qty_returned' => 0,
                'reason' => '',
                'resolution' => '',
                'rma_entity_id' => 0,
                'status' => ''
        ]
    ],
    'order_id' => 0,
    'order_increment_id' => '',
    'status' => '',
    'store_id' => 0,
    'tracks' => [
        [
                'carrier_code' => '',
                'carrier_title' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'rma_entity_id' => 0,
                'track_number' => ''
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/returns/:id');
$request->setRequestMethod('DELETE');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/returns/:id' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/returns/:id' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("DELETE", "/baseUrl/V1/returns/:id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/returns/:id"

payload = { "rmaDataObject": {
        "comments": [
            {
                "admin": False,
                "comment": "",
                "created_at": "",
                "custom_attributes": [
                    {
                        "attribute_code": "",
                        "value": ""
                    }
                ],
                "customer_notified": False,
                "entity_id": 0,
                "extension_attributes": {},
                "rma_entity_id": 0,
                "status": "",
                "visible_on_front": False
            }
        ],
        "custom_attributes": [{}],
        "customer_custom_email": "",
        "customer_id": 0,
        "date_requested": "",
        "entity_id": 0,
        "extension_attributes": {},
        "increment_id": "",
        "items": [
            {
                "condition": "",
                "entity_id": 0,
                "extension_attributes": {},
                "order_item_id": 0,
                "qty_approved": 0,
                "qty_authorized": 0,
                "qty_requested": 0,
                "qty_returned": 0,
                "reason": "",
                "resolution": "",
                "rma_entity_id": 0,
                "status": ""
            }
        ],
        "order_id": 0,
        "order_increment_id": "",
        "status": "",
        "store_id": 0,
        "tracks": [
            {
                "carrier_code": "",
                "carrier_title": "",
                "entity_id": 0,
                "extension_attributes": {},
                "rma_entity_id": 0,
                "track_number": ""
            }
        ]
    } }
headers = {"content-type": "application/json"}

response = requests.delete(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/returns/:id"

payload <- "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}"

encode <- "json"

response <- VERB("DELETE", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/returns/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.delete('/baseUrl/V1/returns/:id') do |req|
  req.body = "{\n  \"rmaDataObject\": {\n    \"comments\": [\n      {\n        \"admin\": false,\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"custom_attributes\": [\n          {\n            \"attribute_code\": \"\",\n            \"value\": \"\"\n          }\n        ],\n        \"customer_notified\": false,\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"status\": \"\",\n        \"visible_on_front\": false\n      }\n    ],\n    \"custom_attributes\": [\n      {}\n    ],\n    \"customer_custom_email\": \"\",\n    \"customer_id\": 0,\n    \"date_requested\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"condition\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_item_id\": 0,\n        \"qty_approved\": 0,\n        \"qty_authorized\": 0,\n        \"qty_requested\": 0,\n        \"qty_returned\": 0,\n        \"reason\": \"\",\n        \"resolution\": \"\",\n        \"rma_entity_id\": 0,\n        \"status\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"order_increment_id\": \"\",\n    \"status\": \"\",\n    \"store_id\": 0,\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"carrier_title\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"rma_entity_id\": 0,\n        \"track_number\": \"\"\n      }\n    ]\n  }\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/returns/:id";

    let payload = json!({"rmaDataObject": json!({
            "comments": (
                json!({
                    "admin": false,
                    "comment": "",
                    "created_at": "",
                    "custom_attributes": (
                        json!({
                            "attribute_code": "",
                            "value": ""
                        })
                    ),
                    "customer_notified": false,
                    "entity_id": 0,
                    "extension_attributes": json!({}),
                    "rma_entity_id": 0,
                    "status": "",
                    "visible_on_front": false
                })
            ),
            "custom_attributes": (json!({})),
            "customer_custom_email": "",
            "customer_id": 0,
            "date_requested": "",
            "entity_id": 0,
            "extension_attributes": json!({}),
            "increment_id": "",
            "items": (
                json!({
                    "condition": "",
                    "entity_id": 0,
                    "extension_attributes": json!({}),
                    "order_item_id": 0,
                    "qty_approved": 0,
                    "qty_authorized": 0,
                    "qty_requested": 0,
                    "qty_returned": 0,
                    "reason": "",
                    "resolution": "",
                    "rma_entity_id": 0,
                    "status": ""
                })
            ),
            "order_id": 0,
            "order_increment_id": "",
            "status": "",
            "store_id": 0,
            "tracks": (
                json!({
                    "carrier_code": "",
                    "carrier_title": "",
                    "entity_id": 0,
                    "extension_attributes": json!({}),
                    "rma_entity_id": 0,
                    "track_number": ""
                })
            )
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/returns/:id \
  --header 'content-type: application/json' \
  --data '{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}'
echo '{
  "rmaDataObject": {
    "comments": [
      {
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          {
            "attribute_code": "",
            "value": ""
          }
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      }
    ],
    "custom_attributes": [
      {}
    ],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": {},
    "increment_id": "",
    "items": [
      {
        "condition": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      }
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
      }
    ]
  }
}' |  \
  http DELETE {{baseUrl}}/V1/returns/:id \
  content-type:application/json
wget --quiet \
  --method DELETE \
  --header 'content-type: application/json' \
  --body-data '{\n  "rmaDataObject": {\n    "comments": [\n      {\n        "admin": false,\n        "comment": "",\n        "created_at": "",\n        "custom_attributes": [\n          {\n            "attribute_code": "",\n            "value": ""\n          }\n        ],\n        "customer_notified": false,\n        "entity_id": 0,\n        "extension_attributes": {},\n        "rma_entity_id": 0,\n        "status": "",\n        "visible_on_front": false\n      }\n    ],\n    "custom_attributes": [\n      {}\n    ],\n    "customer_custom_email": "",\n    "customer_id": 0,\n    "date_requested": "",\n    "entity_id": 0,\n    "extension_attributes": {},\n    "increment_id": "",\n    "items": [\n      {\n        "condition": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "order_item_id": 0,\n        "qty_approved": 0,\n        "qty_authorized": 0,\n        "qty_requested": 0,\n        "qty_returned": 0,\n        "reason": "",\n        "resolution": "",\n        "rma_entity_id": 0,\n        "status": ""\n      }\n    ],\n    "order_id": 0,\n    "order_increment_id": "",\n    "status": "",\n    "store_id": 0,\n    "tracks": [\n      {\n        "carrier_code": "",\n        "carrier_title": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "rma_entity_id": 0,\n        "track_number": ""\n      }\n    ]\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/returns/:id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["rmaDataObject": [
    "comments": [
      [
        "admin": false,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
          [
            "attribute_code": "",
            "value": ""
          ]
        ],
        "customer_notified": false,
        "entity_id": 0,
        "extension_attributes": [],
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": false
      ]
    ],
    "custom_attributes": [[]],
    "customer_custom_email": "",
    "customer_id": 0,
    "date_requested": "",
    "entity_id": 0,
    "extension_attributes": [],
    "increment_id": "",
    "items": [
      [
        "condition": "",
        "entity_id": 0,
        "extension_attributes": [],
        "order_item_id": 0,
        "qty_approved": 0,
        "qty_authorized": 0,
        "qty_requested": 0,
        "qty_returned": 0,
        "reason": "",
        "resolution": "",
        "rma_entity_id": 0,
        "status": ""
      ]
    ],
    "order_id": 0,
    "order_increment_id": "",
    "status": "",
    "store_id": 0,
    "tracks": [
      [
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": [],
        "rma_entity_id": 0,
        "track_number": ""
      ]
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/returns/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST returns-{id}-comments (POST)
{{baseUrl}}/V1/returns/:id/comments
QUERY PARAMS

id
BODY json

{
  "data": {
    "admin": false,
    "comment": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_notified": false,
    "entity_id": 0,
    "extension_attributes": {},
    "rma_entity_id": 0,
    "status": "",
    "visible_on_front": false
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/returns/:id/comments");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"data\": {\n    \"admin\": false,\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_notified\": false,\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"status\": \"\",\n    \"visible_on_front\": false\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/returns/:id/comments" {:content-type :json
                                                                    :form-params {:data {:admin false
                                                                                         :comment ""
                                                                                         :created_at ""
                                                                                         :custom_attributes [{:attribute_code ""
                                                                                                              :value ""}]
                                                                                         :customer_notified false
                                                                                         :entity_id 0
                                                                                         :extension_attributes {}
                                                                                         :rma_entity_id 0
                                                                                         :status ""
                                                                                         :visible_on_front false}}})
require "http/client"

url = "{{baseUrl}}/V1/returns/:id/comments"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"data\": {\n    \"admin\": false,\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_notified\": false,\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"status\": \"\",\n    \"visible_on_front\": false\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}}/V1/returns/:id/comments"),
    Content = new StringContent("{\n  \"data\": {\n    \"admin\": false,\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_notified\": false,\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"status\": \"\",\n    \"visible_on_front\": false\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}}/V1/returns/:id/comments");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"data\": {\n    \"admin\": false,\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_notified\": false,\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"status\": \"\",\n    \"visible_on_front\": false\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/returns/:id/comments"

	payload := strings.NewReader("{\n  \"data\": {\n    \"admin\": false,\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_notified\": false,\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"status\": \"\",\n    \"visible_on_front\": false\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/returns/:id/comments HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 336

{
  "data": {
    "admin": false,
    "comment": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_notified": false,
    "entity_id": 0,
    "extension_attributes": {},
    "rma_entity_id": 0,
    "status": "",
    "visible_on_front": false
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/returns/:id/comments")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"data\": {\n    \"admin\": false,\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_notified\": false,\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"status\": \"\",\n    \"visible_on_front\": false\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/returns/:id/comments"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"data\": {\n    \"admin\": false,\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_notified\": false,\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"status\": \"\",\n    \"visible_on_front\": false\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  \"data\": {\n    \"admin\": false,\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_notified\": false,\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"status\": \"\",\n    \"visible_on_front\": false\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/returns/:id/comments")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/returns/:id/comments")
  .header("content-type", "application/json")
  .body("{\n  \"data\": {\n    \"admin\": false,\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_notified\": false,\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"status\": \"\",\n    \"visible_on_front\": false\n  }\n}")
  .asString();
const data = JSON.stringify({
  data: {
    admin: false,
    comment: '',
    created_at: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_notified: false,
    entity_id: 0,
    extension_attributes: {},
    rma_entity_id: 0,
    status: '',
    visible_on_front: 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}}/V1/returns/:id/comments');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/returns/:id/comments',
  headers: {'content-type': 'application/json'},
  data: {
    data: {
      admin: false,
      comment: '',
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_notified: false,
      entity_id: 0,
      extension_attributes: {},
      rma_entity_id: 0,
      status: '',
      visible_on_front: false
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/returns/:id/comments';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"data":{"admin":false,"comment":"","created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_notified":false,"entity_id":0,"extension_attributes":{},"rma_entity_id":0,"status":"","visible_on_front":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}}/V1/returns/:id/comments',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "data": {\n    "admin": false,\n    "comment": "",\n    "created_at": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_notified": false,\n    "entity_id": 0,\n    "extension_attributes": {},\n    "rma_entity_id": 0,\n    "status": "",\n    "visible_on_front": false\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  \"data\": {\n    \"admin\": false,\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_notified\": false,\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"status\": \"\",\n    \"visible_on_front\": false\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/returns/:id/comments")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/returns/:id/comments',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  data: {
    admin: false,
    comment: '',
    created_at: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    customer_notified: false,
    entity_id: 0,
    extension_attributes: {},
    rma_entity_id: 0,
    status: '',
    visible_on_front: false
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/returns/:id/comments',
  headers: {'content-type': 'application/json'},
  body: {
    data: {
      admin: false,
      comment: '',
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_notified: false,
      entity_id: 0,
      extension_attributes: {},
      rma_entity_id: 0,
      status: '',
      visible_on_front: 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}}/V1/returns/:id/comments');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  data: {
    admin: false,
    comment: '',
    created_at: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_notified: false,
    entity_id: 0,
    extension_attributes: {},
    rma_entity_id: 0,
    status: '',
    visible_on_front: 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}}/V1/returns/:id/comments',
  headers: {'content-type': 'application/json'},
  data: {
    data: {
      admin: false,
      comment: '',
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_notified: false,
      entity_id: 0,
      extension_attributes: {},
      rma_entity_id: 0,
      status: '',
      visible_on_front: false
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/returns/:id/comments';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"data":{"admin":false,"comment":"","created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_notified":false,"entity_id":0,"extension_attributes":{},"rma_entity_id":0,"status":"","visible_on_front":false}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"data": @{ @"admin": @NO, @"comment": @"", @"created_at": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_notified": @NO, @"entity_id": @0, @"extension_attributes": @{  }, @"rma_entity_id": @0, @"status": @"", @"visible_on_front": @NO } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/returns/:id/comments"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/returns/:id/comments" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"data\": {\n    \"admin\": false,\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_notified\": false,\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"status\": \"\",\n    \"visible_on_front\": false\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/returns/:id/comments",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'data' => [
        'admin' => null,
        'comment' => '',
        'created_at' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_notified' => null,
        'entity_id' => 0,
        'extension_attributes' => [
                
        ],
        'rma_entity_id' => 0,
        'status' => '',
        'visible_on_front' => null
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/returns/:id/comments', [
  'body' => '{
  "data": {
    "admin": false,
    "comment": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_notified": false,
    "entity_id": 0,
    "extension_attributes": {},
    "rma_entity_id": 0,
    "status": "",
    "visible_on_front": false
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/returns/:id/comments');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'data' => [
    'admin' => null,
    'comment' => '',
    'created_at' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_notified' => null,
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'rma_entity_id' => 0,
    'status' => '',
    'visible_on_front' => null
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'data' => [
    'admin' => null,
    'comment' => '',
    'created_at' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_notified' => null,
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'rma_entity_id' => 0,
    'status' => '',
    'visible_on_front' => null
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/returns/:id/comments');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/returns/:id/comments' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "data": {
    "admin": false,
    "comment": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_notified": false,
    "entity_id": 0,
    "extension_attributes": {},
    "rma_entity_id": 0,
    "status": "",
    "visible_on_front": false
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/returns/:id/comments' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "data": {
    "admin": false,
    "comment": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_notified": false,
    "entity_id": 0,
    "extension_attributes": {},
    "rma_entity_id": 0,
    "status": "",
    "visible_on_front": false
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"data\": {\n    \"admin\": false,\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_notified\": false,\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"status\": \"\",\n    \"visible_on_front\": false\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/returns/:id/comments", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/returns/:id/comments"

payload = { "data": {
        "admin": False,
        "comment": "",
        "created_at": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "customer_notified": False,
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "status": "",
        "visible_on_front": False
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/returns/:id/comments"

payload <- "{\n  \"data\": {\n    \"admin\": false,\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_notified\": false,\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"status\": \"\",\n    \"visible_on_front\": false\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/returns/:id/comments")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"data\": {\n    \"admin\": false,\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_notified\": false,\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"status\": \"\",\n    \"visible_on_front\": false\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/V1/returns/:id/comments') do |req|
  req.body = "{\n  \"data\": {\n    \"admin\": false,\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_notified\": false,\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"status\": \"\",\n    \"visible_on_front\": false\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/returns/:id/comments";

    let payload = json!({"data": json!({
            "admin": false,
            "comment": "",
            "created_at": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "customer_notified": false,
            "entity_id": 0,
            "extension_attributes": json!({}),
            "rma_entity_id": 0,
            "status": "",
            "visible_on_front": false
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/returns/:id/comments \
  --header 'content-type: application/json' \
  --data '{
  "data": {
    "admin": false,
    "comment": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_notified": false,
    "entity_id": 0,
    "extension_attributes": {},
    "rma_entity_id": 0,
    "status": "",
    "visible_on_front": false
  }
}'
echo '{
  "data": {
    "admin": false,
    "comment": "",
    "created_at": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_notified": false,
    "entity_id": 0,
    "extension_attributes": {},
    "rma_entity_id": 0,
    "status": "",
    "visible_on_front": false
  }
}' |  \
  http POST {{baseUrl}}/V1/returns/:id/comments \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "data": {\n    "admin": false,\n    "comment": "",\n    "created_at": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_notified": false,\n    "entity_id": 0,\n    "extension_attributes": {},\n    "rma_entity_id": 0,\n    "status": "",\n    "visible_on_front": false\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/returns/:id/comments
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["data": [
    "admin": false,
    "comment": "",
    "created_at": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "customer_notified": false,
    "entity_id": 0,
    "extension_attributes": [],
    "rma_entity_id": 0,
    "status": "",
    "visible_on_front": false
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/returns/:id/comments")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET returns-{id}-comments
{{baseUrl}}/V1/returns/:id/comments
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/returns/:id/comments");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/returns/:id/comments")
require "http/client"

url = "{{baseUrl}}/V1/returns/:id/comments"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/returns/:id/comments"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/returns/:id/comments");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/returns/:id/comments"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/returns/:id/comments HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/returns/:id/comments")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/returns/:id/comments"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/returns/:id/comments")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/returns/:id/comments")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/returns/:id/comments');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/returns/:id/comments'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/returns/:id/comments';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/returns/:id/comments',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/returns/:id/comments")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/returns/:id/comments',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/returns/:id/comments'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/returns/:id/comments');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/returns/:id/comments'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/returns/:id/comments';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/returns/:id/comments"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/returns/:id/comments" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/returns/:id/comments",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/returns/:id/comments');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/returns/:id/comments');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/returns/:id/comments');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/returns/:id/comments' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/returns/:id/comments' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/returns/:id/comments")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/returns/:id/comments"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/returns/:id/comments"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/returns/:id/comments")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/returns/:id/comments') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/returns/:id/comments";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/returns/:id/comments
http GET {{baseUrl}}/V1/returns/:id/comments
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/returns/:id/comments
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/returns/:id/comments")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET returns-{id}-labels
{{baseUrl}}/V1/returns/:id/labels
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/returns/:id/labels");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/returns/:id/labels")
require "http/client"

url = "{{baseUrl}}/V1/returns/:id/labels"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/returns/:id/labels"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/returns/:id/labels");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/returns/:id/labels"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/returns/:id/labels HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/returns/:id/labels")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/returns/:id/labels"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/returns/:id/labels")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/returns/:id/labels")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/returns/:id/labels');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/returns/:id/labels'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/returns/:id/labels';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/returns/:id/labels',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/returns/:id/labels")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/returns/:id/labels',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/returns/:id/labels'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/returns/:id/labels');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/returns/:id/labels'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/returns/:id/labels';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/returns/:id/labels"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/returns/:id/labels" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/returns/:id/labels",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/returns/:id/labels');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/returns/:id/labels');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/returns/:id/labels');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/returns/:id/labels' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/returns/:id/labels' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/returns/:id/labels")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/returns/:id/labels"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/returns/:id/labels"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/returns/:id/labels")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/returns/:id/labels') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/returns/:id/labels";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/returns/:id/labels
http GET {{baseUrl}}/V1/returns/:id/labels
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/returns/:id/labels
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/returns/:id/labels")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST returns-{id}-tracking-numbers (POST)
{{baseUrl}}/V1/returns/:id/tracking-numbers
QUERY PARAMS

id
BODY json

{
  "track": {
    "carrier_code": "",
    "carrier_title": "",
    "entity_id": 0,
    "extension_attributes": {},
    "rma_entity_id": 0,
    "track_number": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/returns/:id/tracking-numbers");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"track\": {\n    \"carrier_code\": \"\",\n    \"carrier_title\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"track_number\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/returns/:id/tracking-numbers" {:content-type :json
                                                                            :form-params {:track {:carrier_code ""
                                                                                                  :carrier_title ""
                                                                                                  :entity_id 0
                                                                                                  :extension_attributes {}
                                                                                                  :rma_entity_id 0
                                                                                                  :track_number ""}}})
require "http/client"

url = "{{baseUrl}}/V1/returns/:id/tracking-numbers"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"track\": {\n    \"carrier_code\": \"\",\n    \"carrier_title\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"track_number\": \"\"\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}}/V1/returns/:id/tracking-numbers"),
    Content = new StringContent("{\n  \"track\": {\n    \"carrier_code\": \"\",\n    \"carrier_title\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"track_number\": \"\"\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}}/V1/returns/:id/tracking-numbers");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"track\": {\n    \"carrier_code\": \"\",\n    \"carrier_title\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"track_number\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/returns/:id/tracking-numbers"

	payload := strings.NewReader("{\n  \"track\": {\n    \"carrier_code\": \"\",\n    \"carrier_title\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"track_number\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/returns/:id/tracking-numbers HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 168

{
  "track": {
    "carrier_code": "",
    "carrier_title": "",
    "entity_id": 0,
    "extension_attributes": {},
    "rma_entity_id": 0,
    "track_number": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/returns/:id/tracking-numbers")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"track\": {\n    \"carrier_code\": \"\",\n    \"carrier_title\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"track_number\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/returns/:id/tracking-numbers"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"track\": {\n    \"carrier_code\": \"\",\n    \"carrier_title\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"track_number\": \"\"\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  \"track\": {\n    \"carrier_code\": \"\",\n    \"carrier_title\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"track_number\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/returns/:id/tracking-numbers")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/returns/:id/tracking-numbers")
  .header("content-type", "application/json")
  .body("{\n  \"track\": {\n    \"carrier_code\": \"\",\n    \"carrier_title\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"track_number\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  track: {
    carrier_code: '',
    carrier_title: '',
    entity_id: 0,
    extension_attributes: {},
    rma_entity_id: 0,
    track_number: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/returns/:id/tracking-numbers');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/returns/:id/tracking-numbers',
  headers: {'content-type': 'application/json'},
  data: {
    track: {
      carrier_code: '',
      carrier_title: '',
      entity_id: 0,
      extension_attributes: {},
      rma_entity_id: 0,
      track_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/returns/:id/tracking-numbers';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"track":{"carrier_code":"","carrier_title":"","entity_id":0,"extension_attributes":{},"rma_entity_id":0,"track_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/returns/:id/tracking-numbers',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "track": {\n    "carrier_code": "",\n    "carrier_title": "",\n    "entity_id": 0,\n    "extension_attributes": {},\n    "rma_entity_id": 0,\n    "track_number": ""\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  \"track\": {\n    \"carrier_code\": \"\",\n    \"carrier_title\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"track_number\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/returns/:id/tracking-numbers")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/returns/:id/tracking-numbers',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  track: {
    carrier_code: '',
    carrier_title: '',
    entity_id: 0,
    extension_attributes: {},
    rma_entity_id: 0,
    track_number: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/returns/:id/tracking-numbers',
  headers: {'content-type': 'application/json'},
  body: {
    track: {
      carrier_code: '',
      carrier_title: '',
      entity_id: 0,
      extension_attributes: {},
      rma_entity_id: 0,
      track_number: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/returns/:id/tracking-numbers');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  track: {
    carrier_code: '',
    carrier_title: '',
    entity_id: 0,
    extension_attributes: {},
    rma_entity_id: 0,
    track_number: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/returns/:id/tracking-numbers',
  headers: {'content-type': 'application/json'},
  data: {
    track: {
      carrier_code: '',
      carrier_title: '',
      entity_id: 0,
      extension_attributes: {},
      rma_entity_id: 0,
      track_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/returns/:id/tracking-numbers';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"track":{"carrier_code":"","carrier_title":"","entity_id":0,"extension_attributes":{},"rma_entity_id":0,"track_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"track": @{ @"carrier_code": @"", @"carrier_title": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"rma_entity_id": @0, @"track_number": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/returns/:id/tracking-numbers"]
                                                       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}}/V1/returns/:id/tracking-numbers" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"track\": {\n    \"carrier_code\": \"\",\n    \"carrier_title\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"track_number\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/returns/:id/tracking-numbers",
  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([
    'track' => [
        'carrier_code' => '',
        'carrier_title' => '',
        'entity_id' => 0,
        'extension_attributes' => [
                
        ],
        'rma_entity_id' => 0,
        'track_number' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/returns/:id/tracking-numbers', [
  'body' => '{
  "track": {
    "carrier_code": "",
    "carrier_title": "",
    "entity_id": 0,
    "extension_attributes": {},
    "rma_entity_id": 0,
    "track_number": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/returns/:id/tracking-numbers');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'track' => [
    'carrier_code' => '',
    'carrier_title' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'rma_entity_id' => 0,
    'track_number' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'track' => [
    'carrier_code' => '',
    'carrier_title' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'rma_entity_id' => 0,
    'track_number' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/returns/:id/tracking-numbers');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/returns/:id/tracking-numbers' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "track": {
    "carrier_code": "",
    "carrier_title": "",
    "entity_id": 0,
    "extension_attributes": {},
    "rma_entity_id": 0,
    "track_number": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/returns/:id/tracking-numbers' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "track": {
    "carrier_code": "",
    "carrier_title": "",
    "entity_id": 0,
    "extension_attributes": {},
    "rma_entity_id": 0,
    "track_number": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"track\": {\n    \"carrier_code\": \"\",\n    \"carrier_title\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"track_number\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/returns/:id/tracking-numbers", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/returns/:id/tracking-numbers"

payload = { "track": {
        "carrier_code": "",
        "carrier_title": "",
        "entity_id": 0,
        "extension_attributes": {},
        "rma_entity_id": 0,
        "track_number": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/returns/:id/tracking-numbers"

payload <- "{\n  \"track\": {\n    \"carrier_code\": \"\",\n    \"carrier_title\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"track_number\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/returns/:id/tracking-numbers")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"track\": {\n    \"carrier_code\": \"\",\n    \"carrier_title\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"track_number\": \"\"\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/V1/returns/:id/tracking-numbers') do |req|
  req.body = "{\n  \"track\": {\n    \"carrier_code\": \"\",\n    \"carrier_title\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"rma_entity_id\": 0,\n    \"track_number\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/returns/:id/tracking-numbers";

    let payload = json!({"track": json!({
            "carrier_code": "",
            "carrier_title": "",
            "entity_id": 0,
            "extension_attributes": json!({}),
            "rma_entity_id": 0,
            "track_number": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/returns/:id/tracking-numbers \
  --header 'content-type: application/json' \
  --data '{
  "track": {
    "carrier_code": "",
    "carrier_title": "",
    "entity_id": 0,
    "extension_attributes": {},
    "rma_entity_id": 0,
    "track_number": ""
  }
}'
echo '{
  "track": {
    "carrier_code": "",
    "carrier_title": "",
    "entity_id": 0,
    "extension_attributes": {},
    "rma_entity_id": 0,
    "track_number": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/returns/:id/tracking-numbers \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "track": {\n    "carrier_code": "",\n    "carrier_title": "",\n    "entity_id": 0,\n    "extension_attributes": {},\n    "rma_entity_id": 0,\n    "track_number": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/returns/:id/tracking-numbers
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["track": [
    "carrier_code": "",
    "carrier_title": "",
    "entity_id": 0,
    "extension_attributes": [],
    "rma_entity_id": 0,
    "track_number": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/returns/:id/tracking-numbers")! 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 returns-{id}-tracking-numbers
{{baseUrl}}/V1/returns/:id/tracking-numbers
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/returns/:id/tracking-numbers");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/returns/:id/tracking-numbers")
require "http/client"

url = "{{baseUrl}}/V1/returns/:id/tracking-numbers"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/returns/:id/tracking-numbers"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/returns/:id/tracking-numbers");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/returns/:id/tracking-numbers"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/returns/:id/tracking-numbers HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/returns/:id/tracking-numbers")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/returns/:id/tracking-numbers"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/returns/:id/tracking-numbers")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/returns/:id/tracking-numbers")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/returns/:id/tracking-numbers');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/returns/:id/tracking-numbers'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/returns/:id/tracking-numbers';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/returns/:id/tracking-numbers',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/returns/:id/tracking-numbers")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/returns/:id/tracking-numbers',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/returns/:id/tracking-numbers'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/returns/:id/tracking-numbers');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/returns/:id/tracking-numbers'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/returns/:id/tracking-numbers';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/returns/:id/tracking-numbers"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/returns/:id/tracking-numbers" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/returns/:id/tracking-numbers",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/returns/:id/tracking-numbers');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/returns/:id/tracking-numbers');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/returns/:id/tracking-numbers');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/returns/:id/tracking-numbers' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/returns/:id/tracking-numbers' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/returns/:id/tracking-numbers")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/returns/:id/tracking-numbers"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/returns/:id/tracking-numbers"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/returns/:id/tracking-numbers")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/returns/:id/tracking-numbers') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/returns/:id/tracking-numbers";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/returns/:id/tracking-numbers
http GET {{baseUrl}}/V1/returns/:id/tracking-numbers
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/returns/:id/tracking-numbers
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/returns/:id/tracking-numbers")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE returns-{id}-tracking-numbers-{trackId}
{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId
QUERY PARAMS

id
trackId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId")
require "http/client"

url = "{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/returns/:id/tracking-numbers/:trackId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId"))
    .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}}/V1/returns/:id/tracking-numbers/:trackId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId")
  .asString();
const 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}}/V1/returns/:id/tracking-numbers/:trackId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/returns/:id/tracking-numbers/:trackId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId');

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}}/V1/returns/:id/tracking-numbers/:trackId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/returns/:id/tracking-numbers/:trackId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/returns/:id/tracking-numbers/:trackId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId
http DELETE {{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/returns/:id/tracking-numbers/:trackId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET returnsAttributeMetadata
{{baseUrl}}/V1/returnsAttributeMetadata
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/returnsAttributeMetadata");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/returnsAttributeMetadata")
require "http/client"

url = "{{baseUrl}}/V1/returnsAttributeMetadata"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/returnsAttributeMetadata"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/returnsAttributeMetadata");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/returnsAttributeMetadata"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/returnsAttributeMetadata HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/returnsAttributeMetadata")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/returnsAttributeMetadata"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/returnsAttributeMetadata")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/returnsAttributeMetadata")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/returnsAttributeMetadata');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/returnsAttributeMetadata'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/returnsAttributeMetadata';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/returnsAttributeMetadata',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/returnsAttributeMetadata")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/returnsAttributeMetadata',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/returnsAttributeMetadata'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/returnsAttributeMetadata');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/returnsAttributeMetadata'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/returnsAttributeMetadata';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/returnsAttributeMetadata"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/returnsAttributeMetadata" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/returnsAttributeMetadata",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/returnsAttributeMetadata');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/returnsAttributeMetadata');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/returnsAttributeMetadata');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/returnsAttributeMetadata' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/returnsAttributeMetadata' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/returnsAttributeMetadata")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/returnsAttributeMetadata"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/returnsAttributeMetadata"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/returnsAttributeMetadata")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/returnsAttributeMetadata') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/returnsAttributeMetadata";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/returnsAttributeMetadata
http GET {{baseUrl}}/V1/returnsAttributeMetadata
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/returnsAttributeMetadata
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/returnsAttributeMetadata")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET returnsAttributeMetadata-{attributeCode}
{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode
QUERY PARAMS

attributeCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode")
require "http/client"

url = "{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/returnsAttributeMetadata/:attributeCode HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/returnsAttributeMetadata/:attributeCode',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/returnsAttributeMetadata/:attributeCode")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/returnsAttributeMetadata/:attributeCode') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode
http GET {{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/returnsAttributeMetadata/:attributeCode")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET returnsAttributeMetadata-custom
{{baseUrl}}/V1/returnsAttributeMetadata/custom
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/returnsAttributeMetadata/custom");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/returnsAttributeMetadata/custom")
require "http/client"

url = "{{baseUrl}}/V1/returnsAttributeMetadata/custom"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/returnsAttributeMetadata/custom"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/returnsAttributeMetadata/custom");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/returnsAttributeMetadata/custom"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/returnsAttributeMetadata/custom HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/returnsAttributeMetadata/custom")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/returnsAttributeMetadata/custom"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/returnsAttributeMetadata/custom")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/returnsAttributeMetadata/custom")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/returnsAttributeMetadata/custom');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/returnsAttributeMetadata/custom'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/returnsAttributeMetadata/custom';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/returnsAttributeMetadata/custom',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/returnsAttributeMetadata/custom")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/returnsAttributeMetadata/custom',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/returnsAttributeMetadata/custom'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/returnsAttributeMetadata/custom');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/returnsAttributeMetadata/custom'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/returnsAttributeMetadata/custom';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/returnsAttributeMetadata/custom"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/returnsAttributeMetadata/custom" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/returnsAttributeMetadata/custom",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/returnsAttributeMetadata/custom');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/returnsAttributeMetadata/custom');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/returnsAttributeMetadata/custom');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/returnsAttributeMetadata/custom' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/returnsAttributeMetadata/custom' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/returnsAttributeMetadata/custom")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/returnsAttributeMetadata/custom"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/returnsAttributeMetadata/custom"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/returnsAttributeMetadata/custom")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/returnsAttributeMetadata/custom') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/returnsAttributeMetadata/custom";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/returnsAttributeMetadata/custom
http GET {{baseUrl}}/V1/returnsAttributeMetadata/custom
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/returnsAttributeMetadata/custom
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/returnsAttributeMetadata/custom")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET returnsAttributeMetadata-form-{formCode}
{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode
QUERY PARAMS

formCode
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode")
require "http/client"

url = "{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/returnsAttributeMetadata/form/:formCode HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/returnsAttributeMetadata/form/:formCode',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/returnsAttributeMetadata/form/:formCode")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/returnsAttributeMetadata/form/:formCode') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode
http GET {{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/returnsAttributeMetadata/form/:formCode")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST reward-mine-use-reward
{{baseUrl}}/V1/reward/mine/use-reward
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/reward/mine/use-reward");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/reward/mine/use-reward")
require "http/client"

url = "{{baseUrl}}/V1/reward/mine/use-reward"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/reward/mine/use-reward"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/reward/mine/use-reward");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/reward/mine/use-reward"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/reward/mine/use-reward HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/reward/mine/use-reward")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/reward/mine/use-reward"))
    .method("POST", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/reward/mine/use-reward")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/reward/mine/use-reward")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/reward/mine/use-reward');

xhr.send(data);
import axios from 'axios';

const options = {method: 'POST', url: '{{baseUrl}}/V1/reward/mine/use-reward'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/reward/mine/use-reward';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/reward/mine/use-reward',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/reward/mine/use-reward")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/reward/mine/use-reward',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'POST', url: '{{baseUrl}}/V1/reward/mine/use-reward'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/reward/mine/use-reward');

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}}/V1/reward/mine/use-reward'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/reward/mine/use-reward';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/reward/mine/use-reward"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/reward/mine/use-reward" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/reward/mine/use-reward",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/reward/mine/use-reward');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/reward/mine/use-reward');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/reward/mine/use-reward');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/reward/mine/use-reward' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/reward/mine/use-reward' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/V1/reward/mine/use-reward")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/reward/mine/use-reward"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/reward/mine/use-reward"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/reward/mine/use-reward")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/V1/reward/mine/use-reward') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/reward/mine/use-reward";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/reward/mine/use-reward
http POST {{baseUrl}}/V1/reward/mine/use-reward
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/V1/reward/mine/use-reward
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/reward/mine/use-reward")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST salesRules
{{baseUrl}}/V1/salesRules
BODY json

{
  "rule": {
    "action_condition": {
      "aggregator_type": "",
      "attribute_name": "",
      "condition_type": "",
      "conditions": [],
      "extension_attributes": {},
      "operator": "",
      "value": ""
    },
    "apply_to_shipping": false,
    "condition": {},
    "coupon_type": "",
    "customer_group_ids": [],
    "description": "",
    "discount_amount": "",
    "discount_qty": "",
    "discount_step": 0,
    "extension_attributes": {
      "reward_points_delta": 0
    },
    "from_date": "",
    "is_active": false,
    "is_advanced": false,
    "is_rss": false,
    "name": "",
    "product_ids": [],
    "rule_id": 0,
    "simple_action": "",
    "simple_free_shipping": "",
    "sort_order": 0,
    "stop_rules_processing": false,
    "store_labels": [
      {
        "extension_attributes": {},
        "store_id": 0,
        "store_label": ""
      }
    ],
    "times_used": 0,
    "to_date": "",
    "use_auto_generation": false,
    "uses_per_coupon": 0,
    "uses_per_customer": 0,
    "website_ids": []
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/salesRules");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/salesRules" {:content-type :json
                                                          :form-params {:rule {:action_condition {:aggregator_type ""
                                                                                                  :attribute_name ""
                                                                                                  :condition_type ""
                                                                                                  :conditions []
                                                                                                  :extension_attributes {}
                                                                                                  :operator ""
                                                                                                  :value ""}
                                                                               :apply_to_shipping false
                                                                               :condition {}
                                                                               :coupon_type ""
                                                                               :customer_group_ids []
                                                                               :description ""
                                                                               :discount_amount ""
                                                                               :discount_qty ""
                                                                               :discount_step 0
                                                                               :extension_attributes {:reward_points_delta 0}
                                                                               :from_date ""
                                                                               :is_active false
                                                                               :is_advanced false
                                                                               :is_rss false
                                                                               :name ""
                                                                               :product_ids []
                                                                               :rule_id 0
                                                                               :simple_action ""
                                                                               :simple_free_shipping ""
                                                                               :sort_order 0
                                                                               :stop_rules_processing false
                                                                               :store_labels [{:extension_attributes {}
                                                                                               :store_id 0
                                                                                               :store_label ""}]
                                                                               :times_used 0
                                                                               :to_date ""
                                                                               :use_auto_generation false
                                                                               :uses_per_coupon 0
                                                                               :uses_per_customer 0
                                                                               :website_ids []}}})
require "http/client"

url = "{{baseUrl}}/V1/salesRules"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\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}}/V1/salesRules"),
    Content = new StringContent("{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\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}}/V1/salesRules");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/salesRules"

	payload := strings.NewReader("{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/salesRules HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1050

{
  "rule": {
    "action_condition": {
      "aggregator_type": "",
      "attribute_name": "",
      "condition_type": "",
      "conditions": [],
      "extension_attributes": {},
      "operator": "",
      "value": ""
    },
    "apply_to_shipping": false,
    "condition": {},
    "coupon_type": "",
    "customer_group_ids": [],
    "description": "",
    "discount_amount": "",
    "discount_qty": "",
    "discount_step": 0,
    "extension_attributes": {
      "reward_points_delta": 0
    },
    "from_date": "",
    "is_active": false,
    "is_advanced": false,
    "is_rss": false,
    "name": "",
    "product_ids": [],
    "rule_id": 0,
    "simple_action": "",
    "simple_free_shipping": "",
    "sort_order": 0,
    "stop_rules_processing": false,
    "store_labels": [
      {
        "extension_attributes": {},
        "store_id": 0,
        "store_label": ""
      }
    ],
    "times_used": 0,
    "to_date": "",
    "use_auto_generation": false,
    "uses_per_coupon": 0,
    "uses_per_customer": 0,
    "website_ids": []
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/salesRules")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/salesRules"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\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  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/salesRules")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/salesRules")
  .header("content-type", "application/json")
  .body("{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}")
  .asString();
const data = JSON.stringify({
  rule: {
    action_condition: {
      aggregator_type: '',
      attribute_name: '',
      condition_type: '',
      conditions: [],
      extension_attributes: {},
      operator: '',
      value: ''
    },
    apply_to_shipping: false,
    condition: {},
    coupon_type: '',
    customer_group_ids: [],
    description: '',
    discount_amount: '',
    discount_qty: '',
    discount_step: 0,
    extension_attributes: {
      reward_points_delta: 0
    },
    from_date: '',
    is_active: false,
    is_advanced: false,
    is_rss: false,
    name: '',
    product_ids: [],
    rule_id: 0,
    simple_action: '',
    simple_free_shipping: '',
    sort_order: 0,
    stop_rules_processing: false,
    store_labels: [
      {
        extension_attributes: {},
        store_id: 0,
        store_label: ''
      }
    ],
    times_used: 0,
    to_date: '',
    use_auto_generation: false,
    uses_per_coupon: 0,
    uses_per_customer: 0,
    website_ids: []
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/salesRules');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/salesRules',
  headers: {'content-type': 'application/json'},
  data: {
    rule: {
      action_condition: {
        aggregator_type: '',
        attribute_name: '',
        condition_type: '',
        conditions: [],
        extension_attributes: {},
        operator: '',
        value: ''
      },
      apply_to_shipping: false,
      condition: {},
      coupon_type: '',
      customer_group_ids: [],
      description: '',
      discount_amount: '',
      discount_qty: '',
      discount_step: 0,
      extension_attributes: {reward_points_delta: 0},
      from_date: '',
      is_active: false,
      is_advanced: false,
      is_rss: false,
      name: '',
      product_ids: [],
      rule_id: 0,
      simple_action: '',
      simple_free_shipping: '',
      sort_order: 0,
      stop_rules_processing: false,
      store_labels: [{extension_attributes: {}, store_id: 0, store_label: ''}],
      times_used: 0,
      to_date: '',
      use_auto_generation: false,
      uses_per_coupon: 0,
      uses_per_customer: 0,
      website_ids: []
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/salesRules';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"rule":{"action_condition":{"aggregator_type":"","attribute_name":"","condition_type":"","conditions":[],"extension_attributes":{},"operator":"","value":""},"apply_to_shipping":false,"condition":{},"coupon_type":"","customer_group_ids":[],"description":"","discount_amount":"","discount_qty":"","discount_step":0,"extension_attributes":{"reward_points_delta":0},"from_date":"","is_active":false,"is_advanced":false,"is_rss":false,"name":"","product_ids":[],"rule_id":0,"simple_action":"","simple_free_shipping":"","sort_order":0,"stop_rules_processing":false,"store_labels":[{"extension_attributes":{},"store_id":0,"store_label":""}],"times_used":0,"to_date":"","use_auto_generation":false,"uses_per_coupon":0,"uses_per_customer":0,"website_ids":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/salesRules',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "rule": {\n    "action_condition": {\n      "aggregator_type": "",\n      "attribute_name": "",\n      "condition_type": "",\n      "conditions": [],\n      "extension_attributes": {},\n      "operator": "",\n      "value": ""\n    },\n    "apply_to_shipping": false,\n    "condition": {},\n    "coupon_type": "",\n    "customer_group_ids": [],\n    "description": "",\n    "discount_amount": "",\n    "discount_qty": "",\n    "discount_step": 0,\n    "extension_attributes": {\n      "reward_points_delta": 0\n    },\n    "from_date": "",\n    "is_active": false,\n    "is_advanced": false,\n    "is_rss": false,\n    "name": "",\n    "product_ids": [],\n    "rule_id": 0,\n    "simple_action": "",\n    "simple_free_shipping": "",\n    "sort_order": 0,\n    "stop_rules_processing": false,\n    "store_labels": [\n      {\n        "extension_attributes": {},\n        "store_id": 0,\n        "store_label": ""\n      }\n    ],\n    "times_used": 0,\n    "to_date": "",\n    "use_auto_generation": false,\n    "uses_per_coupon": 0,\n    "uses_per_customer": 0,\n    "website_ids": []\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  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/salesRules")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/salesRules',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  rule: {
    action_condition: {
      aggregator_type: '',
      attribute_name: '',
      condition_type: '',
      conditions: [],
      extension_attributes: {},
      operator: '',
      value: ''
    },
    apply_to_shipping: false,
    condition: {},
    coupon_type: '',
    customer_group_ids: [],
    description: '',
    discount_amount: '',
    discount_qty: '',
    discount_step: 0,
    extension_attributes: {reward_points_delta: 0},
    from_date: '',
    is_active: false,
    is_advanced: false,
    is_rss: false,
    name: '',
    product_ids: [],
    rule_id: 0,
    simple_action: '',
    simple_free_shipping: '',
    sort_order: 0,
    stop_rules_processing: false,
    store_labels: [{extension_attributes: {}, store_id: 0, store_label: ''}],
    times_used: 0,
    to_date: '',
    use_auto_generation: false,
    uses_per_coupon: 0,
    uses_per_customer: 0,
    website_ids: []
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/salesRules',
  headers: {'content-type': 'application/json'},
  body: {
    rule: {
      action_condition: {
        aggregator_type: '',
        attribute_name: '',
        condition_type: '',
        conditions: [],
        extension_attributes: {},
        operator: '',
        value: ''
      },
      apply_to_shipping: false,
      condition: {},
      coupon_type: '',
      customer_group_ids: [],
      description: '',
      discount_amount: '',
      discount_qty: '',
      discount_step: 0,
      extension_attributes: {reward_points_delta: 0},
      from_date: '',
      is_active: false,
      is_advanced: false,
      is_rss: false,
      name: '',
      product_ids: [],
      rule_id: 0,
      simple_action: '',
      simple_free_shipping: '',
      sort_order: 0,
      stop_rules_processing: false,
      store_labels: [{extension_attributes: {}, store_id: 0, store_label: ''}],
      times_used: 0,
      to_date: '',
      use_auto_generation: false,
      uses_per_coupon: 0,
      uses_per_customer: 0,
      website_ids: []
    }
  },
  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}}/V1/salesRules');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  rule: {
    action_condition: {
      aggregator_type: '',
      attribute_name: '',
      condition_type: '',
      conditions: [],
      extension_attributes: {},
      operator: '',
      value: ''
    },
    apply_to_shipping: false,
    condition: {},
    coupon_type: '',
    customer_group_ids: [],
    description: '',
    discount_amount: '',
    discount_qty: '',
    discount_step: 0,
    extension_attributes: {
      reward_points_delta: 0
    },
    from_date: '',
    is_active: false,
    is_advanced: false,
    is_rss: false,
    name: '',
    product_ids: [],
    rule_id: 0,
    simple_action: '',
    simple_free_shipping: '',
    sort_order: 0,
    stop_rules_processing: false,
    store_labels: [
      {
        extension_attributes: {},
        store_id: 0,
        store_label: ''
      }
    ],
    times_used: 0,
    to_date: '',
    use_auto_generation: false,
    uses_per_coupon: 0,
    uses_per_customer: 0,
    website_ids: []
  }
});

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}}/V1/salesRules',
  headers: {'content-type': 'application/json'},
  data: {
    rule: {
      action_condition: {
        aggregator_type: '',
        attribute_name: '',
        condition_type: '',
        conditions: [],
        extension_attributes: {},
        operator: '',
        value: ''
      },
      apply_to_shipping: false,
      condition: {},
      coupon_type: '',
      customer_group_ids: [],
      description: '',
      discount_amount: '',
      discount_qty: '',
      discount_step: 0,
      extension_attributes: {reward_points_delta: 0},
      from_date: '',
      is_active: false,
      is_advanced: false,
      is_rss: false,
      name: '',
      product_ids: [],
      rule_id: 0,
      simple_action: '',
      simple_free_shipping: '',
      sort_order: 0,
      stop_rules_processing: false,
      store_labels: [{extension_attributes: {}, store_id: 0, store_label: ''}],
      times_used: 0,
      to_date: '',
      use_auto_generation: false,
      uses_per_coupon: 0,
      uses_per_customer: 0,
      website_ids: []
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/salesRules';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"rule":{"action_condition":{"aggregator_type":"","attribute_name":"","condition_type":"","conditions":[],"extension_attributes":{},"operator":"","value":""},"apply_to_shipping":false,"condition":{},"coupon_type":"","customer_group_ids":[],"description":"","discount_amount":"","discount_qty":"","discount_step":0,"extension_attributes":{"reward_points_delta":0},"from_date":"","is_active":false,"is_advanced":false,"is_rss":false,"name":"","product_ids":[],"rule_id":0,"simple_action":"","simple_free_shipping":"","sort_order":0,"stop_rules_processing":false,"store_labels":[{"extension_attributes":{},"store_id":0,"store_label":""}],"times_used":0,"to_date":"","use_auto_generation":false,"uses_per_coupon":0,"uses_per_customer":0,"website_ids":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"rule": @{ @"action_condition": @{ @"aggregator_type": @"", @"attribute_name": @"", @"condition_type": @"", @"conditions": @[  ], @"extension_attributes": @{  }, @"operator": @"", @"value": @"" }, @"apply_to_shipping": @NO, @"condition": @{  }, @"coupon_type": @"", @"customer_group_ids": @[  ], @"description": @"", @"discount_amount": @"", @"discount_qty": @"", @"discount_step": @0, @"extension_attributes": @{ @"reward_points_delta": @0 }, @"from_date": @"", @"is_active": @NO, @"is_advanced": @NO, @"is_rss": @NO, @"name": @"", @"product_ids": @[  ], @"rule_id": @0, @"simple_action": @"", @"simple_free_shipping": @"", @"sort_order": @0, @"stop_rules_processing": @NO, @"store_labels": @[ @{ @"extension_attributes": @{  }, @"store_id": @0, @"store_label": @"" } ], @"times_used": @0, @"to_date": @"", @"use_auto_generation": @NO, @"uses_per_coupon": @0, @"uses_per_customer": @0, @"website_ids": @[  ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/salesRules"]
                                                       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}}/V1/salesRules" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/salesRules",
  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([
    'rule' => [
        'action_condition' => [
                'aggregator_type' => '',
                'attribute_name' => '',
                'condition_type' => '',
                'conditions' => [
                                
                ],
                'extension_attributes' => [
                                
                ],
                'operator' => '',
                'value' => ''
        ],
        'apply_to_shipping' => null,
        'condition' => [
                
        ],
        'coupon_type' => '',
        'customer_group_ids' => [
                
        ],
        'description' => '',
        'discount_amount' => '',
        'discount_qty' => '',
        'discount_step' => 0,
        'extension_attributes' => [
                'reward_points_delta' => 0
        ],
        'from_date' => '',
        'is_active' => null,
        'is_advanced' => null,
        'is_rss' => null,
        'name' => '',
        'product_ids' => [
                
        ],
        'rule_id' => 0,
        'simple_action' => '',
        'simple_free_shipping' => '',
        'sort_order' => 0,
        'stop_rules_processing' => null,
        'store_labels' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'store_id' => 0,
                                'store_label' => ''
                ]
        ],
        'times_used' => 0,
        'to_date' => '',
        'use_auto_generation' => null,
        'uses_per_coupon' => 0,
        'uses_per_customer' => 0,
        'website_ids' => [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/salesRules', [
  'body' => '{
  "rule": {
    "action_condition": {
      "aggregator_type": "",
      "attribute_name": "",
      "condition_type": "",
      "conditions": [],
      "extension_attributes": {},
      "operator": "",
      "value": ""
    },
    "apply_to_shipping": false,
    "condition": {},
    "coupon_type": "",
    "customer_group_ids": [],
    "description": "",
    "discount_amount": "",
    "discount_qty": "",
    "discount_step": 0,
    "extension_attributes": {
      "reward_points_delta": 0
    },
    "from_date": "",
    "is_active": false,
    "is_advanced": false,
    "is_rss": false,
    "name": "",
    "product_ids": [],
    "rule_id": 0,
    "simple_action": "",
    "simple_free_shipping": "",
    "sort_order": 0,
    "stop_rules_processing": false,
    "store_labels": [
      {
        "extension_attributes": {},
        "store_id": 0,
        "store_label": ""
      }
    ],
    "times_used": 0,
    "to_date": "",
    "use_auto_generation": false,
    "uses_per_coupon": 0,
    "uses_per_customer": 0,
    "website_ids": []
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/salesRules');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'rule' => [
    'action_condition' => [
        'aggregator_type' => '',
        'attribute_name' => '',
        'condition_type' => '',
        'conditions' => [
                
        ],
        'extension_attributes' => [
                
        ],
        'operator' => '',
        'value' => ''
    ],
    'apply_to_shipping' => null,
    'condition' => [
        
    ],
    'coupon_type' => '',
    'customer_group_ids' => [
        
    ],
    'description' => '',
    'discount_amount' => '',
    'discount_qty' => '',
    'discount_step' => 0,
    'extension_attributes' => [
        'reward_points_delta' => 0
    ],
    'from_date' => '',
    'is_active' => null,
    'is_advanced' => null,
    'is_rss' => null,
    'name' => '',
    'product_ids' => [
        
    ],
    'rule_id' => 0,
    'simple_action' => '',
    'simple_free_shipping' => '',
    'sort_order' => 0,
    'stop_rules_processing' => null,
    'store_labels' => [
        [
                'extension_attributes' => [
                                
                ],
                'store_id' => 0,
                'store_label' => ''
        ]
    ],
    'times_used' => 0,
    'to_date' => '',
    'use_auto_generation' => null,
    'uses_per_coupon' => 0,
    'uses_per_customer' => 0,
    'website_ids' => [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'rule' => [
    'action_condition' => [
        'aggregator_type' => '',
        'attribute_name' => '',
        'condition_type' => '',
        'conditions' => [
                
        ],
        'extension_attributes' => [
                
        ],
        'operator' => '',
        'value' => ''
    ],
    'apply_to_shipping' => null,
    'condition' => [
        
    ],
    'coupon_type' => '',
    'customer_group_ids' => [
        
    ],
    'description' => '',
    'discount_amount' => '',
    'discount_qty' => '',
    'discount_step' => 0,
    'extension_attributes' => [
        'reward_points_delta' => 0
    ],
    'from_date' => '',
    'is_active' => null,
    'is_advanced' => null,
    'is_rss' => null,
    'name' => '',
    'product_ids' => [
        
    ],
    'rule_id' => 0,
    'simple_action' => '',
    'simple_free_shipping' => '',
    'sort_order' => 0,
    'stop_rules_processing' => null,
    'store_labels' => [
        [
                'extension_attributes' => [
                                
                ],
                'store_id' => 0,
                'store_label' => ''
        ]
    ],
    'times_used' => 0,
    'to_date' => '',
    'use_auto_generation' => null,
    'uses_per_coupon' => 0,
    'uses_per_customer' => 0,
    'website_ids' => [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/salesRules');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/salesRules' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "rule": {
    "action_condition": {
      "aggregator_type": "",
      "attribute_name": "",
      "condition_type": "",
      "conditions": [],
      "extension_attributes": {},
      "operator": "",
      "value": ""
    },
    "apply_to_shipping": false,
    "condition": {},
    "coupon_type": "",
    "customer_group_ids": [],
    "description": "",
    "discount_amount": "",
    "discount_qty": "",
    "discount_step": 0,
    "extension_attributes": {
      "reward_points_delta": 0
    },
    "from_date": "",
    "is_active": false,
    "is_advanced": false,
    "is_rss": false,
    "name": "",
    "product_ids": [],
    "rule_id": 0,
    "simple_action": "",
    "simple_free_shipping": "",
    "sort_order": 0,
    "stop_rules_processing": false,
    "store_labels": [
      {
        "extension_attributes": {},
        "store_id": 0,
        "store_label": ""
      }
    ],
    "times_used": 0,
    "to_date": "",
    "use_auto_generation": false,
    "uses_per_coupon": 0,
    "uses_per_customer": 0,
    "website_ids": []
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/salesRules' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "rule": {
    "action_condition": {
      "aggregator_type": "",
      "attribute_name": "",
      "condition_type": "",
      "conditions": [],
      "extension_attributes": {},
      "operator": "",
      "value": ""
    },
    "apply_to_shipping": false,
    "condition": {},
    "coupon_type": "",
    "customer_group_ids": [],
    "description": "",
    "discount_amount": "",
    "discount_qty": "",
    "discount_step": 0,
    "extension_attributes": {
      "reward_points_delta": 0
    },
    "from_date": "",
    "is_active": false,
    "is_advanced": false,
    "is_rss": false,
    "name": "",
    "product_ids": [],
    "rule_id": 0,
    "simple_action": "",
    "simple_free_shipping": "",
    "sort_order": 0,
    "stop_rules_processing": false,
    "store_labels": [
      {
        "extension_attributes": {},
        "store_id": 0,
        "store_label": ""
      }
    ],
    "times_used": 0,
    "to_date": "",
    "use_auto_generation": false,
    "uses_per_coupon": 0,
    "uses_per_customer": 0,
    "website_ids": []
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/salesRules", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/salesRules"

payload = { "rule": {
        "action_condition": {
            "aggregator_type": "",
            "attribute_name": "",
            "condition_type": "",
            "conditions": [],
            "extension_attributes": {},
            "operator": "",
            "value": ""
        },
        "apply_to_shipping": False,
        "condition": {},
        "coupon_type": "",
        "customer_group_ids": [],
        "description": "",
        "discount_amount": "",
        "discount_qty": "",
        "discount_step": 0,
        "extension_attributes": { "reward_points_delta": 0 },
        "from_date": "",
        "is_active": False,
        "is_advanced": False,
        "is_rss": False,
        "name": "",
        "product_ids": [],
        "rule_id": 0,
        "simple_action": "",
        "simple_free_shipping": "",
        "sort_order": 0,
        "stop_rules_processing": False,
        "store_labels": [
            {
                "extension_attributes": {},
                "store_id": 0,
                "store_label": ""
            }
        ],
        "times_used": 0,
        "to_date": "",
        "use_auto_generation": False,
        "uses_per_coupon": 0,
        "uses_per_customer": 0,
        "website_ids": []
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/salesRules"

payload <- "{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/salesRules")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\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/V1/salesRules') do |req|
  req.body = "{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/salesRules";

    let payload = json!({"rule": json!({
            "action_condition": json!({
                "aggregator_type": "",
                "attribute_name": "",
                "condition_type": "",
                "conditions": (),
                "extension_attributes": json!({}),
                "operator": "",
                "value": ""
            }),
            "apply_to_shipping": false,
            "condition": json!({}),
            "coupon_type": "",
            "customer_group_ids": (),
            "description": "",
            "discount_amount": "",
            "discount_qty": "",
            "discount_step": 0,
            "extension_attributes": json!({"reward_points_delta": 0}),
            "from_date": "",
            "is_active": false,
            "is_advanced": false,
            "is_rss": false,
            "name": "",
            "product_ids": (),
            "rule_id": 0,
            "simple_action": "",
            "simple_free_shipping": "",
            "sort_order": 0,
            "stop_rules_processing": false,
            "store_labels": (
                json!({
                    "extension_attributes": json!({}),
                    "store_id": 0,
                    "store_label": ""
                })
            ),
            "times_used": 0,
            "to_date": "",
            "use_auto_generation": false,
            "uses_per_coupon": 0,
            "uses_per_customer": 0,
            "website_ids": ()
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/salesRules \
  --header 'content-type: application/json' \
  --data '{
  "rule": {
    "action_condition": {
      "aggregator_type": "",
      "attribute_name": "",
      "condition_type": "",
      "conditions": [],
      "extension_attributes": {},
      "operator": "",
      "value": ""
    },
    "apply_to_shipping": false,
    "condition": {},
    "coupon_type": "",
    "customer_group_ids": [],
    "description": "",
    "discount_amount": "",
    "discount_qty": "",
    "discount_step": 0,
    "extension_attributes": {
      "reward_points_delta": 0
    },
    "from_date": "",
    "is_active": false,
    "is_advanced": false,
    "is_rss": false,
    "name": "",
    "product_ids": [],
    "rule_id": 0,
    "simple_action": "",
    "simple_free_shipping": "",
    "sort_order": 0,
    "stop_rules_processing": false,
    "store_labels": [
      {
        "extension_attributes": {},
        "store_id": 0,
        "store_label": ""
      }
    ],
    "times_used": 0,
    "to_date": "",
    "use_auto_generation": false,
    "uses_per_coupon": 0,
    "uses_per_customer": 0,
    "website_ids": []
  }
}'
echo '{
  "rule": {
    "action_condition": {
      "aggregator_type": "",
      "attribute_name": "",
      "condition_type": "",
      "conditions": [],
      "extension_attributes": {},
      "operator": "",
      "value": ""
    },
    "apply_to_shipping": false,
    "condition": {},
    "coupon_type": "",
    "customer_group_ids": [],
    "description": "",
    "discount_amount": "",
    "discount_qty": "",
    "discount_step": 0,
    "extension_attributes": {
      "reward_points_delta": 0
    },
    "from_date": "",
    "is_active": false,
    "is_advanced": false,
    "is_rss": false,
    "name": "",
    "product_ids": [],
    "rule_id": 0,
    "simple_action": "",
    "simple_free_shipping": "",
    "sort_order": 0,
    "stop_rules_processing": false,
    "store_labels": [
      {
        "extension_attributes": {},
        "store_id": 0,
        "store_label": ""
      }
    ],
    "times_used": 0,
    "to_date": "",
    "use_auto_generation": false,
    "uses_per_coupon": 0,
    "uses_per_customer": 0,
    "website_ids": []
  }
}' |  \
  http POST {{baseUrl}}/V1/salesRules \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "rule": {\n    "action_condition": {\n      "aggregator_type": "",\n      "attribute_name": "",\n      "condition_type": "",\n      "conditions": [],\n      "extension_attributes": {},\n      "operator": "",\n      "value": ""\n    },\n    "apply_to_shipping": false,\n    "condition": {},\n    "coupon_type": "",\n    "customer_group_ids": [],\n    "description": "",\n    "discount_amount": "",\n    "discount_qty": "",\n    "discount_step": 0,\n    "extension_attributes": {\n      "reward_points_delta": 0\n    },\n    "from_date": "",\n    "is_active": false,\n    "is_advanced": false,\n    "is_rss": false,\n    "name": "",\n    "product_ids": [],\n    "rule_id": 0,\n    "simple_action": "",\n    "simple_free_shipping": "",\n    "sort_order": 0,\n    "stop_rules_processing": false,\n    "store_labels": [\n      {\n        "extension_attributes": {},\n        "store_id": 0,\n        "store_label": ""\n      }\n    ],\n    "times_used": 0,\n    "to_date": "",\n    "use_auto_generation": false,\n    "uses_per_coupon": 0,\n    "uses_per_customer": 0,\n    "website_ids": []\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/salesRules
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["rule": [
    "action_condition": [
      "aggregator_type": "",
      "attribute_name": "",
      "condition_type": "",
      "conditions": [],
      "extension_attributes": [],
      "operator": "",
      "value": ""
    ],
    "apply_to_shipping": false,
    "condition": [],
    "coupon_type": "",
    "customer_group_ids": [],
    "description": "",
    "discount_amount": "",
    "discount_qty": "",
    "discount_step": 0,
    "extension_attributes": ["reward_points_delta": 0],
    "from_date": "",
    "is_active": false,
    "is_advanced": false,
    "is_rss": false,
    "name": "",
    "product_ids": [],
    "rule_id": 0,
    "simple_action": "",
    "simple_free_shipping": "",
    "sort_order": 0,
    "stop_rules_processing": false,
    "store_labels": [
      [
        "extension_attributes": [],
        "store_id": 0,
        "store_label": ""
      ]
    ],
    "times_used": 0,
    "to_date": "",
    "use_auto_generation": false,
    "uses_per_coupon": 0,
    "uses_per_customer": 0,
    "website_ids": []
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/salesRules")! 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 salesRules-{ruleId} (GET)
{{baseUrl}}/V1/salesRules/:ruleId
QUERY PARAMS

ruleId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/salesRules/:ruleId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/salesRules/:ruleId")
require "http/client"

url = "{{baseUrl}}/V1/salesRules/:ruleId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/salesRules/:ruleId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/salesRules/:ruleId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/salesRules/:ruleId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/salesRules/:ruleId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/salesRules/:ruleId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/salesRules/:ruleId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/salesRules/:ruleId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/salesRules/:ruleId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/salesRules/:ruleId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/salesRules/:ruleId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/salesRules/:ruleId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/salesRules/:ruleId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/salesRules/:ruleId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/salesRules/:ruleId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/salesRules/:ruleId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/salesRules/:ruleId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/salesRules/:ruleId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/salesRules/:ruleId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/salesRules/:ruleId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/salesRules/:ruleId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/salesRules/:ruleId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/salesRules/:ruleId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/salesRules/:ruleId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/salesRules/:ruleId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/salesRules/:ruleId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/salesRules/:ruleId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/salesRules/:ruleId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/salesRules/:ruleId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/salesRules/:ruleId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/salesRules/:ruleId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/salesRules/:ruleId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/salesRules/:ruleId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/salesRules/:ruleId
http GET {{baseUrl}}/V1/salesRules/:ruleId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/salesRules/:ruleId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/salesRules/:ruleId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT salesRules-{ruleId} (PUT)
{{baseUrl}}/V1/salesRules/:ruleId
QUERY PARAMS

ruleId
BODY json

{
  "rule": {
    "action_condition": {
      "aggregator_type": "",
      "attribute_name": "",
      "condition_type": "",
      "conditions": [],
      "extension_attributes": {},
      "operator": "",
      "value": ""
    },
    "apply_to_shipping": false,
    "condition": {},
    "coupon_type": "",
    "customer_group_ids": [],
    "description": "",
    "discount_amount": "",
    "discount_qty": "",
    "discount_step": 0,
    "extension_attributes": {
      "reward_points_delta": 0
    },
    "from_date": "",
    "is_active": false,
    "is_advanced": false,
    "is_rss": false,
    "name": "",
    "product_ids": [],
    "rule_id": 0,
    "simple_action": "",
    "simple_free_shipping": "",
    "sort_order": 0,
    "stop_rules_processing": false,
    "store_labels": [
      {
        "extension_attributes": {},
        "store_id": 0,
        "store_label": ""
      }
    ],
    "times_used": 0,
    "to_date": "",
    "use_auto_generation": false,
    "uses_per_coupon": 0,
    "uses_per_customer": 0,
    "website_ids": []
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/salesRules/:ruleId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/salesRules/:ruleId" {:content-type :json
                                                                 :form-params {:rule {:action_condition {:aggregator_type ""
                                                                                                         :attribute_name ""
                                                                                                         :condition_type ""
                                                                                                         :conditions []
                                                                                                         :extension_attributes {}
                                                                                                         :operator ""
                                                                                                         :value ""}
                                                                                      :apply_to_shipping false
                                                                                      :condition {}
                                                                                      :coupon_type ""
                                                                                      :customer_group_ids []
                                                                                      :description ""
                                                                                      :discount_amount ""
                                                                                      :discount_qty ""
                                                                                      :discount_step 0
                                                                                      :extension_attributes {:reward_points_delta 0}
                                                                                      :from_date ""
                                                                                      :is_active false
                                                                                      :is_advanced false
                                                                                      :is_rss false
                                                                                      :name ""
                                                                                      :product_ids []
                                                                                      :rule_id 0
                                                                                      :simple_action ""
                                                                                      :simple_free_shipping ""
                                                                                      :sort_order 0
                                                                                      :stop_rules_processing false
                                                                                      :store_labels [{:extension_attributes {}
                                                                                                      :store_id 0
                                                                                                      :store_label ""}]
                                                                                      :times_used 0
                                                                                      :to_date ""
                                                                                      :use_auto_generation false
                                                                                      :uses_per_coupon 0
                                                                                      :uses_per_customer 0
                                                                                      :website_ids []}}})
require "http/client"

url = "{{baseUrl}}/V1/salesRules/:ruleId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\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}}/V1/salesRules/:ruleId"),
    Content = new StringContent("{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\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}}/V1/salesRules/:ruleId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/salesRules/:ruleId"

	payload := strings.NewReader("{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/salesRules/:ruleId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1050

{
  "rule": {
    "action_condition": {
      "aggregator_type": "",
      "attribute_name": "",
      "condition_type": "",
      "conditions": [],
      "extension_attributes": {},
      "operator": "",
      "value": ""
    },
    "apply_to_shipping": false,
    "condition": {},
    "coupon_type": "",
    "customer_group_ids": [],
    "description": "",
    "discount_amount": "",
    "discount_qty": "",
    "discount_step": 0,
    "extension_attributes": {
      "reward_points_delta": 0
    },
    "from_date": "",
    "is_active": false,
    "is_advanced": false,
    "is_rss": false,
    "name": "",
    "product_ids": [],
    "rule_id": 0,
    "simple_action": "",
    "simple_free_shipping": "",
    "sort_order": 0,
    "stop_rules_processing": false,
    "store_labels": [
      {
        "extension_attributes": {},
        "store_id": 0,
        "store_label": ""
      }
    ],
    "times_used": 0,
    "to_date": "",
    "use_auto_generation": false,
    "uses_per_coupon": 0,
    "uses_per_customer": 0,
    "website_ids": []
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/salesRules/:ruleId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/salesRules/:ruleId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\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  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/salesRules/:ruleId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/salesRules/:ruleId")
  .header("content-type", "application/json")
  .body("{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}")
  .asString();
const data = JSON.stringify({
  rule: {
    action_condition: {
      aggregator_type: '',
      attribute_name: '',
      condition_type: '',
      conditions: [],
      extension_attributes: {},
      operator: '',
      value: ''
    },
    apply_to_shipping: false,
    condition: {},
    coupon_type: '',
    customer_group_ids: [],
    description: '',
    discount_amount: '',
    discount_qty: '',
    discount_step: 0,
    extension_attributes: {
      reward_points_delta: 0
    },
    from_date: '',
    is_active: false,
    is_advanced: false,
    is_rss: false,
    name: '',
    product_ids: [],
    rule_id: 0,
    simple_action: '',
    simple_free_shipping: '',
    sort_order: 0,
    stop_rules_processing: false,
    store_labels: [
      {
        extension_attributes: {},
        store_id: 0,
        store_label: ''
      }
    ],
    times_used: 0,
    to_date: '',
    use_auto_generation: false,
    uses_per_coupon: 0,
    uses_per_customer: 0,
    website_ids: []
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/salesRules/:ruleId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/salesRules/:ruleId',
  headers: {'content-type': 'application/json'},
  data: {
    rule: {
      action_condition: {
        aggregator_type: '',
        attribute_name: '',
        condition_type: '',
        conditions: [],
        extension_attributes: {},
        operator: '',
        value: ''
      },
      apply_to_shipping: false,
      condition: {},
      coupon_type: '',
      customer_group_ids: [],
      description: '',
      discount_amount: '',
      discount_qty: '',
      discount_step: 0,
      extension_attributes: {reward_points_delta: 0},
      from_date: '',
      is_active: false,
      is_advanced: false,
      is_rss: false,
      name: '',
      product_ids: [],
      rule_id: 0,
      simple_action: '',
      simple_free_shipping: '',
      sort_order: 0,
      stop_rules_processing: false,
      store_labels: [{extension_attributes: {}, store_id: 0, store_label: ''}],
      times_used: 0,
      to_date: '',
      use_auto_generation: false,
      uses_per_coupon: 0,
      uses_per_customer: 0,
      website_ids: []
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/salesRules/:ruleId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"rule":{"action_condition":{"aggregator_type":"","attribute_name":"","condition_type":"","conditions":[],"extension_attributes":{},"operator":"","value":""},"apply_to_shipping":false,"condition":{},"coupon_type":"","customer_group_ids":[],"description":"","discount_amount":"","discount_qty":"","discount_step":0,"extension_attributes":{"reward_points_delta":0},"from_date":"","is_active":false,"is_advanced":false,"is_rss":false,"name":"","product_ids":[],"rule_id":0,"simple_action":"","simple_free_shipping":"","sort_order":0,"stop_rules_processing":false,"store_labels":[{"extension_attributes":{},"store_id":0,"store_label":""}],"times_used":0,"to_date":"","use_auto_generation":false,"uses_per_coupon":0,"uses_per_customer":0,"website_ids":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/salesRules/:ruleId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "rule": {\n    "action_condition": {\n      "aggregator_type": "",\n      "attribute_name": "",\n      "condition_type": "",\n      "conditions": [],\n      "extension_attributes": {},\n      "operator": "",\n      "value": ""\n    },\n    "apply_to_shipping": false,\n    "condition": {},\n    "coupon_type": "",\n    "customer_group_ids": [],\n    "description": "",\n    "discount_amount": "",\n    "discount_qty": "",\n    "discount_step": 0,\n    "extension_attributes": {\n      "reward_points_delta": 0\n    },\n    "from_date": "",\n    "is_active": false,\n    "is_advanced": false,\n    "is_rss": false,\n    "name": "",\n    "product_ids": [],\n    "rule_id": 0,\n    "simple_action": "",\n    "simple_free_shipping": "",\n    "sort_order": 0,\n    "stop_rules_processing": false,\n    "store_labels": [\n      {\n        "extension_attributes": {},\n        "store_id": 0,\n        "store_label": ""\n      }\n    ],\n    "times_used": 0,\n    "to_date": "",\n    "use_auto_generation": false,\n    "uses_per_coupon": 0,\n    "uses_per_customer": 0,\n    "website_ids": []\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  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/salesRules/:ruleId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/salesRules/:ruleId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  rule: {
    action_condition: {
      aggregator_type: '',
      attribute_name: '',
      condition_type: '',
      conditions: [],
      extension_attributes: {},
      operator: '',
      value: ''
    },
    apply_to_shipping: false,
    condition: {},
    coupon_type: '',
    customer_group_ids: [],
    description: '',
    discount_amount: '',
    discount_qty: '',
    discount_step: 0,
    extension_attributes: {reward_points_delta: 0},
    from_date: '',
    is_active: false,
    is_advanced: false,
    is_rss: false,
    name: '',
    product_ids: [],
    rule_id: 0,
    simple_action: '',
    simple_free_shipping: '',
    sort_order: 0,
    stop_rules_processing: false,
    store_labels: [{extension_attributes: {}, store_id: 0, store_label: ''}],
    times_used: 0,
    to_date: '',
    use_auto_generation: false,
    uses_per_coupon: 0,
    uses_per_customer: 0,
    website_ids: []
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/salesRules/:ruleId',
  headers: {'content-type': 'application/json'},
  body: {
    rule: {
      action_condition: {
        aggregator_type: '',
        attribute_name: '',
        condition_type: '',
        conditions: [],
        extension_attributes: {},
        operator: '',
        value: ''
      },
      apply_to_shipping: false,
      condition: {},
      coupon_type: '',
      customer_group_ids: [],
      description: '',
      discount_amount: '',
      discount_qty: '',
      discount_step: 0,
      extension_attributes: {reward_points_delta: 0},
      from_date: '',
      is_active: false,
      is_advanced: false,
      is_rss: false,
      name: '',
      product_ids: [],
      rule_id: 0,
      simple_action: '',
      simple_free_shipping: '',
      sort_order: 0,
      stop_rules_processing: false,
      store_labels: [{extension_attributes: {}, store_id: 0, store_label: ''}],
      times_used: 0,
      to_date: '',
      use_auto_generation: false,
      uses_per_coupon: 0,
      uses_per_customer: 0,
      website_ids: []
    }
  },
  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}}/V1/salesRules/:ruleId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  rule: {
    action_condition: {
      aggregator_type: '',
      attribute_name: '',
      condition_type: '',
      conditions: [],
      extension_attributes: {},
      operator: '',
      value: ''
    },
    apply_to_shipping: false,
    condition: {},
    coupon_type: '',
    customer_group_ids: [],
    description: '',
    discount_amount: '',
    discount_qty: '',
    discount_step: 0,
    extension_attributes: {
      reward_points_delta: 0
    },
    from_date: '',
    is_active: false,
    is_advanced: false,
    is_rss: false,
    name: '',
    product_ids: [],
    rule_id: 0,
    simple_action: '',
    simple_free_shipping: '',
    sort_order: 0,
    stop_rules_processing: false,
    store_labels: [
      {
        extension_attributes: {},
        store_id: 0,
        store_label: ''
      }
    ],
    times_used: 0,
    to_date: '',
    use_auto_generation: false,
    uses_per_coupon: 0,
    uses_per_customer: 0,
    website_ids: []
  }
});

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}}/V1/salesRules/:ruleId',
  headers: {'content-type': 'application/json'},
  data: {
    rule: {
      action_condition: {
        aggregator_type: '',
        attribute_name: '',
        condition_type: '',
        conditions: [],
        extension_attributes: {},
        operator: '',
        value: ''
      },
      apply_to_shipping: false,
      condition: {},
      coupon_type: '',
      customer_group_ids: [],
      description: '',
      discount_amount: '',
      discount_qty: '',
      discount_step: 0,
      extension_attributes: {reward_points_delta: 0},
      from_date: '',
      is_active: false,
      is_advanced: false,
      is_rss: false,
      name: '',
      product_ids: [],
      rule_id: 0,
      simple_action: '',
      simple_free_shipping: '',
      sort_order: 0,
      stop_rules_processing: false,
      store_labels: [{extension_attributes: {}, store_id: 0, store_label: ''}],
      times_used: 0,
      to_date: '',
      use_auto_generation: false,
      uses_per_coupon: 0,
      uses_per_customer: 0,
      website_ids: []
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/salesRules/:ruleId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"rule":{"action_condition":{"aggregator_type":"","attribute_name":"","condition_type":"","conditions":[],"extension_attributes":{},"operator":"","value":""},"apply_to_shipping":false,"condition":{},"coupon_type":"","customer_group_ids":[],"description":"","discount_amount":"","discount_qty":"","discount_step":0,"extension_attributes":{"reward_points_delta":0},"from_date":"","is_active":false,"is_advanced":false,"is_rss":false,"name":"","product_ids":[],"rule_id":0,"simple_action":"","simple_free_shipping":"","sort_order":0,"stop_rules_processing":false,"store_labels":[{"extension_attributes":{},"store_id":0,"store_label":""}],"times_used":0,"to_date":"","use_auto_generation":false,"uses_per_coupon":0,"uses_per_customer":0,"website_ids":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"rule": @{ @"action_condition": @{ @"aggregator_type": @"", @"attribute_name": @"", @"condition_type": @"", @"conditions": @[  ], @"extension_attributes": @{  }, @"operator": @"", @"value": @"" }, @"apply_to_shipping": @NO, @"condition": @{  }, @"coupon_type": @"", @"customer_group_ids": @[  ], @"description": @"", @"discount_amount": @"", @"discount_qty": @"", @"discount_step": @0, @"extension_attributes": @{ @"reward_points_delta": @0 }, @"from_date": @"", @"is_active": @NO, @"is_advanced": @NO, @"is_rss": @NO, @"name": @"", @"product_ids": @[  ], @"rule_id": @0, @"simple_action": @"", @"simple_free_shipping": @"", @"sort_order": @0, @"stop_rules_processing": @NO, @"store_labels": @[ @{ @"extension_attributes": @{  }, @"store_id": @0, @"store_label": @"" } ], @"times_used": @0, @"to_date": @"", @"use_auto_generation": @NO, @"uses_per_coupon": @0, @"uses_per_customer": @0, @"website_ids": @[  ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/salesRules/:ruleId"]
                                                       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}}/V1/salesRules/:ruleId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/salesRules/:ruleId",
  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([
    'rule' => [
        'action_condition' => [
                'aggregator_type' => '',
                'attribute_name' => '',
                'condition_type' => '',
                'conditions' => [
                                
                ],
                'extension_attributes' => [
                                
                ],
                'operator' => '',
                'value' => ''
        ],
        'apply_to_shipping' => null,
        'condition' => [
                
        ],
        'coupon_type' => '',
        'customer_group_ids' => [
                
        ],
        'description' => '',
        'discount_amount' => '',
        'discount_qty' => '',
        'discount_step' => 0,
        'extension_attributes' => [
                'reward_points_delta' => 0
        ],
        'from_date' => '',
        'is_active' => null,
        'is_advanced' => null,
        'is_rss' => null,
        'name' => '',
        'product_ids' => [
                
        ],
        'rule_id' => 0,
        'simple_action' => '',
        'simple_free_shipping' => '',
        'sort_order' => 0,
        'stop_rules_processing' => null,
        'store_labels' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'store_id' => 0,
                                'store_label' => ''
                ]
        ],
        'times_used' => 0,
        'to_date' => '',
        'use_auto_generation' => null,
        'uses_per_coupon' => 0,
        'uses_per_customer' => 0,
        'website_ids' => [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/salesRules/:ruleId', [
  'body' => '{
  "rule": {
    "action_condition": {
      "aggregator_type": "",
      "attribute_name": "",
      "condition_type": "",
      "conditions": [],
      "extension_attributes": {},
      "operator": "",
      "value": ""
    },
    "apply_to_shipping": false,
    "condition": {},
    "coupon_type": "",
    "customer_group_ids": [],
    "description": "",
    "discount_amount": "",
    "discount_qty": "",
    "discount_step": 0,
    "extension_attributes": {
      "reward_points_delta": 0
    },
    "from_date": "",
    "is_active": false,
    "is_advanced": false,
    "is_rss": false,
    "name": "",
    "product_ids": [],
    "rule_id": 0,
    "simple_action": "",
    "simple_free_shipping": "",
    "sort_order": 0,
    "stop_rules_processing": false,
    "store_labels": [
      {
        "extension_attributes": {},
        "store_id": 0,
        "store_label": ""
      }
    ],
    "times_used": 0,
    "to_date": "",
    "use_auto_generation": false,
    "uses_per_coupon": 0,
    "uses_per_customer": 0,
    "website_ids": []
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/salesRules/:ruleId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'rule' => [
    'action_condition' => [
        'aggregator_type' => '',
        'attribute_name' => '',
        'condition_type' => '',
        'conditions' => [
                
        ],
        'extension_attributes' => [
                
        ],
        'operator' => '',
        'value' => ''
    ],
    'apply_to_shipping' => null,
    'condition' => [
        
    ],
    'coupon_type' => '',
    'customer_group_ids' => [
        
    ],
    'description' => '',
    'discount_amount' => '',
    'discount_qty' => '',
    'discount_step' => 0,
    'extension_attributes' => [
        'reward_points_delta' => 0
    ],
    'from_date' => '',
    'is_active' => null,
    'is_advanced' => null,
    'is_rss' => null,
    'name' => '',
    'product_ids' => [
        
    ],
    'rule_id' => 0,
    'simple_action' => '',
    'simple_free_shipping' => '',
    'sort_order' => 0,
    'stop_rules_processing' => null,
    'store_labels' => [
        [
                'extension_attributes' => [
                                
                ],
                'store_id' => 0,
                'store_label' => ''
        ]
    ],
    'times_used' => 0,
    'to_date' => '',
    'use_auto_generation' => null,
    'uses_per_coupon' => 0,
    'uses_per_customer' => 0,
    'website_ids' => [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'rule' => [
    'action_condition' => [
        'aggregator_type' => '',
        'attribute_name' => '',
        'condition_type' => '',
        'conditions' => [
                
        ],
        'extension_attributes' => [
                
        ],
        'operator' => '',
        'value' => ''
    ],
    'apply_to_shipping' => null,
    'condition' => [
        
    ],
    'coupon_type' => '',
    'customer_group_ids' => [
        
    ],
    'description' => '',
    'discount_amount' => '',
    'discount_qty' => '',
    'discount_step' => 0,
    'extension_attributes' => [
        'reward_points_delta' => 0
    ],
    'from_date' => '',
    'is_active' => null,
    'is_advanced' => null,
    'is_rss' => null,
    'name' => '',
    'product_ids' => [
        
    ],
    'rule_id' => 0,
    'simple_action' => '',
    'simple_free_shipping' => '',
    'sort_order' => 0,
    'stop_rules_processing' => null,
    'store_labels' => [
        [
                'extension_attributes' => [
                                
                ],
                'store_id' => 0,
                'store_label' => ''
        ]
    ],
    'times_used' => 0,
    'to_date' => '',
    'use_auto_generation' => null,
    'uses_per_coupon' => 0,
    'uses_per_customer' => 0,
    'website_ids' => [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/salesRules/:ruleId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/salesRules/:ruleId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "rule": {
    "action_condition": {
      "aggregator_type": "",
      "attribute_name": "",
      "condition_type": "",
      "conditions": [],
      "extension_attributes": {},
      "operator": "",
      "value": ""
    },
    "apply_to_shipping": false,
    "condition": {},
    "coupon_type": "",
    "customer_group_ids": [],
    "description": "",
    "discount_amount": "",
    "discount_qty": "",
    "discount_step": 0,
    "extension_attributes": {
      "reward_points_delta": 0
    },
    "from_date": "",
    "is_active": false,
    "is_advanced": false,
    "is_rss": false,
    "name": "",
    "product_ids": [],
    "rule_id": 0,
    "simple_action": "",
    "simple_free_shipping": "",
    "sort_order": 0,
    "stop_rules_processing": false,
    "store_labels": [
      {
        "extension_attributes": {},
        "store_id": 0,
        "store_label": ""
      }
    ],
    "times_used": 0,
    "to_date": "",
    "use_auto_generation": false,
    "uses_per_coupon": 0,
    "uses_per_customer": 0,
    "website_ids": []
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/salesRules/:ruleId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "rule": {
    "action_condition": {
      "aggregator_type": "",
      "attribute_name": "",
      "condition_type": "",
      "conditions": [],
      "extension_attributes": {},
      "operator": "",
      "value": ""
    },
    "apply_to_shipping": false,
    "condition": {},
    "coupon_type": "",
    "customer_group_ids": [],
    "description": "",
    "discount_amount": "",
    "discount_qty": "",
    "discount_step": 0,
    "extension_attributes": {
      "reward_points_delta": 0
    },
    "from_date": "",
    "is_active": false,
    "is_advanced": false,
    "is_rss": false,
    "name": "",
    "product_ids": [],
    "rule_id": 0,
    "simple_action": "",
    "simple_free_shipping": "",
    "sort_order": 0,
    "stop_rules_processing": false,
    "store_labels": [
      {
        "extension_attributes": {},
        "store_id": 0,
        "store_label": ""
      }
    ],
    "times_used": 0,
    "to_date": "",
    "use_auto_generation": false,
    "uses_per_coupon": 0,
    "uses_per_customer": 0,
    "website_ids": []
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/salesRules/:ruleId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/salesRules/:ruleId"

payload = { "rule": {
        "action_condition": {
            "aggregator_type": "",
            "attribute_name": "",
            "condition_type": "",
            "conditions": [],
            "extension_attributes": {},
            "operator": "",
            "value": ""
        },
        "apply_to_shipping": False,
        "condition": {},
        "coupon_type": "",
        "customer_group_ids": [],
        "description": "",
        "discount_amount": "",
        "discount_qty": "",
        "discount_step": 0,
        "extension_attributes": { "reward_points_delta": 0 },
        "from_date": "",
        "is_active": False,
        "is_advanced": False,
        "is_rss": False,
        "name": "",
        "product_ids": [],
        "rule_id": 0,
        "simple_action": "",
        "simple_free_shipping": "",
        "sort_order": 0,
        "stop_rules_processing": False,
        "store_labels": [
            {
                "extension_attributes": {},
                "store_id": 0,
                "store_label": ""
            }
        ],
        "times_used": 0,
        "to_date": "",
        "use_auto_generation": False,
        "uses_per_coupon": 0,
        "uses_per_customer": 0,
        "website_ids": []
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/salesRules/:ruleId"

payload <- "{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/salesRules/:ruleId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\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/V1/salesRules/:ruleId') do |req|
  req.body = "{\n  \"rule\": {\n    \"action_condition\": {\n      \"aggregator_type\": \"\",\n      \"attribute_name\": \"\",\n      \"condition_type\": \"\",\n      \"conditions\": [],\n      \"extension_attributes\": {},\n      \"operator\": \"\",\n      \"value\": \"\"\n    },\n    \"apply_to_shipping\": false,\n    \"condition\": {},\n    \"coupon_type\": \"\",\n    \"customer_group_ids\": [],\n    \"description\": \"\",\n    \"discount_amount\": \"\",\n    \"discount_qty\": \"\",\n    \"discount_step\": 0,\n    \"extension_attributes\": {\n      \"reward_points_delta\": 0\n    },\n    \"from_date\": \"\",\n    \"is_active\": false,\n    \"is_advanced\": false,\n    \"is_rss\": false,\n    \"name\": \"\",\n    \"product_ids\": [],\n    \"rule_id\": 0,\n    \"simple_action\": \"\",\n    \"simple_free_shipping\": \"\",\n    \"sort_order\": 0,\n    \"stop_rules_processing\": false,\n    \"store_labels\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": 0,\n        \"store_label\": \"\"\n      }\n    ],\n    \"times_used\": 0,\n    \"to_date\": \"\",\n    \"use_auto_generation\": false,\n    \"uses_per_coupon\": 0,\n    \"uses_per_customer\": 0,\n    \"website_ids\": []\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}}/V1/salesRules/:ruleId";

    let payload = json!({"rule": json!({
            "action_condition": json!({
                "aggregator_type": "",
                "attribute_name": "",
                "condition_type": "",
                "conditions": (),
                "extension_attributes": json!({}),
                "operator": "",
                "value": ""
            }),
            "apply_to_shipping": false,
            "condition": json!({}),
            "coupon_type": "",
            "customer_group_ids": (),
            "description": "",
            "discount_amount": "",
            "discount_qty": "",
            "discount_step": 0,
            "extension_attributes": json!({"reward_points_delta": 0}),
            "from_date": "",
            "is_active": false,
            "is_advanced": false,
            "is_rss": false,
            "name": "",
            "product_ids": (),
            "rule_id": 0,
            "simple_action": "",
            "simple_free_shipping": "",
            "sort_order": 0,
            "stop_rules_processing": false,
            "store_labels": (
                json!({
                    "extension_attributes": json!({}),
                    "store_id": 0,
                    "store_label": ""
                })
            ),
            "times_used": 0,
            "to_date": "",
            "use_auto_generation": false,
            "uses_per_coupon": 0,
            "uses_per_customer": 0,
            "website_ids": ()
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/salesRules/:ruleId \
  --header 'content-type: application/json' \
  --data '{
  "rule": {
    "action_condition": {
      "aggregator_type": "",
      "attribute_name": "",
      "condition_type": "",
      "conditions": [],
      "extension_attributes": {},
      "operator": "",
      "value": ""
    },
    "apply_to_shipping": false,
    "condition": {},
    "coupon_type": "",
    "customer_group_ids": [],
    "description": "",
    "discount_amount": "",
    "discount_qty": "",
    "discount_step": 0,
    "extension_attributes": {
      "reward_points_delta": 0
    },
    "from_date": "",
    "is_active": false,
    "is_advanced": false,
    "is_rss": false,
    "name": "",
    "product_ids": [],
    "rule_id": 0,
    "simple_action": "",
    "simple_free_shipping": "",
    "sort_order": 0,
    "stop_rules_processing": false,
    "store_labels": [
      {
        "extension_attributes": {},
        "store_id": 0,
        "store_label": ""
      }
    ],
    "times_used": 0,
    "to_date": "",
    "use_auto_generation": false,
    "uses_per_coupon": 0,
    "uses_per_customer": 0,
    "website_ids": []
  }
}'
echo '{
  "rule": {
    "action_condition": {
      "aggregator_type": "",
      "attribute_name": "",
      "condition_type": "",
      "conditions": [],
      "extension_attributes": {},
      "operator": "",
      "value": ""
    },
    "apply_to_shipping": false,
    "condition": {},
    "coupon_type": "",
    "customer_group_ids": [],
    "description": "",
    "discount_amount": "",
    "discount_qty": "",
    "discount_step": 0,
    "extension_attributes": {
      "reward_points_delta": 0
    },
    "from_date": "",
    "is_active": false,
    "is_advanced": false,
    "is_rss": false,
    "name": "",
    "product_ids": [],
    "rule_id": 0,
    "simple_action": "",
    "simple_free_shipping": "",
    "sort_order": 0,
    "stop_rules_processing": false,
    "store_labels": [
      {
        "extension_attributes": {},
        "store_id": 0,
        "store_label": ""
      }
    ],
    "times_used": 0,
    "to_date": "",
    "use_auto_generation": false,
    "uses_per_coupon": 0,
    "uses_per_customer": 0,
    "website_ids": []
  }
}' |  \
  http PUT {{baseUrl}}/V1/salesRules/:ruleId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "rule": {\n    "action_condition": {\n      "aggregator_type": "",\n      "attribute_name": "",\n      "condition_type": "",\n      "conditions": [],\n      "extension_attributes": {},\n      "operator": "",\n      "value": ""\n    },\n    "apply_to_shipping": false,\n    "condition": {},\n    "coupon_type": "",\n    "customer_group_ids": [],\n    "description": "",\n    "discount_amount": "",\n    "discount_qty": "",\n    "discount_step": 0,\n    "extension_attributes": {\n      "reward_points_delta": 0\n    },\n    "from_date": "",\n    "is_active": false,\n    "is_advanced": false,\n    "is_rss": false,\n    "name": "",\n    "product_ids": [],\n    "rule_id": 0,\n    "simple_action": "",\n    "simple_free_shipping": "",\n    "sort_order": 0,\n    "stop_rules_processing": false,\n    "store_labels": [\n      {\n        "extension_attributes": {},\n        "store_id": 0,\n        "store_label": ""\n      }\n    ],\n    "times_used": 0,\n    "to_date": "",\n    "use_auto_generation": false,\n    "uses_per_coupon": 0,\n    "uses_per_customer": 0,\n    "website_ids": []\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/salesRules/:ruleId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["rule": [
    "action_condition": [
      "aggregator_type": "",
      "attribute_name": "",
      "condition_type": "",
      "conditions": [],
      "extension_attributes": [],
      "operator": "",
      "value": ""
    ],
    "apply_to_shipping": false,
    "condition": [],
    "coupon_type": "",
    "customer_group_ids": [],
    "description": "",
    "discount_amount": "",
    "discount_qty": "",
    "discount_step": 0,
    "extension_attributes": ["reward_points_delta": 0],
    "from_date": "",
    "is_active": false,
    "is_advanced": false,
    "is_rss": false,
    "name": "",
    "product_ids": [],
    "rule_id": 0,
    "simple_action": "",
    "simple_free_shipping": "",
    "sort_order": 0,
    "stop_rules_processing": false,
    "store_labels": [
      [
        "extension_attributes": [],
        "store_id": 0,
        "store_label": ""
      ]
    ],
    "times_used": 0,
    "to_date": "",
    "use_auto_generation": false,
    "uses_per_coupon": 0,
    "uses_per_customer": 0,
    "website_ids": []
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/salesRules/:ruleId")! 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()
DELETE salesRules-{ruleId}
{{baseUrl}}/V1/salesRules/:ruleId
QUERY PARAMS

ruleId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/salesRules/:ruleId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/salesRules/:ruleId")
require "http/client"

url = "{{baseUrl}}/V1/salesRules/:ruleId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/salesRules/:ruleId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/salesRules/:ruleId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/salesRules/:ruleId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/salesRules/:ruleId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/salesRules/:ruleId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/salesRules/:ruleId"))
    .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}}/V1/salesRules/:ruleId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/salesRules/:ruleId")
  .asString();
const 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}}/V1/salesRules/:ruleId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/salesRules/:ruleId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/salesRules/:ruleId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/salesRules/:ruleId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/salesRules/:ruleId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/salesRules/:ruleId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/salesRules/:ruleId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/salesRules/:ruleId');

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}}/V1/salesRules/:ruleId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/salesRules/:ruleId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/salesRules/:ruleId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/salesRules/:ruleId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/salesRules/:ruleId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/salesRules/:ruleId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/salesRules/:ruleId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/salesRules/:ruleId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/salesRules/:ruleId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/salesRules/:ruleId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/salesRules/:ruleId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/salesRules/:ruleId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/salesRules/:ruleId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/salesRules/:ruleId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/salesRules/:ruleId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/salesRules/:ruleId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/salesRules/:ruleId
http DELETE {{baseUrl}}/V1/salesRules/:ruleId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/salesRules/:ruleId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/salesRules/:ruleId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/salesRules/search");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/salesRules/search")
require "http/client"

url = "{{baseUrl}}/V1/salesRules/search"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/salesRules/search"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/salesRules/search");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/salesRules/search"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/salesRules/search HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/salesRules/search")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/salesRules/search"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/salesRules/search")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/salesRules/search")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/salesRules/search');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/salesRules/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/salesRules/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/salesRules/search',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/salesRules/search")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/salesRules/search',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/salesRules/search'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/salesRules/search');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/salesRules/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/salesRules/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/salesRules/search"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/salesRules/search" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/salesRules/search",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/salesRules/search');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/salesRules/search');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/salesRules/search');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/salesRules/search' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/salesRules/search' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/salesRules/search")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/salesRules/search"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/salesRules/search"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/salesRules/search")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/salesRules/search') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/salesRules/search";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/salesRules/search
http GET {{baseUrl}}/V1/salesRules/search
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/salesRules/search
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/salesRules/search")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/search");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/search")
require "http/client"

url = "{{baseUrl}}/V1/search"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/search"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/search");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/search"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/search HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/search")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/search"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/search")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/search")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/search');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/search',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/search")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/search',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/search'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/search');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/search"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/search" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/search",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/search');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/search');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/search');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/search' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/search' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/search")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/search"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/search"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/search")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/search') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/search";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/search
http GET {{baseUrl}}/V1/search
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/search
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/search")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST sharedCatalog
{{baseUrl}}/V1/sharedCatalog
BODY json

{
  "sharedCatalog": {
    "created_at": "",
    "created_by": 0,
    "customer_group_id": 0,
    "description": "",
    "id": 0,
    "name": "",
    "store_id": 0,
    "tax_class_id": 0,
    "type": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/sharedCatalog");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/sharedCatalog" {:content-type :json
                                                             :form-params {:sharedCatalog {:created_at ""
                                                                                           :created_by 0
                                                                                           :customer_group_id 0
                                                                                           :description ""
                                                                                           :id 0
                                                                                           :name ""
                                                                                           :store_id 0
                                                                                           :tax_class_id 0
                                                                                           :type 0}}})
require "http/client"

url = "{{baseUrl}}/V1/sharedCatalog"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\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}}/V1/sharedCatalog"),
    Content = new StringContent("{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\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}}/V1/sharedCatalog");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/sharedCatalog"

	payload := strings.NewReader("{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/sharedCatalog HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 207

{
  "sharedCatalog": {
    "created_at": "",
    "created_by": 0,
    "customer_group_id": 0,
    "description": "",
    "id": 0,
    "name": "",
    "store_id": 0,
    "tax_class_id": 0,
    "type": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/sharedCatalog")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/sharedCatalog"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\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  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/sharedCatalog")
  .header("content-type", "application/json")
  .body("{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  sharedCatalog: {
    created_at: '',
    created_by: 0,
    customer_group_id: 0,
    description: '',
    id: 0,
    name: '',
    store_id: 0,
    tax_class_id: 0,
    type: 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}}/V1/sharedCatalog');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/sharedCatalog',
  headers: {'content-type': 'application/json'},
  data: {
    sharedCatalog: {
      created_at: '',
      created_by: 0,
      customer_group_id: 0,
      description: '',
      id: 0,
      name: '',
      store_id: 0,
      tax_class_id: 0,
      type: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/sharedCatalog';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"sharedCatalog":{"created_at":"","created_by":0,"customer_group_id":0,"description":"","id":0,"name":"","store_id":0,"tax_class_id":0,"type":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}}/V1/sharedCatalog',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "sharedCatalog": {\n    "created_at": "",\n    "created_by": 0,\n    "customer_group_id": 0,\n    "description": "",\n    "id": 0,\n    "name": "",\n    "store_id": 0,\n    "tax_class_id": 0,\n    "type": 0\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  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/sharedCatalog',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  sharedCatalog: {
    created_at: '',
    created_by: 0,
    customer_group_id: 0,
    description: '',
    id: 0,
    name: '',
    store_id: 0,
    tax_class_id: 0,
    type: 0
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/sharedCatalog',
  headers: {'content-type': 'application/json'},
  body: {
    sharedCatalog: {
      created_at: '',
      created_by: 0,
      customer_group_id: 0,
      description: '',
      id: 0,
      name: '',
      store_id: 0,
      tax_class_id: 0,
      type: 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}}/V1/sharedCatalog');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  sharedCatalog: {
    created_at: '',
    created_by: 0,
    customer_group_id: 0,
    description: '',
    id: 0,
    name: '',
    store_id: 0,
    tax_class_id: 0,
    type: 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}}/V1/sharedCatalog',
  headers: {'content-type': 'application/json'},
  data: {
    sharedCatalog: {
      created_at: '',
      created_by: 0,
      customer_group_id: 0,
      description: '',
      id: 0,
      name: '',
      store_id: 0,
      tax_class_id: 0,
      type: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/sharedCatalog';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"sharedCatalog":{"created_at":"","created_by":0,"customer_group_id":0,"description":"","id":0,"name":"","store_id":0,"tax_class_id":0,"type":0}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"sharedCatalog": @{ @"created_at": @"", @"created_by": @0, @"customer_group_id": @0, @"description": @"", @"id": @0, @"name": @"", @"store_id": @0, @"tax_class_id": @0, @"type": @0 } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/sharedCatalog"]
                                                       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}}/V1/sharedCatalog" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/sharedCatalog",
  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([
    'sharedCatalog' => [
        'created_at' => '',
        'created_by' => 0,
        'customer_group_id' => 0,
        'description' => '',
        'id' => 0,
        'name' => '',
        'store_id' => 0,
        'tax_class_id' => 0,
        'type' => 0
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/sharedCatalog', [
  'body' => '{
  "sharedCatalog": {
    "created_at": "",
    "created_by": 0,
    "customer_group_id": 0,
    "description": "",
    "id": 0,
    "name": "",
    "store_id": 0,
    "tax_class_id": 0,
    "type": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/sharedCatalog');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'sharedCatalog' => [
    'created_at' => '',
    'created_by' => 0,
    'customer_group_id' => 0,
    'description' => '',
    'id' => 0,
    'name' => '',
    'store_id' => 0,
    'tax_class_id' => 0,
    'type' => 0
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'sharedCatalog' => [
    'created_at' => '',
    'created_by' => 0,
    'customer_group_id' => 0,
    'description' => '',
    'id' => 0,
    'name' => '',
    'store_id' => 0,
    'tax_class_id' => 0,
    'type' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/sharedCatalog');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/sharedCatalog' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "sharedCatalog": {
    "created_at": "",
    "created_by": 0,
    "customer_group_id": 0,
    "description": "",
    "id": 0,
    "name": "",
    "store_id": 0,
    "tax_class_id": 0,
    "type": 0
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/sharedCatalog' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "sharedCatalog": {
    "created_at": "",
    "created_by": 0,
    "customer_group_id": 0,
    "description": "",
    "id": 0,
    "name": "",
    "store_id": 0,
    "tax_class_id": 0,
    "type": 0
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/sharedCatalog", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/sharedCatalog"

payload = { "sharedCatalog": {
        "created_at": "",
        "created_by": 0,
        "customer_group_id": 0,
        "description": "",
        "id": 0,
        "name": "",
        "store_id": 0,
        "tax_class_id": 0,
        "type": 0
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/sharedCatalog"

payload <- "{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/sharedCatalog")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\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/V1/sharedCatalog') do |req|
  req.body = "{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/sharedCatalog";

    let payload = json!({"sharedCatalog": json!({
            "created_at": "",
            "created_by": 0,
            "customer_group_id": 0,
            "description": "",
            "id": 0,
            "name": "",
            "store_id": 0,
            "tax_class_id": 0,
            "type": 0
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/sharedCatalog \
  --header 'content-type: application/json' \
  --data '{
  "sharedCatalog": {
    "created_at": "",
    "created_by": 0,
    "customer_group_id": 0,
    "description": "",
    "id": 0,
    "name": "",
    "store_id": 0,
    "tax_class_id": 0,
    "type": 0
  }
}'
echo '{
  "sharedCatalog": {
    "created_at": "",
    "created_by": 0,
    "customer_group_id": 0,
    "description": "",
    "id": 0,
    "name": "",
    "store_id": 0,
    "tax_class_id": 0,
    "type": 0
  }
}' |  \
  http POST {{baseUrl}}/V1/sharedCatalog \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "sharedCatalog": {\n    "created_at": "",\n    "created_by": 0,\n    "customer_group_id": 0,\n    "description": "",\n    "id": 0,\n    "name": "",\n    "store_id": 0,\n    "tax_class_id": 0,\n    "type": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/sharedCatalog
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["sharedCatalog": [
    "created_at": "",
    "created_by": 0,
    "customer_group_id": 0,
    "description": "",
    "id": 0,
    "name": "",
    "store_id": 0,
    "tax_class_id": 0,
    "type": 0
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/sharedCatalog")! 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 sharedCatalog-
{{baseUrl}}/V1/sharedCatalog/
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/sharedCatalog/");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/sharedCatalog/")
require "http/client"

url = "{{baseUrl}}/V1/sharedCatalog/"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/sharedCatalog/"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/sharedCatalog/");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/sharedCatalog/"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/sharedCatalog/ HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/sharedCatalog/")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/sharedCatalog/"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/sharedCatalog/")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/sharedCatalog/');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/sharedCatalog/'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/sharedCatalog/';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/sharedCatalog/',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/sharedCatalog/',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/sharedCatalog/'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/sharedCatalog/');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/sharedCatalog/'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/sharedCatalog/';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/sharedCatalog/"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/sharedCatalog/" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/sharedCatalog/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/sharedCatalog/');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/sharedCatalog/');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/sharedCatalog/');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/sharedCatalog/' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/sharedCatalog/' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/sharedCatalog/")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/sharedCatalog/"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/sharedCatalog/"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/sharedCatalog/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/sharedCatalog/') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/sharedCatalog/";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/sharedCatalog/
http GET {{baseUrl}}/V1/sharedCatalog/
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/sharedCatalog/
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/sharedCatalog/")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT sharedCatalog-{id}
{{baseUrl}}/V1/sharedCatalog/:id
QUERY PARAMS

id
BODY json

{
  "sharedCatalog": {
    "created_at": "",
    "created_by": 0,
    "customer_group_id": 0,
    "description": "",
    "id": 0,
    "name": "",
    "store_id": 0,
    "tax_class_id": 0,
    "type": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/sharedCatalog/:id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/sharedCatalog/:id" {:content-type :json
                                                                :form-params {:sharedCatalog {:created_at ""
                                                                                              :created_by 0
                                                                                              :customer_group_id 0
                                                                                              :description ""
                                                                                              :id 0
                                                                                              :name ""
                                                                                              :store_id 0
                                                                                              :tax_class_id 0
                                                                                              :type 0}}})
require "http/client"

url = "{{baseUrl}}/V1/sharedCatalog/:id"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\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}}/V1/sharedCatalog/:id"),
    Content = new StringContent("{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\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}}/V1/sharedCatalog/:id");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/sharedCatalog/:id"

	payload := strings.NewReader("{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/sharedCatalog/:id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 207

{
  "sharedCatalog": {
    "created_at": "",
    "created_by": 0,
    "customer_group_id": 0,
    "description": "",
    "id": 0,
    "name": "",
    "store_id": 0,
    "tax_class_id": 0,
    "type": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/sharedCatalog/:id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/sharedCatalog/:id"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\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  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/sharedCatalog/:id")
  .header("content-type", "application/json")
  .body("{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  sharedCatalog: {
    created_at: '',
    created_by: 0,
    customer_group_id: 0,
    description: '',
    id: 0,
    name: '',
    store_id: 0,
    tax_class_id: 0,
    type: 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}}/V1/sharedCatalog/:id');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/sharedCatalog/:id',
  headers: {'content-type': 'application/json'},
  data: {
    sharedCatalog: {
      created_at: '',
      created_by: 0,
      customer_group_id: 0,
      description: '',
      id: 0,
      name: '',
      store_id: 0,
      tax_class_id: 0,
      type: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/sharedCatalog/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"sharedCatalog":{"created_at":"","created_by":0,"customer_group_id":0,"description":"","id":0,"name":"","store_id":0,"tax_class_id":0,"type":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}}/V1/sharedCatalog/:id',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "sharedCatalog": {\n    "created_at": "",\n    "created_by": 0,\n    "customer_group_id": 0,\n    "description": "",\n    "id": 0,\n    "name": "",\n    "store_id": 0,\n    "tax_class_id": 0,\n    "type": 0\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  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:id")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/sharedCatalog/:id',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  sharedCatalog: {
    created_at: '',
    created_by: 0,
    customer_group_id: 0,
    description: '',
    id: 0,
    name: '',
    store_id: 0,
    tax_class_id: 0,
    type: 0
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/sharedCatalog/:id',
  headers: {'content-type': 'application/json'},
  body: {
    sharedCatalog: {
      created_at: '',
      created_by: 0,
      customer_group_id: 0,
      description: '',
      id: 0,
      name: '',
      store_id: 0,
      tax_class_id: 0,
      type: 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}}/V1/sharedCatalog/:id');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  sharedCatalog: {
    created_at: '',
    created_by: 0,
    customer_group_id: 0,
    description: '',
    id: 0,
    name: '',
    store_id: 0,
    tax_class_id: 0,
    type: 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}}/V1/sharedCatalog/:id',
  headers: {'content-type': 'application/json'},
  data: {
    sharedCatalog: {
      created_at: '',
      created_by: 0,
      customer_group_id: 0,
      description: '',
      id: 0,
      name: '',
      store_id: 0,
      tax_class_id: 0,
      type: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/sharedCatalog/:id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"sharedCatalog":{"created_at":"","created_by":0,"customer_group_id":0,"description":"","id":0,"name":"","store_id":0,"tax_class_id":0,"type":0}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"sharedCatalog": @{ @"created_at": @"", @"created_by": @0, @"customer_group_id": @0, @"description": @"", @"id": @0, @"name": @"", @"store_id": @0, @"tax_class_id": @0, @"type": @0 } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/sharedCatalog/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/sharedCatalog/:id" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/sharedCatalog/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'sharedCatalog' => [
        'created_at' => '',
        'created_by' => 0,
        'customer_group_id' => 0,
        'description' => '',
        'id' => 0,
        'name' => '',
        'store_id' => 0,
        'tax_class_id' => 0,
        'type' => 0
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/sharedCatalog/:id', [
  'body' => '{
  "sharedCatalog": {
    "created_at": "",
    "created_by": 0,
    "customer_group_id": 0,
    "description": "",
    "id": 0,
    "name": "",
    "store_id": 0,
    "tax_class_id": 0,
    "type": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/sharedCatalog/:id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'sharedCatalog' => [
    'created_at' => '',
    'created_by' => 0,
    'customer_group_id' => 0,
    'description' => '',
    'id' => 0,
    'name' => '',
    'store_id' => 0,
    'tax_class_id' => 0,
    'type' => 0
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'sharedCatalog' => [
    'created_at' => '',
    'created_by' => 0,
    'customer_group_id' => 0,
    'description' => '',
    'id' => 0,
    'name' => '',
    'store_id' => 0,
    'tax_class_id' => 0,
    'type' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/sharedCatalog/:id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/sharedCatalog/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "sharedCatalog": {
    "created_at": "",
    "created_by": 0,
    "customer_group_id": 0,
    "description": "",
    "id": 0,
    "name": "",
    "store_id": 0,
    "tax_class_id": 0,
    "type": 0
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/sharedCatalog/:id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "sharedCatalog": {
    "created_at": "",
    "created_by": 0,
    "customer_group_id": 0,
    "description": "",
    "id": 0,
    "name": "",
    "store_id": 0,
    "tax_class_id": 0,
    "type": 0
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/sharedCatalog/:id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/sharedCatalog/:id"

payload = { "sharedCatalog": {
        "created_at": "",
        "created_by": 0,
        "customer_group_id": 0,
        "description": "",
        "id": 0,
        "name": "",
        "store_id": 0,
        "tax_class_id": 0,
        "type": 0
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/sharedCatalog/:id"

payload <- "{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/sharedCatalog/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\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/V1/sharedCatalog/:id') do |req|
  req.body = "{\n  \"sharedCatalog\": {\n    \"created_at\": \"\",\n    \"created_by\": 0,\n    \"customer_group_id\": 0,\n    \"description\": \"\",\n    \"id\": 0,\n    \"name\": \"\",\n    \"store_id\": 0,\n    \"tax_class_id\": 0,\n    \"type\": 0\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}}/V1/sharedCatalog/:id";

    let payload = json!({"sharedCatalog": json!({
            "created_at": "",
            "created_by": 0,
            "customer_group_id": 0,
            "description": "",
            "id": 0,
            "name": "",
            "store_id": 0,
            "tax_class_id": 0,
            "type": 0
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/sharedCatalog/:id \
  --header 'content-type: application/json' \
  --data '{
  "sharedCatalog": {
    "created_at": "",
    "created_by": 0,
    "customer_group_id": 0,
    "description": "",
    "id": 0,
    "name": "",
    "store_id": 0,
    "tax_class_id": 0,
    "type": 0
  }
}'
echo '{
  "sharedCatalog": {
    "created_at": "",
    "created_by": 0,
    "customer_group_id": 0,
    "description": "",
    "id": 0,
    "name": "",
    "store_id": 0,
    "tax_class_id": 0,
    "type": 0
  }
}' |  \
  http PUT {{baseUrl}}/V1/sharedCatalog/:id \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "sharedCatalog": {\n    "created_at": "",\n    "created_by": 0,\n    "customer_group_id": 0,\n    "description": "",\n    "id": 0,\n    "name": "",\n    "store_id": 0,\n    "tax_class_id": 0,\n    "type": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/sharedCatalog/:id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["sharedCatalog": [
    "created_at": "",
    "created_by": 0,
    "customer_group_id": 0,
    "description": "",
    "id": 0,
    "name": "",
    "store_id": 0,
    "tax_class_id": 0,
    "type": 0
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/sharedCatalog/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST sharedCatalog-{id}-assignCategories
{{baseUrl}}/V1/sharedCatalog/:id/assignCategories
QUERY PARAMS

id
BODY json

{
  "categories": [
    {
      "available_sort_by": [],
      "children": "",
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {},
      "id": 0,
      "include_in_menu": false,
      "is_active": false,
      "level": 0,
      "name": "",
      "parent_id": 0,
      "path": "",
      "position": 0,
      "updated_at": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/sharedCatalog/:id/assignCategories");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/sharedCatalog/:id/assignCategories" {:content-type :json
                                                                                  :form-params {:categories [{:available_sort_by []
                                                                                                              :children ""
                                                                                                              :created_at ""
                                                                                                              :custom_attributes [{:attribute_code ""
                                                                                                                                   :value ""}]
                                                                                                              :extension_attributes {}
                                                                                                              :id 0
                                                                                                              :include_in_menu false
                                                                                                              :is_active false
                                                                                                              :level 0
                                                                                                              :name ""
                                                                                                              :parent_id 0
                                                                                                              :path ""
                                                                                                              :position 0
                                                                                                              :updated_at ""}]}})
require "http/client"

url = "{{baseUrl}}/V1/sharedCatalog/:id/assignCategories"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\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}}/V1/sharedCatalog/:id/assignCategories"),
    Content = new StringContent("{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\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}}/V1/sharedCatalog/:id/assignCategories");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/sharedCatalog/:id/assignCategories"

	payload := strings.NewReader("{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/sharedCatalog/:id/assignCategories HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 453

{
  "categories": [
    {
      "available_sort_by": [],
      "children": "",
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {},
      "id": 0,
      "include_in_menu": false,
      "is_active": false,
      "level": 0,
      "name": "",
      "parent_id": 0,
      "path": "",
      "position": 0,
      "updated_at": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/sharedCatalog/:id/assignCategories")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/sharedCatalog/:id/assignCategories"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\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  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:id/assignCategories")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/sharedCatalog/:id/assignCategories")
  .header("content-type", "application/json")
  .body("{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  categories: [
    {
      available_sort_by: [],
      children: '',
      created_at: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      extension_attributes: {},
      id: 0,
      include_in_menu: false,
      is_active: false,
      level: 0,
      name: '',
      parent_id: 0,
      path: '',
      position: 0,
      updated_at: ''
    }
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/sharedCatalog/:id/assignCategories');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/sharedCatalog/:id/assignCategories',
  headers: {'content-type': 'application/json'},
  data: {
    categories: [
      {
        available_sort_by: [],
        children: '',
        created_at: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        extension_attributes: {},
        id: 0,
        include_in_menu: false,
        is_active: false,
        level: 0,
        name: '',
        parent_id: 0,
        path: '',
        position: 0,
        updated_at: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/sharedCatalog/:id/assignCategories';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"categories":[{"available_sort_by":[],"children":"","created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{},"id":0,"include_in_menu":false,"is_active":false,"level":0,"name":"","parent_id":0,"path":"","position":0,"updated_at":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/sharedCatalog/:id/assignCategories',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "categories": [\n    {\n      "available_sort_by": [],\n      "children": "",\n      "created_at": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "extension_attributes": {},\n      "id": 0,\n      "include_in_menu": false,\n      "is_active": false,\n      "level": 0,\n      "name": "",\n      "parent_id": 0,\n      "path": "",\n      "position": 0,\n      "updated_at": ""\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  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:id/assignCategories")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/sharedCatalog/:id/assignCategories',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  categories: [
    {
      available_sort_by: [],
      children: '',
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {},
      id: 0,
      include_in_menu: false,
      is_active: false,
      level: 0,
      name: '',
      parent_id: 0,
      path: '',
      position: 0,
      updated_at: ''
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/sharedCatalog/:id/assignCategories',
  headers: {'content-type': 'application/json'},
  body: {
    categories: [
      {
        available_sort_by: [],
        children: '',
        created_at: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        extension_attributes: {},
        id: 0,
        include_in_menu: false,
        is_active: false,
        level: 0,
        name: '',
        parent_id: 0,
        path: '',
        position: 0,
        updated_at: ''
      }
    ]
  },
  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}}/V1/sharedCatalog/:id/assignCategories');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  categories: [
    {
      available_sort_by: [],
      children: '',
      created_at: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      extension_attributes: {},
      id: 0,
      include_in_menu: false,
      is_active: false,
      level: 0,
      name: '',
      parent_id: 0,
      path: '',
      position: 0,
      updated_at: ''
    }
  ]
});

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}}/V1/sharedCatalog/:id/assignCategories',
  headers: {'content-type': 'application/json'},
  data: {
    categories: [
      {
        available_sort_by: [],
        children: '',
        created_at: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        extension_attributes: {},
        id: 0,
        include_in_menu: false,
        is_active: false,
        level: 0,
        name: '',
        parent_id: 0,
        path: '',
        position: 0,
        updated_at: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/sharedCatalog/:id/assignCategories';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"categories":[{"available_sort_by":[],"children":"","created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{},"id":0,"include_in_menu":false,"is_active":false,"level":0,"name":"","parent_id":0,"path":"","position":0,"updated_at":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"categories": @[ @{ @"available_sort_by": @[  ], @"children": @"", @"created_at": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"extension_attributes": @{  }, @"id": @0, @"include_in_menu": @NO, @"is_active": @NO, @"level": @0, @"name": @"", @"parent_id": @0, @"path": @"", @"position": @0, @"updated_at": @"" } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/sharedCatalog/:id/assignCategories"]
                                                       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}}/V1/sharedCatalog/:id/assignCategories" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/sharedCatalog/:id/assignCategories",
  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([
    'categories' => [
        [
                'available_sort_by' => [
                                
                ],
                'children' => '',
                'created_at' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'extension_attributes' => [
                                
                ],
                'id' => 0,
                'include_in_menu' => null,
                'is_active' => null,
                'level' => 0,
                'name' => '',
                'parent_id' => 0,
                'path' => '',
                'position' => 0,
                'updated_at' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/sharedCatalog/:id/assignCategories', [
  'body' => '{
  "categories": [
    {
      "available_sort_by": [],
      "children": "",
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {},
      "id": 0,
      "include_in_menu": false,
      "is_active": false,
      "level": 0,
      "name": "",
      "parent_id": 0,
      "path": "",
      "position": 0,
      "updated_at": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/sharedCatalog/:id/assignCategories');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'categories' => [
    [
        'available_sort_by' => [
                
        ],
        'children' => '',
        'created_at' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'include_in_menu' => null,
        'is_active' => null,
        'level' => 0,
        'name' => '',
        'parent_id' => 0,
        'path' => '',
        'position' => 0,
        'updated_at' => ''
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'categories' => [
    [
        'available_sort_by' => [
                
        ],
        'children' => '',
        'created_at' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'include_in_menu' => null,
        'is_active' => null,
        'level' => 0,
        'name' => '',
        'parent_id' => 0,
        'path' => '',
        'position' => 0,
        'updated_at' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/sharedCatalog/:id/assignCategories');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/sharedCatalog/:id/assignCategories' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "categories": [
    {
      "available_sort_by": [],
      "children": "",
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {},
      "id": 0,
      "include_in_menu": false,
      "is_active": false,
      "level": 0,
      "name": "",
      "parent_id": 0,
      "path": "",
      "position": 0,
      "updated_at": ""
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/sharedCatalog/:id/assignCategories' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "categories": [
    {
      "available_sort_by": [],
      "children": "",
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {},
      "id": 0,
      "include_in_menu": false,
      "is_active": false,
      "level": 0,
      "name": "",
      "parent_id": 0,
      "path": "",
      "position": 0,
      "updated_at": ""
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/sharedCatalog/:id/assignCategories", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/sharedCatalog/:id/assignCategories"

payload = { "categories": [
        {
            "available_sort_by": [],
            "children": "",
            "created_at": "",
            "custom_attributes": [
                {
                    "attribute_code": "",
                    "value": ""
                }
            ],
            "extension_attributes": {},
            "id": 0,
            "include_in_menu": False,
            "is_active": False,
            "level": 0,
            "name": "",
            "parent_id": 0,
            "path": "",
            "position": 0,
            "updated_at": ""
        }
    ] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/sharedCatalog/:id/assignCategories"

payload <- "{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/sharedCatalog/:id/assignCategories")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\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/V1/sharedCatalog/:id/assignCategories') do |req|
  req.body = "{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\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}}/V1/sharedCatalog/:id/assignCategories";

    let payload = json!({"categories": (
            json!({
                "available_sort_by": (),
                "children": "",
                "created_at": "",
                "custom_attributes": (
                    json!({
                        "attribute_code": "",
                        "value": ""
                    })
                ),
                "extension_attributes": json!({}),
                "id": 0,
                "include_in_menu": false,
                "is_active": false,
                "level": 0,
                "name": "",
                "parent_id": 0,
                "path": "",
                "position": 0,
                "updated_at": ""
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/sharedCatalog/:id/assignCategories \
  --header 'content-type: application/json' \
  --data '{
  "categories": [
    {
      "available_sort_by": [],
      "children": "",
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {},
      "id": 0,
      "include_in_menu": false,
      "is_active": false,
      "level": 0,
      "name": "",
      "parent_id": 0,
      "path": "",
      "position": 0,
      "updated_at": ""
    }
  ]
}'
echo '{
  "categories": [
    {
      "available_sort_by": [],
      "children": "",
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {},
      "id": 0,
      "include_in_menu": false,
      "is_active": false,
      "level": 0,
      "name": "",
      "parent_id": 0,
      "path": "",
      "position": 0,
      "updated_at": ""
    }
  ]
}' |  \
  http POST {{baseUrl}}/V1/sharedCatalog/:id/assignCategories \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "categories": [\n    {\n      "available_sort_by": [],\n      "children": "",\n      "created_at": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "extension_attributes": {},\n      "id": 0,\n      "include_in_menu": false,\n      "is_active": false,\n      "level": 0,\n      "name": "",\n      "parent_id": 0,\n      "path": "",\n      "position": 0,\n      "updated_at": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/V1/sharedCatalog/:id/assignCategories
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["categories": [
    [
      "available_sort_by": [],
      "children": "",
      "created_at": "",
      "custom_attributes": [
        [
          "attribute_code": "",
          "value": ""
        ]
      ],
      "extension_attributes": [],
      "id": 0,
      "include_in_menu": false,
      "is_active": false,
      "level": 0,
      "name": "",
      "parent_id": 0,
      "path": "",
      "position": 0,
      "updated_at": ""
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/sharedCatalog/:id/assignCategories")! 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 sharedCatalog-{id}-assignProducts
{{baseUrl}}/V1/sharedCatalog/:id/assignProducts
QUERY PARAMS

id
BODY json

{
  "products": [
    {
      "attribute_set_id": 0,
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {
        "bundle_product_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "position": 0,
            "product_links": [
              {
                "can_change_quantity": 0,
                "extension_attributes": {},
                "id": "",
                "is_default": false,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
              }
            ],
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
          }
        ],
        "category_links": [
          {
            "category_id": "",
            "extension_attributes": {},
            "position": 0
          }
        ],
        "configurable_product_links": [],
        "configurable_product_options": [
          {
            "attribute_id": "",
            "extension_attributes": {},
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": [
              {
                "extension_attributes": {},
                "value_index": 0
              }
            ]
          }
        ],
        "downloadable_product_links": [
          {
            "extension_attributes": {},
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": {
              "extension_attributes": {},
              "file_data": "",
              "name": ""
            },
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "downloadable_product_samples": [
          {
            "extension_attributes": {},
            "id": 0,
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "giftcard_amounts": [
          {
            "attribute_id": 0,
            "extension_attributes": {},
            "value": "",
            "website_id": 0,
            "website_value": ""
          }
        ],
        "stock_item": {
          "backorders": 0,
          "enable_qty_increments": false,
          "extension_attributes": {},
          "is_decimal_divided": false,
          "is_in_stock": false,
          "is_qty_decimal": false,
          "item_id": 0,
          "low_stock_date": "",
          "manage_stock": false,
          "max_sale_qty": "",
          "min_qty": "",
          "min_sale_qty": "",
          "notify_stock_qty": "",
          "product_id": 0,
          "qty": "",
          "qty_increments": "",
          "show_default_notification_message": false,
          "stock_id": 0,
          "stock_status_changed_auto": 0,
          "use_config_backorders": false,
          "use_config_enable_qty_inc": false,
          "use_config_manage_stock": false,
          "use_config_max_sale_qty": false,
          "use_config_min_qty": false,
          "use_config_min_sale_qty": 0,
          "use_config_notify_stock_qty": false,
          "use_config_qty_increments": false
        },
        "website_ids": []
      },
      "id": 0,
      "media_gallery_entries": [
        {
          "content": {
            "base64_encoded_data": "",
            "name": "",
            "type": ""
          },
          "disabled": false,
          "extension_attributes": {
            "video_content": {
              "media_type": "",
              "video_description": "",
              "video_metadata": "",
              "video_provider": "",
              "video_title": "",
              "video_url": ""
            }
          },
          "file": "",
          "id": 0,
          "label": "",
          "media_type": "",
          "position": 0,
          "types": []
        }
      ],
      "name": "",
      "options": [
        {
          "extension_attributes": {
            "vertex_flex_field": ""
          },
          "file_extension": "",
          "image_size_x": 0,
          "image_size_y": 0,
          "is_require": false,
          "max_characters": 0,
          "option_id": 0,
          "price": "",
          "price_type": "",
          "product_sku": "",
          "sku": "",
          "sort_order": 0,
          "title": "",
          "type": "",
          "values": [
            {
              "option_type_id": 0,
              "price": "",
              "price_type": "",
              "sku": "",
              "sort_order": 0,
              "title": ""
            }
          ]
        }
      ],
      "price": "",
      "product_links": [
        {
          "extension_attributes": {
            "qty": ""
          },
          "link_type": "",
          "linked_product_sku": "",
          "linked_product_type": "",
          "position": 0,
          "sku": ""
        }
      ],
      "sku": "",
      "status": 0,
      "tier_prices": [
        {
          "customer_group_id": 0,
          "extension_attributes": {
            "percentage_value": "",
            "website_id": 0
          },
          "qty": "",
          "value": ""
        }
      ],
      "type_id": "",
      "updated_at": "",
      "visibility": 0,
      "weight": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/sharedCatalog/:id/assignProducts");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/sharedCatalog/:id/assignProducts" {:content-type :json
                                                                                :form-params {:products [{:attribute_set_id 0
                                                                                                          :created_at ""
                                                                                                          :custom_attributes [{:attribute_code ""
                                                                                                                               :value ""}]
                                                                                                          :extension_attributes {:bundle_product_options [{:extension_attributes {}
                                                                                                                                                           :option_id 0
                                                                                                                                                           :position 0
                                                                                                                                                           :product_links [{:can_change_quantity 0
                                                                                                                                                                            :extension_attributes {}
                                                                                                                                                                            :id ""
                                                                                                                                                                            :is_default false
                                                                                                                                                                            :option_id 0
                                                                                                                                                                            :position 0
                                                                                                                                                                            :price ""
                                                                                                                                                                            :price_type 0
                                                                                                                                                                            :qty ""
                                                                                                                                                                            :sku ""}]
                                                                                                                                                           :required false
                                                                                                                                                           :sku ""
                                                                                                                                                           :title ""
                                                                                                                                                           :type ""}]
                                                                                                                                 :category_links [{:category_id ""
                                                                                                                                                   :extension_attributes {}
                                                                                                                                                   :position 0}]
                                                                                                                                 :configurable_product_links []
                                                                                                                                 :configurable_product_options [{:attribute_id ""
                                                                                                                                                                 :extension_attributes {}
                                                                                                                                                                 :id 0
                                                                                                                                                                 :is_use_default false
                                                                                                                                                                 :label ""
                                                                                                                                                                 :position 0
                                                                                                                                                                 :product_id 0
                                                                                                                                                                 :values [{:extension_attributes {}
                                                                                                                                                                           :value_index 0}]}]
                                                                                                                                 :downloadable_product_links [{:extension_attributes {}
                                                                                                                                                               :id 0
                                                                                                                                                               :is_shareable 0
                                                                                                                                                               :link_file ""
                                                                                                                                                               :link_file_content {:extension_attributes {}
                                                                                                                                                                                   :file_data ""
                                                                                                                                                                                   :name ""}
                                                                                                                                                               :link_type ""
                                                                                                                                                               :link_url ""
                                                                                                                                                               :number_of_downloads 0
                                                                                                                                                               :price ""
                                                                                                                                                               :sample_file ""
                                                                                                                                                               :sample_file_content {}
                                                                                                                                                               :sample_type ""
                                                                                                                                                               :sample_url ""
                                                                                                                                                               :sort_order 0
                                                                                                                                                               :title ""}]
                                                                                                                                 :downloadable_product_samples [{:extension_attributes {}
                                                                                                                                                                 :id 0
                                                                                                                                                                 :sample_file ""
                                                                                                                                                                 :sample_file_content {}
                                                                                                                                                                 :sample_type ""
                                                                                                                                                                 :sample_url ""
                                                                                                                                                                 :sort_order 0
                                                                                                                                                                 :title ""}]
                                                                                                                                 :giftcard_amounts [{:attribute_id 0
                                                                                                                                                     :extension_attributes {}
                                                                                                                                                     :value ""
                                                                                                                                                     :website_id 0
                                                                                                                                                     :website_value ""}]
                                                                                                                                 :stock_item {:backorders 0
                                                                                                                                              :enable_qty_increments false
                                                                                                                                              :extension_attributes {}
                                                                                                                                              :is_decimal_divided false
                                                                                                                                              :is_in_stock false
                                                                                                                                              :is_qty_decimal false
                                                                                                                                              :item_id 0
                                                                                                                                              :low_stock_date ""
                                                                                                                                              :manage_stock false
                                                                                                                                              :max_sale_qty ""
                                                                                                                                              :min_qty ""
                                                                                                                                              :min_sale_qty ""
                                                                                                                                              :notify_stock_qty ""
                                                                                                                                              :product_id 0
                                                                                                                                              :qty ""
                                                                                                                                              :qty_increments ""
                                                                                                                                              :show_default_notification_message false
                                                                                                                                              :stock_id 0
                                                                                                                                              :stock_status_changed_auto 0
                                                                                                                                              :use_config_backorders false
                                                                                                                                              :use_config_enable_qty_inc false
                                                                                                                                              :use_config_manage_stock false
                                                                                                                                              :use_config_max_sale_qty false
                                                                                                                                              :use_config_min_qty false
                                                                                                                                              :use_config_min_sale_qty 0
                                                                                                                                              :use_config_notify_stock_qty false
                                                                                                                                              :use_config_qty_increments false}
                                                                                                                                 :website_ids []}
                                                                                                          :id 0
                                                                                                          :media_gallery_entries [{:content {:base64_encoded_data ""
                                                                                                                                             :name ""
                                                                                                                                             :type ""}
                                                                                                                                   :disabled false
                                                                                                                                   :extension_attributes {:video_content {:media_type ""
                                                                                                                                                                          :video_description ""
                                                                                                                                                                          :video_metadata ""
                                                                                                                                                                          :video_provider ""
                                                                                                                                                                          :video_title ""
                                                                                                                                                                          :video_url ""}}
                                                                                                                                   :file ""
                                                                                                                                   :id 0
                                                                                                                                   :label ""
                                                                                                                                   :media_type ""
                                                                                                                                   :position 0
                                                                                                                                   :types []}]
                                                                                                          :name ""
                                                                                                          :options [{:extension_attributes {:vertex_flex_field ""}
                                                                                                                     :file_extension ""
                                                                                                                     :image_size_x 0
                                                                                                                     :image_size_y 0
                                                                                                                     :is_require false
                                                                                                                     :max_characters 0
                                                                                                                     :option_id 0
                                                                                                                     :price ""
                                                                                                                     :price_type ""
                                                                                                                     :product_sku ""
                                                                                                                     :sku ""
                                                                                                                     :sort_order 0
                                                                                                                     :title ""
                                                                                                                     :type ""
                                                                                                                     :values [{:option_type_id 0
                                                                                                                               :price ""
                                                                                                                               :price_type ""
                                                                                                                               :sku ""
                                                                                                                               :sort_order 0
                                                                                                                               :title ""}]}]
                                                                                                          :price ""
                                                                                                          :product_links [{:extension_attributes {:qty ""}
                                                                                                                           :link_type ""
                                                                                                                           :linked_product_sku ""
                                                                                                                           :linked_product_type ""
                                                                                                                           :position 0
                                                                                                                           :sku ""}]
                                                                                                          :sku ""
                                                                                                          :status 0
                                                                                                          :tier_prices [{:customer_group_id 0
                                                                                                                         :extension_attributes {:percentage_value ""
                                                                                                                                                :website_id 0}
                                                                                                                         :qty ""
                                                                                                                         :value ""}]
                                                                                                          :type_id ""
                                                                                                          :updated_at ""
                                                                                                          :visibility 0
                                                                                                          :weight ""}]}})
require "http/client"

url = "{{baseUrl}}/V1/sharedCatalog/:id/assignProducts"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\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}}/V1/sharedCatalog/:id/assignProducts"),
    Content = new StringContent("{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\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}}/V1/sharedCatalog/:id/assignProducts");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/sharedCatalog/:id/assignProducts"

	payload := strings.NewReader("{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/sharedCatalog/:id/assignProducts HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 5835

{
  "products": [
    {
      "attribute_set_id": 0,
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {
        "bundle_product_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "position": 0,
            "product_links": [
              {
                "can_change_quantity": 0,
                "extension_attributes": {},
                "id": "",
                "is_default": false,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
              }
            ],
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
          }
        ],
        "category_links": [
          {
            "category_id": "",
            "extension_attributes": {},
            "position": 0
          }
        ],
        "configurable_product_links": [],
        "configurable_product_options": [
          {
            "attribute_id": "",
            "extension_attributes": {},
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": [
              {
                "extension_attributes": {},
                "value_index": 0
              }
            ]
          }
        ],
        "downloadable_product_links": [
          {
            "extension_attributes": {},
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": {
              "extension_attributes": {},
              "file_data": "",
              "name": ""
            },
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "downloadable_product_samples": [
          {
            "extension_attributes": {},
            "id": 0,
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "giftcard_amounts": [
          {
            "attribute_id": 0,
            "extension_attributes": {},
            "value": "",
            "website_id": 0,
            "website_value": ""
          }
        ],
        "stock_item": {
          "backorders": 0,
          "enable_qty_increments": false,
          "extension_attributes": {},
          "is_decimal_divided": false,
          "is_in_stock": false,
          "is_qty_decimal": false,
          "item_id": 0,
          "low_stock_date": "",
          "manage_stock": false,
          "max_sale_qty": "",
          "min_qty": "",
          "min_sale_qty": "",
          "notify_stock_qty": "",
          "product_id": 0,
          "qty": "",
          "qty_increments": "",
          "show_default_notification_message": false,
          "stock_id": 0,
          "stock_status_changed_auto": 0,
          "use_config_backorders": false,
          "use_config_enable_qty_inc": false,
          "use_config_manage_stock": false,
          "use_config_max_sale_qty": false,
          "use_config_min_qty": false,
          "use_config_min_sale_qty": 0,
          "use_config_notify_stock_qty": false,
          "use_config_qty_increments": false
        },
        "website_ids": []
      },
      "id": 0,
      "media_gallery_entries": [
        {
          "content": {
            "base64_encoded_data": "",
            "name": "",
            "type": ""
          },
          "disabled": false,
          "extension_attributes": {
            "video_content": {
              "media_type": "",
              "video_description": "",
              "video_metadata": "",
              "video_provider": "",
              "video_title": "",
              "video_url": ""
            }
          },
          "file": "",
          "id": 0,
          "label": "",
          "media_type": "",
          "position": 0,
          "types": []
        }
      ],
      "name": "",
      "options": [
        {
          "extension_attributes": {
            "vertex_flex_field": ""
          },
          "file_extension": "",
          "image_size_x": 0,
          "image_size_y": 0,
          "is_require": false,
          "max_characters": 0,
          "option_id": 0,
          "price": "",
          "price_type": "",
          "product_sku": "",
          "sku": "",
          "sort_order": 0,
          "title": "",
          "type": "",
          "values": [
            {
              "option_type_id": 0,
              "price": "",
              "price_type": "",
              "sku": "",
              "sort_order": 0,
              "title": ""
            }
          ]
        }
      ],
      "price": "",
      "product_links": [
        {
          "extension_attributes": {
            "qty": ""
          },
          "link_type": "",
          "linked_product_sku": "",
          "linked_product_type": "",
          "position": 0,
          "sku": ""
        }
      ],
      "sku": "",
      "status": 0,
      "tier_prices": [
        {
          "customer_group_id": 0,
          "extension_attributes": {
            "percentage_value": "",
            "website_id": 0
          },
          "qty": "",
          "value": ""
        }
      ],
      "type_id": "",
      "updated_at": "",
      "visibility": 0,
      "weight": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/sharedCatalog/:id/assignProducts")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/sharedCatalog/:id/assignProducts"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\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  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:id/assignProducts")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/sharedCatalog/:id/assignProducts")
  .header("content-type", "application/json")
  .body("{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  products: [
    {
      attribute_set_id: 0,
      created_at: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      extension_attributes: {
        bundle_product_options: [
          {
            extension_attributes: {},
            option_id: 0,
            position: 0,
            product_links: [
              {
                can_change_quantity: 0,
                extension_attributes: {},
                id: '',
                is_default: false,
                option_id: 0,
                position: 0,
                price: '',
                price_type: 0,
                qty: '',
                sku: ''
              }
            ],
            required: false,
            sku: '',
            title: '',
            type: ''
          }
        ],
        category_links: [
          {
            category_id: '',
            extension_attributes: {},
            position: 0
          }
        ],
        configurable_product_links: [],
        configurable_product_options: [
          {
            attribute_id: '',
            extension_attributes: {},
            id: 0,
            is_use_default: false,
            label: '',
            position: 0,
            product_id: 0,
            values: [
              {
                extension_attributes: {},
                value_index: 0
              }
            ]
          }
        ],
        downloadable_product_links: [
          {
            extension_attributes: {},
            id: 0,
            is_shareable: 0,
            link_file: '',
            link_file_content: {
              extension_attributes: {},
              file_data: '',
              name: ''
            },
            link_type: '',
            link_url: '',
            number_of_downloads: 0,
            price: '',
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        downloadable_product_samples: [
          {
            extension_attributes: {},
            id: 0,
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        giftcard_amounts: [
          {
            attribute_id: 0,
            extension_attributes: {},
            value: '',
            website_id: 0,
            website_value: ''
          }
        ],
        stock_item: {
          backorders: 0,
          enable_qty_increments: false,
          extension_attributes: {},
          is_decimal_divided: false,
          is_in_stock: false,
          is_qty_decimal: false,
          item_id: 0,
          low_stock_date: '',
          manage_stock: false,
          max_sale_qty: '',
          min_qty: '',
          min_sale_qty: '',
          notify_stock_qty: '',
          product_id: 0,
          qty: '',
          qty_increments: '',
          show_default_notification_message: false,
          stock_id: 0,
          stock_status_changed_auto: 0,
          use_config_backorders: false,
          use_config_enable_qty_inc: false,
          use_config_manage_stock: false,
          use_config_max_sale_qty: false,
          use_config_min_qty: false,
          use_config_min_sale_qty: 0,
          use_config_notify_stock_qty: false,
          use_config_qty_increments: false
        },
        website_ids: []
      },
      id: 0,
      media_gallery_entries: [
        {
          content: {
            base64_encoded_data: '',
            name: '',
            type: ''
          },
          disabled: false,
          extension_attributes: {
            video_content: {
              media_type: '',
              video_description: '',
              video_metadata: '',
              video_provider: '',
              video_title: '',
              video_url: ''
            }
          },
          file: '',
          id: 0,
          label: '',
          media_type: '',
          position: 0,
          types: []
        }
      ],
      name: '',
      options: [
        {
          extension_attributes: {
            vertex_flex_field: ''
          },
          file_extension: '',
          image_size_x: 0,
          image_size_y: 0,
          is_require: false,
          max_characters: 0,
          option_id: 0,
          price: '',
          price_type: '',
          product_sku: '',
          sku: '',
          sort_order: 0,
          title: '',
          type: '',
          values: [
            {
              option_type_id: 0,
              price: '',
              price_type: '',
              sku: '',
              sort_order: 0,
              title: ''
            }
          ]
        }
      ],
      price: '',
      product_links: [
        {
          extension_attributes: {
            qty: ''
          },
          link_type: '',
          linked_product_sku: '',
          linked_product_type: '',
          position: 0,
          sku: ''
        }
      ],
      sku: '',
      status: 0,
      tier_prices: [
        {
          customer_group_id: 0,
          extension_attributes: {
            percentage_value: '',
            website_id: 0
          },
          qty: '',
          value: ''
        }
      ],
      type_id: '',
      updated_at: '',
      visibility: 0,
      weight: ''
    }
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/sharedCatalog/:id/assignProducts');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/sharedCatalog/:id/assignProducts',
  headers: {'content-type': 'application/json'},
  data: {
    products: [
      {
        attribute_set_id: 0,
        created_at: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        extension_attributes: {
          bundle_product_options: [
            {
              extension_attributes: {},
              option_id: 0,
              position: 0,
              product_links: [
                {
                  can_change_quantity: 0,
                  extension_attributes: {},
                  id: '',
                  is_default: false,
                  option_id: 0,
                  position: 0,
                  price: '',
                  price_type: 0,
                  qty: '',
                  sku: ''
                }
              ],
              required: false,
              sku: '',
              title: '',
              type: ''
            }
          ],
          category_links: [{category_id: '', extension_attributes: {}, position: 0}],
          configurable_product_links: [],
          configurable_product_options: [
            {
              attribute_id: '',
              extension_attributes: {},
              id: 0,
              is_use_default: false,
              label: '',
              position: 0,
              product_id: 0,
              values: [{extension_attributes: {}, value_index: 0}]
            }
          ],
          downloadable_product_links: [
            {
              extension_attributes: {},
              id: 0,
              is_shareable: 0,
              link_file: '',
              link_file_content: {extension_attributes: {}, file_data: '', name: ''},
              link_type: '',
              link_url: '',
              number_of_downloads: 0,
              price: '',
              sample_file: '',
              sample_file_content: {},
              sample_type: '',
              sample_url: '',
              sort_order: 0,
              title: ''
            }
          ],
          downloadable_product_samples: [
            {
              extension_attributes: {},
              id: 0,
              sample_file: '',
              sample_file_content: {},
              sample_type: '',
              sample_url: '',
              sort_order: 0,
              title: ''
            }
          ],
          giftcard_amounts: [
            {
              attribute_id: 0,
              extension_attributes: {},
              value: '',
              website_id: 0,
              website_value: ''
            }
          ],
          stock_item: {
            backorders: 0,
            enable_qty_increments: false,
            extension_attributes: {},
            is_decimal_divided: false,
            is_in_stock: false,
            is_qty_decimal: false,
            item_id: 0,
            low_stock_date: '',
            manage_stock: false,
            max_sale_qty: '',
            min_qty: '',
            min_sale_qty: '',
            notify_stock_qty: '',
            product_id: 0,
            qty: '',
            qty_increments: '',
            show_default_notification_message: false,
            stock_id: 0,
            stock_status_changed_auto: 0,
            use_config_backorders: false,
            use_config_enable_qty_inc: false,
            use_config_manage_stock: false,
            use_config_max_sale_qty: false,
            use_config_min_qty: false,
            use_config_min_sale_qty: 0,
            use_config_notify_stock_qty: false,
            use_config_qty_increments: false
          },
          website_ids: []
        },
        id: 0,
        media_gallery_entries: [
          {
            content: {base64_encoded_data: '', name: '', type: ''},
            disabled: false,
            extension_attributes: {
              video_content: {
                media_type: '',
                video_description: '',
                video_metadata: '',
                video_provider: '',
                video_title: '',
                video_url: ''
              }
            },
            file: '',
            id: 0,
            label: '',
            media_type: '',
            position: 0,
            types: []
          }
        ],
        name: '',
        options: [
          {
            extension_attributes: {vertex_flex_field: ''},
            file_extension: '',
            image_size_x: 0,
            image_size_y: 0,
            is_require: false,
            max_characters: 0,
            option_id: 0,
            price: '',
            price_type: '',
            product_sku: '',
            sku: '',
            sort_order: 0,
            title: '',
            type: '',
            values: [
              {
                option_type_id: 0,
                price: '',
                price_type: '',
                sku: '',
                sort_order: 0,
                title: ''
              }
            ]
          }
        ],
        price: '',
        product_links: [
          {
            extension_attributes: {qty: ''},
            link_type: '',
            linked_product_sku: '',
            linked_product_type: '',
            position: 0,
            sku: ''
          }
        ],
        sku: '',
        status: 0,
        tier_prices: [
          {
            customer_group_id: 0,
            extension_attributes: {percentage_value: '', website_id: 0},
            qty: '',
            value: ''
          }
        ],
        type_id: '',
        updated_at: '',
        visibility: 0,
        weight: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/sharedCatalog/:id/assignProducts';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"products":[{"attribute_set_id":0,"created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{"bundle_product_options":[{"extension_attributes":{},"option_id":0,"position":0,"product_links":[{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}],"required":false,"sku":"","title":"","type":""}],"category_links":[{"category_id":"","extension_attributes":{},"position":0}],"configurable_product_links":[],"configurable_product_options":[{"attribute_id":"","extension_attributes":{},"id":0,"is_use_default":false,"label":"","position":0,"product_id":0,"values":[{"extension_attributes":{},"value_index":0}]}],"downloadable_product_links":[{"extension_attributes":{},"id":0,"is_shareable":0,"link_file":"","link_file_content":{"extension_attributes":{},"file_data":"","name":""},"link_type":"","link_url":"","number_of_downloads":0,"price":"","sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"downloadable_product_samples":[{"extension_attributes":{},"id":0,"sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"giftcard_amounts":[{"attribute_id":0,"extension_attributes":{},"value":"","website_id":0,"website_value":""}],"stock_item":{"backorders":0,"enable_qty_increments":false,"extension_attributes":{},"is_decimal_divided":false,"is_in_stock":false,"is_qty_decimal":false,"item_id":0,"low_stock_date":"","manage_stock":false,"max_sale_qty":"","min_qty":"","min_sale_qty":"","notify_stock_qty":"","product_id":0,"qty":"","qty_increments":"","show_default_notification_message":false,"stock_id":0,"stock_status_changed_auto":0,"use_config_backorders":false,"use_config_enable_qty_inc":false,"use_config_manage_stock":false,"use_config_max_sale_qty":false,"use_config_min_qty":false,"use_config_min_sale_qty":0,"use_config_notify_stock_qty":false,"use_config_qty_increments":false},"website_ids":[]},"id":0,"media_gallery_entries":[{"content":{"base64_encoded_data":"","name":"","type":""},"disabled":false,"extension_attributes":{"video_content":{"media_type":"","video_description":"","video_metadata":"","video_provider":"","video_title":"","video_url":""}},"file":"","id":0,"label":"","media_type":"","position":0,"types":[]}],"name":"","options":[{"extension_attributes":{"vertex_flex_field":""},"file_extension":"","image_size_x":0,"image_size_y":0,"is_require":false,"max_characters":0,"option_id":0,"price":"","price_type":"","product_sku":"","sku":"","sort_order":0,"title":"","type":"","values":[{"option_type_id":0,"price":"","price_type":"","sku":"","sort_order":0,"title":""}]}],"price":"","product_links":[{"extension_attributes":{"qty":""},"link_type":"","linked_product_sku":"","linked_product_type":"","position":0,"sku":""}],"sku":"","status":0,"tier_prices":[{"customer_group_id":0,"extension_attributes":{"percentage_value":"","website_id":0},"qty":"","value":""}],"type_id":"","updated_at":"","visibility":0,"weight":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/sharedCatalog/:id/assignProducts',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "products": [\n    {\n      "attribute_set_id": 0,\n      "created_at": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "extension_attributes": {\n        "bundle_product_options": [\n          {\n            "extension_attributes": {},\n            "option_id": 0,\n            "position": 0,\n            "product_links": [\n              {\n                "can_change_quantity": 0,\n                "extension_attributes": {},\n                "id": "",\n                "is_default": false,\n                "option_id": 0,\n                "position": 0,\n                "price": "",\n                "price_type": 0,\n                "qty": "",\n                "sku": ""\n              }\n            ],\n            "required": false,\n            "sku": "",\n            "title": "",\n            "type": ""\n          }\n        ],\n        "category_links": [\n          {\n            "category_id": "",\n            "extension_attributes": {},\n            "position": 0\n          }\n        ],\n        "configurable_product_links": [],\n        "configurable_product_options": [\n          {\n            "attribute_id": "",\n            "extension_attributes": {},\n            "id": 0,\n            "is_use_default": false,\n            "label": "",\n            "position": 0,\n            "product_id": 0,\n            "values": [\n              {\n                "extension_attributes": {},\n                "value_index": 0\n              }\n            ]\n          }\n        ],\n        "downloadable_product_links": [\n          {\n            "extension_attributes": {},\n            "id": 0,\n            "is_shareable": 0,\n            "link_file": "",\n            "link_file_content": {\n              "extension_attributes": {},\n              "file_data": "",\n              "name": ""\n            },\n            "link_type": "",\n            "link_url": "",\n            "number_of_downloads": 0,\n            "price": "",\n            "sample_file": "",\n            "sample_file_content": {},\n            "sample_type": "",\n            "sample_url": "",\n            "sort_order": 0,\n            "title": ""\n          }\n        ],\n        "downloadable_product_samples": [\n          {\n            "extension_attributes": {},\n            "id": 0,\n            "sample_file": "",\n            "sample_file_content": {},\n            "sample_type": "",\n            "sample_url": "",\n            "sort_order": 0,\n            "title": ""\n          }\n        ],\n        "giftcard_amounts": [\n          {\n            "attribute_id": 0,\n            "extension_attributes": {},\n            "value": "",\n            "website_id": 0,\n            "website_value": ""\n          }\n        ],\n        "stock_item": {\n          "backorders": 0,\n          "enable_qty_increments": false,\n          "extension_attributes": {},\n          "is_decimal_divided": false,\n          "is_in_stock": false,\n          "is_qty_decimal": false,\n          "item_id": 0,\n          "low_stock_date": "",\n          "manage_stock": false,\n          "max_sale_qty": "",\n          "min_qty": "",\n          "min_sale_qty": "",\n          "notify_stock_qty": "",\n          "product_id": 0,\n          "qty": "",\n          "qty_increments": "",\n          "show_default_notification_message": false,\n          "stock_id": 0,\n          "stock_status_changed_auto": 0,\n          "use_config_backorders": false,\n          "use_config_enable_qty_inc": false,\n          "use_config_manage_stock": false,\n          "use_config_max_sale_qty": false,\n          "use_config_min_qty": false,\n          "use_config_min_sale_qty": 0,\n          "use_config_notify_stock_qty": false,\n          "use_config_qty_increments": false\n        },\n        "website_ids": []\n      },\n      "id": 0,\n      "media_gallery_entries": [\n        {\n          "content": {\n            "base64_encoded_data": "",\n            "name": "",\n            "type": ""\n          },\n          "disabled": false,\n          "extension_attributes": {\n            "video_content": {\n              "media_type": "",\n              "video_description": "",\n              "video_metadata": "",\n              "video_provider": "",\n              "video_title": "",\n              "video_url": ""\n            }\n          },\n          "file": "",\n          "id": 0,\n          "label": "",\n          "media_type": "",\n          "position": 0,\n          "types": []\n        }\n      ],\n      "name": "",\n      "options": [\n        {\n          "extension_attributes": {\n            "vertex_flex_field": ""\n          },\n          "file_extension": "",\n          "image_size_x": 0,\n          "image_size_y": 0,\n          "is_require": false,\n          "max_characters": 0,\n          "option_id": 0,\n          "price": "",\n          "price_type": "",\n          "product_sku": "",\n          "sku": "",\n          "sort_order": 0,\n          "title": "",\n          "type": "",\n          "values": [\n            {\n              "option_type_id": 0,\n              "price": "",\n              "price_type": "",\n              "sku": "",\n              "sort_order": 0,\n              "title": ""\n            }\n          ]\n        }\n      ],\n      "price": "",\n      "product_links": [\n        {\n          "extension_attributes": {\n            "qty": ""\n          },\n          "link_type": "",\n          "linked_product_sku": "",\n          "linked_product_type": "",\n          "position": 0,\n          "sku": ""\n        }\n      ],\n      "sku": "",\n      "status": 0,\n      "tier_prices": [\n        {\n          "customer_group_id": 0,\n          "extension_attributes": {\n            "percentage_value": "",\n            "website_id": 0\n          },\n          "qty": "",\n          "value": ""\n        }\n      ],\n      "type_id": "",\n      "updated_at": "",\n      "visibility": 0,\n      "weight": ""\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  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:id/assignProducts")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/sharedCatalog/:id/assignProducts',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  products: [
    {
      attribute_set_id: 0,
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {
        bundle_product_options: [
          {
            extension_attributes: {},
            option_id: 0,
            position: 0,
            product_links: [
              {
                can_change_quantity: 0,
                extension_attributes: {},
                id: '',
                is_default: false,
                option_id: 0,
                position: 0,
                price: '',
                price_type: 0,
                qty: '',
                sku: ''
              }
            ],
            required: false,
            sku: '',
            title: '',
            type: ''
          }
        ],
        category_links: [{category_id: '', extension_attributes: {}, position: 0}],
        configurable_product_links: [],
        configurable_product_options: [
          {
            attribute_id: '',
            extension_attributes: {},
            id: 0,
            is_use_default: false,
            label: '',
            position: 0,
            product_id: 0,
            values: [{extension_attributes: {}, value_index: 0}]
          }
        ],
        downloadable_product_links: [
          {
            extension_attributes: {},
            id: 0,
            is_shareable: 0,
            link_file: '',
            link_file_content: {extension_attributes: {}, file_data: '', name: ''},
            link_type: '',
            link_url: '',
            number_of_downloads: 0,
            price: '',
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        downloadable_product_samples: [
          {
            extension_attributes: {},
            id: 0,
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        giftcard_amounts: [
          {
            attribute_id: 0,
            extension_attributes: {},
            value: '',
            website_id: 0,
            website_value: ''
          }
        ],
        stock_item: {
          backorders: 0,
          enable_qty_increments: false,
          extension_attributes: {},
          is_decimal_divided: false,
          is_in_stock: false,
          is_qty_decimal: false,
          item_id: 0,
          low_stock_date: '',
          manage_stock: false,
          max_sale_qty: '',
          min_qty: '',
          min_sale_qty: '',
          notify_stock_qty: '',
          product_id: 0,
          qty: '',
          qty_increments: '',
          show_default_notification_message: false,
          stock_id: 0,
          stock_status_changed_auto: 0,
          use_config_backorders: false,
          use_config_enable_qty_inc: false,
          use_config_manage_stock: false,
          use_config_max_sale_qty: false,
          use_config_min_qty: false,
          use_config_min_sale_qty: 0,
          use_config_notify_stock_qty: false,
          use_config_qty_increments: false
        },
        website_ids: []
      },
      id: 0,
      media_gallery_entries: [
        {
          content: {base64_encoded_data: '', name: '', type: ''},
          disabled: false,
          extension_attributes: {
            video_content: {
              media_type: '',
              video_description: '',
              video_metadata: '',
              video_provider: '',
              video_title: '',
              video_url: ''
            }
          },
          file: '',
          id: 0,
          label: '',
          media_type: '',
          position: 0,
          types: []
        }
      ],
      name: '',
      options: [
        {
          extension_attributes: {vertex_flex_field: ''},
          file_extension: '',
          image_size_x: 0,
          image_size_y: 0,
          is_require: false,
          max_characters: 0,
          option_id: 0,
          price: '',
          price_type: '',
          product_sku: '',
          sku: '',
          sort_order: 0,
          title: '',
          type: '',
          values: [
            {
              option_type_id: 0,
              price: '',
              price_type: '',
              sku: '',
              sort_order: 0,
              title: ''
            }
          ]
        }
      ],
      price: '',
      product_links: [
        {
          extension_attributes: {qty: ''},
          link_type: '',
          linked_product_sku: '',
          linked_product_type: '',
          position: 0,
          sku: ''
        }
      ],
      sku: '',
      status: 0,
      tier_prices: [
        {
          customer_group_id: 0,
          extension_attributes: {percentage_value: '', website_id: 0},
          qty: '',
          value: ''
        }
      ],
      type_id: '',
      updated_at: '',
      visibility: 0,
      weight: ''
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/sharedCatalog/:id/assignProducts',
  headers: {'content-type': 'application/json'},
  body: {
    products: [
      {
        attribute_set_id: 0,
        created_at: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        extension_attributes: {
          bundle_product_options: [
            {
              extension_attributes: {},
              option_id: 0,
              position: 0,
              product_links: [
                {
                  can_change_quantity: 0,
                  extension_attributes: {},
                  id: '',
                  is_default: false,
                  option_id: 0,
                  position: 0,
                  price: '',
                  price_type: 0,
                  qty: '',
                  sku: ''
                }
              ],
              required: false,
              sku: '',
              title: '',
              type: ''
            }
          ],
          category_links: [{category_id: '', extension_attributes: {}, position: 0}],
          configurable_product_links: [],
          configurable_product_options: [
            {
              attribute_id: '',
              extension_attributes: {},
              id: 0,
              is_use_default: false,
              label: '',
              position: 0,
              product_id: 0,
              values: [{extension_attributes: {}, value_index: 0}]
            }
          ],
          downloadable_product_links: [
            {
              extension_attributes: {},
              id: 0,
              is_shareable: 0,
              link_file: '',
              link_file_content: {extension_attributes: {}, file_data: '', name: ''},
              link_type: '',
              link_url: '',
              number_of_downloads: 0,
              price: '',
              sample_file: '',
              sample_file_content: {},
              sample_type: '',
              sample_url: '',
              sort_order: 0,
              title: ''
            }
          ],
          downloadable_product_samples: [
            {
              extension_attributes: {},
              id: 0,
              sample_file: '',
              sample_file_content: {},
              sample_type: '',
              sample_url: '',
              sort_order: 0,
              title: ''
            }
          ],
          giftcard_amounts: [
            {
              attribute_id: 0,
              extension_attributes: {},
              value: '',
              website_id: 0,
              website_value: ''
            }
          ],
          stock_item: {
            backorders: 0,
            enable_qty_increments: false,
            extension_attributes: {},
            is_decimal_divided: false,
            is_in_stock: false,
            is_qty_decimal: false,
            item_id: 0,
            low_stock_date: '',
            manage_stock: false,
            max_sale_qty: '',
            min_qty: '',
            min_sale_qty: '',
            notify_stock_qty: '',
            product_id: 0,
            qty: '',
            qty_increments: '',
            show_default_notification_message: false,
            stock_id: 0,
            stock_status_changed_auto: 0,
            use_config_backorders: false,
            use_config_enable_qty_inc: false,
            use_config_manage_stock: false,
            use_config_max_sale_qty: false,
            use_config_min_qty: false,
            use_config_min_sale_qty: 0,
            use_config_notify_stock_qty: false,
            use_config_qty_increments: false
          },
          website_ids: []
        },
        id: 0,
        media_gallery_entries: [
          {
            content: {base64_encoded_data: '', name: '', type: ''},
            disabled: false,
            extension_attributes: {
              video_content: {
                media_type: '',
                video_description: '',
                video_metadata: '',
                video_provider: '',
                video_title: '',
                video_url: ''
              }
            },
            file: '',
            id: 0,
            label: '',
            media_type: '',
            position: 0,
            types: []
          }
        ],
        name: '',
        options: [
          {
            extension_attributes: {vertex_flex_field: ''},
            file_extension: '',
            image_size_x: 0,
            image_size_y: 0,
            is_require: false,
            max_characters: 0,
            option_id: 0,
            price: '',
            price_type: '',
            product_sku: '',
            sku: '',
            sort_order: 0,
            title: '',
            type: '',
            values: [
              {
                option_type_id: 0,
                price: '',
                price_type: '',
                sku: '',
                sort_order: 0,
                title: ''
              }
            ]
          }
        ],
        price: '',
        product_links: [
          {
            extension_attributes: {qty: ''},
            link_type: '',
            linked_product_sku: '',
            linked_product_type: '',
            position: 0,
            sku: ''
          }
        ],
        sku: '',
        status: 0,
        tier_prices: [
          {
            customer_group_id: 0,
            extension_attributes: {percentage_value: '', website_id: 0},
            qty: '',
            value: ''
          }
        ],
        type_id: '',
        updated_at: '',
        visibility: 0,
        weight: ''
      }
    ]
  },
  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}}/V1/sharedCatalog/:id/assignProducts');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  products: [
    {
      attribute_set_id: 0,
      created_at: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      extension_attributes: {
        bundle_product_options: [
          {
            extension_attributes: {},
            option_id: 0,
            position: 0,
            product_links: [
              {
                can_change_quantity: 0,
                extension_attributes: {},
                id: '',
                is_default: false,
                option_id: 0,
                position: 0,
                price: '',
                price_type: 0,
                qty: '',
                sku: ''
              }
            ],
            required: false,
            sku: '',
            title: '',
            type: ''
          }
        ],
        category_links: [
          {
            category_id: '',
            extension_attributes: {},
            position: 0
          }
        ],
        configurable_product_links: [],
        configurable_product_options: [
          {
            attribute_id: '',
            extension_attributes: {},
            id: 0,
            is_use_default: false,
            label: '',
            position: 0,
            product_id: 0,
            values: [
              {
                extension_attributes: {},
                value_index: 0
              }
            ]
          }
        ],
        downloadable_product_links: [
          {
            extension_attributes: {},
            id: 0,
            is_shareable: 0,
            link_file: '',
            link_file_content: {
              extension_attributes: {},
              file_data: '',
              name: ''
            },
            link_type: '',
            link_url: '',
            number_of_downloads: 0,
            price: '',
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        downloadable_product_samples: [
          {
            extension_attributes: {},
            id: 0,
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        giftcard_amounts: [
          {
            attribute_id: 0,
            extension_attributes: {},
            value: '',
            website_id: 0,
            website_value: ''
          }
        ],
        stock_item: {
          backorders: 0,
          enable_qty_increments: false,
          extension_attributes: {},
          is_decimal_divided: false,
          is_in_stock: false,
          is_qty_decimal: false,
          item_id: 0,
          low_stock_date: '',
          manage_stock: false,
          max_sale_qty: '',
          min_qty: '',
          min_sale_qty: '',
          notify_stock_qty: '',
          product_id: 0,
          qty: '',
          qty_increments: '',
          show_default_notification_message: false,
          stock_id: 0,
          stock_status_changed_auto: 0,
          use_config_backorders: false,
          use_config_enable_qty_inc: false,
          use_config_manage_stock: false,
          use_config_max_sale_qty: false,
          use_config_min_qty: false,
          use_config_min_sale_qty: 0,
          use_config_notify_stock_qty: false,
          use_config_qty_increments: false
        },
        website_ids: []
      },
      id: 0,
      media_gallery_entries: [
        {
          content: {
            base64_encoded_data: '',
            name: '',
            type: ''
          },
          disabled: false,
          extension_attributes: {
            video_content: {
              media_type: '',
              video_description: '',
              video_metadata: '',
              video_provider: '',
              video_title: '',
              video_url: ''
            }
          },
          file: '',
          id: 0,
          label: '',
          media_type: '',
          position: 0,
          types: []
        }
      ],
      name: '',
      options: [
        {
          extension_attributes: {
            vertex_flex_field: ''
          },
          file_extension: '',
          image_size_x: 0,
          image_size_y: 0,
          is_require: false,
          max_characters: 0,
          option_id: 0,
          price: '',
          price_type: '',
          product_sku: '',
          sku: '',
          sort_order: 0,
          title: '',
          type: '',
          values: [
            {
              option_type_id: 0,
              price: '',
              price_type: '',
              sku: '',
              sort_order: 0,
              title: ''
            }
          ]
        }
      ],
      price: '',
      product_links: [
        {
          extension_attributes: {
            qty: ''
          },
          link_type: '',
          linked_product_sku: '',
          linked_product_type: '',
          position: 0,
          sku: ''
        }
      ],
      sku: '',
      status: 0,
      tier_prices: [
        {
          customer_group_id: 0,
          extension_attributes: {
            percentage_value: '',
            website_id: 0
          },
          qty: '',
          value: ''
        }
      ],
      type_id: '',
      updated_at: '',
      visibility: 0,
      weight: ''
    }
  ]
});

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}}/V1/sharedCatalog/:id/assignProducts',
  headers: {'content-type': 'application/json'},
  data: {
    products: [
      {
        attribute_set_id: 0,
        created_at: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        extension_attributes: {
          bundle_product_options: [
            {
              extension_attributes: {},
              option_id: 0,
              position: 0,
              product_links: [
                {
                  can_change_quantity: 0,
                  extension_attributes: {},
                  id: '',
                  is_default: false,
                  option_id: 0,
                  position: 0,
                  price: '',
                  price_type: 0,
                  qty: '',
                  sku: ''
                }
              ],
              required: false,
              sku: '',
              title: '',
              type: ''
            }
          ],
          category_links: [{category_id: '', extension_attributes: {}, position: 0}],
          configurable_product_links: [],
          configurable_product_options: [
            {
              attribute_id: '',
              extension_attributes: {},
              id: 0,
              is_use_default: false,
              label: '',
              position: 0,
              product_id: 0,
              values: [{extension_attributes: {}, value_index: 0}]
            }
          ],
          downloadable_product_links: [
            {
              extension_attributes: {},
              id: 0,
              is_shareable: 0,
              link_file: '',
              link_file_content: {extension_attributes: {}, file_data: '', name: ''},
              link_type: '',
              link_url: '',
              number_of_downloads: 0,
              price: '',
              sample_file: '',
              sample_file_content: {},
              sample_type: '',
              sample_url: '',
              sort_order: 0,
              title: ''
            }
          ],
          downloadable_product_samples: [
            {
              extension_attributes: {},
              id: 0,
              sample_file: '',
              sample_file_content: {},
              sample_type: '',
              sample_url: '',
              sort_order: 0,
              title: ''
            }
          ],
          giftcard_amounts: [
            {
              attribute_id: 0,
              extension_attributes: {},
              value: '',
              website_id: 0,
              website_value: ''
            }
          ],
          stock_item: {
            backorders: 0,
            enable_qty_increments: false,
            extension_attributes: {},
            is_decimal_divided: false,
            is_in_stock: false,
            is_qty_decimal: false,
            item_id: 0,
            low_stock_date: '',
            manage_stock: false,
            max_sale_qty: '',
            min_qty: '',
            min_sale_qty: '',
            notify_stock_qty: '',
            product_id: 0,
            qty: '',
            qty_increments: '',
            show_default_notification_message: false,
            stock_id: 0,
            stock_status_changed_auto: 0,
            use_config_backorders: false,
            use_config_enable_qty_inc: false,
            use_config_manage_stock: false,
            use_config_max_sale_qty: false,
            use_config_min_qty: false,
            use_config_min_sale_qty: 0,
            use_config_notify_stock_qty: false,
            use_config_qty_increments: false
          },
          website_ids: []
        },
        id: 0,
        media_gallery_entries: [
          {
            content: {base64_encoded_data: '', name: '', type: ''},
            disabled: false,
            extension_attributes: {
              video_content: {
                media_type: '',
                video_description: '',
                video_metadata: '',
                video_provider: '',
                video_title: '',
                video_url: ''
              }
            },
            file: '',
            id: 0,
            label: '',
            media_type: '',
            position: 0,
            types: []
          }
        ],
        name: '',
        options: [
          {
            extension_attributes: {vertex_flex_field: ''},
            file_extension: '',
            image_size_x: 0,
            image_size_y: 0,
            is_require: false,
            max_characters: 0,
            option_id: 0,
            price: '',
            price_type: '',
            product_sku: '',
            sku: '',
            sort_order: 0,
            title: '',
            type: '',
            values: [
              {
                option_type_id: 0,
                price: '',
                price_type: '',
                sku: '',
                sort_order: 0,
                title: ''
              }
            ]
          }
        ],
        price: '',
        product_links: [
          {
            extension_attributes: {qty: ''},
            link_type: '',
            linked_product_sku: '',
            linked_product_type: '',
            position: 0,
            sku: ''
          }
        ],
        sku: '',
        status: 0,
        tier_prices: [
          {
            customer_group_id: 0,
            extension_attributes: {percentage_value: '', website_id: 0},
            qty: '',
            value: ''
          }
        ],
        type_id: '',
        updated_at: '',
        visibility: 0,
        weight: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/sharedCatalog/:id/assignProducts';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"products":[{"attribute_set_id":0,"created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{"bundle_product_options":[{"extension_attributes":{},"option_id":0,"position":0,"product_links":[{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}],"required":false,"sku":"","title":"","type":""}],"category_links":[{"category_id":"","extension_attributes":{},"position":0}],"configurable_product_links":[],"configurable_product_options":[{"attribute_id":"","extension_attributes":{},"id":0,"is_use_default":false,"label":"","position":0,"product_id":0,"values":[{"extension_attributes":{},"value_index":0}]}],"downloadable_product_links":[{"extension_attributes":{},"id":0,"is_shareable":0,"link_file":"","link_file_content":{"extension_attributes":{},"file_data":"","name":""},"link_type":"","link_url":"","number_of_downloads":0,"price":"","sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"downloadable_product_samples":[{"extension_attributes":{},"id":0,"sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"giftcard_amounts":[{"attribute_id":0,"extension_attributes":{},"value":"","website_id":0,"website_value":""}],"stock_item":{"backorders":0,"enable_qty_increments":false,"extension_attributes":{},"is_decimal_divided":false,"is_in_stock":false,"is_qty_decimal":false,"item_id":0,"low_stock_date":"","manage_stock":false,"max_sale_qty":"","min_qty":"","min_sale_qty":"","notify_stock_qty":"","product_id":0,"qty":"","qty_increments":"","show_default_notification_message":false,"stock_id":0,"stock_status_changed_auto":0,"use_config_backorders":false,"use_config_enable_qty_inc":false,"use_config_manage_stock":false,"use_config_max_sale_qty":false,"use_config_min_qty":false,"use_config_min_sale_qty":0,"use_config_notify_stock_qty":false,"use_config_qty_increments":false},"website_ids":[]},"id":0,"media_gallery_entries":[{"content":{"base64_encoded_data":"","name":"","type":""},"disabled":false,"extension_attributes":{"video_content":{"media_type":"","video_description":"","video_metadata":"","video_provider":"","video_title":"","video_url":""}},"file":"","id":0,"label":"","media_type":"","position":0,"types":[]}],"name":"","options":[{"extension_attributes":{"vertex_flex_field":""},"file_extension":"","image_size_x":0,"image_size_y":0,"is_require":false,"max_characters":0,"option_id":0,"price":"","price_type":"","product_sku":"","sku":"","sort_order":0,"title":"","type":"","values":[{"option_type_id":0,"price":"","price_type":"","sku":"","sort_order":0,"title":""}]}],"price":"","product_links":[{"extension_attributes":{"qty":""},"link_type":"","linked_product_sku":"","linked_product_type":"","position":0,"sku":""}],"sku":"","status":0,"tier_prices":[{"customer_group_id":0,"extension_attributes":{"percentage_value":"","website_id":0},"qty":"","value":""}],"type_id":"","updated_at":"","visibility":0,"weight":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"products": @[ @{ @"attribute_set_id": @0, @"created_at": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"extension_attributes": @{ @"bundle_product_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @0, @"position": @0, @"product_links": @[ @{ @"can_change_quantity": @0, @"extension_attributes": @{  }, @"id": @"", @"is_default": @NO, @"option_id": @0, @"position": @0, @"price": @"", @"price_type": @0, @"qty": @"", @"sku": @"" } ], @"required": @NO, @"sku": @"", @"title": @"", @"type": @"" } ], @"category_links": @[ @{ @"category_id": @"", @"extension_attributes": @{  }, @"position": @0 } ], @"configurable_product_links": @[  ], @"configurable_product_options": @[ @{ @"attribute_id": @"", @"extension_attributes": @{  }, @"id": @0, @"is_use_default": @NO, @"label": @"", @"position": @0, @"product_id": @0, @"values": @[ @{ @"extension_attributes": @{  }, @"value_index": @0 } ] } ], @"downloadable_product_links": @[ @{ @"extension_attributes": @{  }, @"id": @0, @"is_shareable": @0, @"link_file": @"", @"link_file_content": @{ @"extension_attributes": @{  }, @"file_data": @"", @"name": @"" }, @"link_type": @"", @"link_url": @"", @"number_of_downloads": @0, @"price": @"", @"sample_file": @"", @"sample_file_content": @{  }, @"sample_type": @"", @"sample_url": @"", @"sort_order": @0, @"title": @"" } ], @"downloadable_product_samples": @[ @{ @"extension_attributes": @{  }, @"id": @0, @"sample_file": @"", @"sample_file_content": @{  }, @"sample_type": @"", @"sample_url": @"", @"sort_order": @0, @"title": @"" } ], @"giftcard_amounts": @[ @{ @"attribute_id": @0, @"extension_attributes": @{  }, @"value": @"", @"website_id": @0, @"website_value": @"" } ], @"stock_item": @{ @"backorders": @0, @"enable_qty_increments": @NO, @"extension_attributes": @{  }, @"is_decimal_divided": @NO, @"is_in_stock": @NO, @"is_qty_decimal": @NO, @"item_id": @0, @"low_stock_date": @"", @"manage_stock": @NO, @"max_sale_qty": @"", @"min_qty": @"", @"min_sale_qty": @"", @"notify_stock_qty": @"", @"product_id": @0, @"qty": @"", @"qty_increments": @"", @"show_default_notification_message": @NO, @"stock_id": @0, @"stock_status_changed_auto": @0, @"use_config_backorders": @NO, @"use_config_enable_qty_inc": @NO, @"use_config_manage_stock": @NO, @"use_config_max_sale_qty": @NO, @"use_config_min_qty": @NO, @"use_config_min_sale_qty": @0, @"use_config_notify_stock_qty": @NO, @"use_config_qty_increments": @NO }, @"website_ids": @[  ] }, @"id": @0, @"media_gallery_entries": @[ @{ @"content": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" }, @"disabled": @NO, @"extension_attributes": @{ @"video_content": @{ @"media_type": @"", @"video_description": @"", @"video_metadata": @"", @"video_provider": @"", @"video_title": @"", @"video_url": @"" } }, @"file": @"", @"id": @0, @"label": @"", @"media_type": @"", @"position": @0, @"types": @[  ] } ], @"name": @"", @"options": @[ @{ @"extension_attributes": @{ @"vertex_flex_field": @"" }, @"file_extension": @"", @"image_size_x": @0, @"image_size_y": @0, @"is_require": @NO, @"max_characters": @0, @"option_id": @0, @"price": @"", @"price_type": @"", @"product_sku": @"", @"sku": @"", @"sort_order": @0, @"title": @"", @"type": @"", @"values": @[ @{ @"option_type_id": @0, @"price": @"", @"price_type": @"", @"sku": @"", @"sort_order": @0, @"title": @"" } ] } ], @"price": @"", @"product_links": @[ @{ @"extension_attributes": @{ @"qty": @"" }, @"link_type": @"", @"linked_product_sku": @"", @"linked_product_type": @"", @"position": @0, @"sku": @"" } ], @"sku": @"", @"status": @0, @"tier_prices": @[ @{ @"customer_group_id": @0, @"extension_attributes": @{ @"percentage_value": @"", @"website_id": @0 }, @"qty": @"", @"value": @"" } ], @"type_id": @"", @"updated_at": @"", @"visibility": @0, @"weight": @"" } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/sharedCatalog/:id/assignProducts"]
                                                       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}}/V1/sharedCatalog/:id/assignProducts" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/sharedCatalog/:id/assignProducts",
  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([
    'products' => [
        [
                'attribute_set_id' => 0,
                'created_at' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'extension_attributes' => [
                                'bundle_product_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'option_id' => 0,
                                                                                                                                'position' => 0,
                                                                                                                                'product_links' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'can_change_quantity' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'is_default' => null,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'position' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'price_type' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'sku' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'required' => null,
                                                                                                                                'sku' => '',
                                                                                                                                'title' => '',
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'category_links' => [
                                                                [
                                                                                                                                'category_id' => '',
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'position' => 0
                                                                ]
                                ],
                                'configurable_product_links' => [
                                                                
                                ],
                                'configurable_product_options' => [
                                                                [
                                                                                                                                'attribute_id' => '',
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'is_use_default' => null,
                                                                                                                                'label' => '',
                                                                                                                                'position' => 0,
                                                                                                                                'product_id' => 0,
                                                                                                                                'values' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'value_index' => 0
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ]
                                ],
                                'downloadable_product_links' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'is_shareable' => 0,
                                                                                                                                'link_file' => '',
                                                                                                                                'link_file_content' => [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'file_data' => '',
                                                                                                                                                                                                                                                                'name' => ''
                                                                                                                                ],
                                                                                                                                'link_type' => '',
                                                                                                                                'link_url' => '',
                                                                                                                                'number_of_downloads' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'sample_file' => '',
                                                                                                                                'sample_file_content' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'sample_type' => '',
                                                                                                                                'sample_url' => '',
                                                                                                                                'sort_order' => 0,
                                                                                                                                'title' => ''
                                                                ]
                                ],
                                'downloadable_product_samples' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'sample_file' => '',
                                                                                                                                'sample_file_content' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'sample_type' => '',
                                                                                                                                'sample_url' => '',
                                                                                                                                'sort_order' => 0,
                                                                                                                                'title' => ''
                                                                ]
                                ],
                                'giftcard_amounts' => [
                                                                [
                                                                                                                                'attribute_id' => 0,
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'value' => '',
                                                                                                                                'website_id' => 0,
                                                                                                                                'website_value' => ''
                                                                ]
                                ],
                                'stock_item' => [
                                                                'backorders' => 0,
                                                                'enable_qty_increments' => null,
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'is_decimal_divided' => null,
                                                                'is_in_stock' => null,
                                                                'is_qty_decimal' => null,
                                                                'item_id' => 0,
                                                                'low_stock_date' => '',
                                                                'manage_stock' => null,
                                                                'max_sale_qty' => '',
                                                                'min_qty' => '',
                                                                'min_sale_qty' => '',
                                                                'notify_stock_qty' => '',
                                                                'product_id' => 0,
                                                                'qty' => '',
                                                                'qty_increments' => '',
                                                                'show_default_notification_message' => null,
                                                                'stock_id' => 0,
                                                                'stock_status_changed_auto' => 0,
                                                                'use_config_backorders' => null,
                                                                'use_config_enable_qty_inc' => null,
                                                                'use_config_manage_stock' => null,
                                                                'use_config_max_sale_qty' => null,
                                                                'use_config_min_qty' => null,
                                                                'use_config_min_sale_qty' => 0,
                                                                'use_config_notify_stock_qty' => null,
                                                                'use_config_qty_increments' => null
                                ],
                                'website_ids' => [
                                                                
                                ]
                ],
                'id' => 0,
                'media_gallery_entries' => [
                                [
                                                                'content' => [
                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                'name' => '',
                                                                                                                                'type' => ''
                                                                ],
                                                                'disabled' => null,
                                                                'extension_attributes' => [
                                                                                                                                'video_content' => [
                                                                                                                                                                                                                                                                'media_type' => '',
                                                                                                                                                                                                                                                                'video_description' => '',
                                                                                                                                                                                                                                                                'video_metadata' => '',
                                                                                                                                                                                                                                                                'video_provider' => '',
                                                                                                                                                                                                                                                                'video_title' => '',
                                                                                                                                                                                                                                                                'video_url' => ''
                                                                                                                                ]
                                                                ],
                                                                'file' => '',
                                                                'id' => 0,
                                                                'label' => '',
                                                                'media_type' => '',
                                                                'position' => 0,
                                                                'types' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'name' => '',
                'options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                'vertex_flex_field' => ''
                                                                ],
                                                                'file_extension' => '',
                                                                'image_size_x' => 0,
                                                                'image_size_y' => 0,
                                                                'is_require' => null,
                                                                'max_characters' => 0,
                                                                'option_id' => 0,
                                                                'price' => '',
                                                                'price_type' => '',
                                                                'product_sku' => '',
                                                                'sku' => '',
                                                                'sort_order' => 0,
                                                                'title' => '',
                                                                'type' => '',
                                                                'values' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'option_type_id' => 0,
                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                'price_type' => '',
                                                                                                                                                                                                                                                                'sku' => '',
                                                                                                                                                                                                                                                                'sort_order' => 0,
                                                                                                                                                                                                                                                                'title' => ''
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'price' => '',
                'product_links' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                'qty' => ''
                                                                ],
                                                                'link_type' => '',
                                                                'linked_product_sku' => '',
                                                                'linked_product_type' => '',
                                                                'position' => 0,
                                                                'sku' => ''
                                ]
                ],
                'sku' => '',
                'status' => 0,
                'tier_prices' => [
                                [
                                                                'customer_group_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                'percentage_value' => '',
                                                                                                                                'website_id' => 0
                                                                ],
                                                                'qty' => '',
                                                                'value' => ''
                                ]
                ],
                'type_id' => '',
                'updated_at' => '',
                'visibility' => 0,
                'weight' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/sharedCatalog/:id/assignProducts', [
  'body' => '{
  "products": [
    {
      "attribute_set_id": 0,
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {
        "bundle_product_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "position": 0,
            "product_links": [
              {
                "can_change_quantity": 0,
                "extension_attributes": {},
                "id": "",
                "is_default": false,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
              }
            ],
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
          }
        ],
        "category_links": [
          {
            "category_id": "",
            "extension_attributes": {},
            "position": 0
          }
        ],
        "configurable_product_links": [],
        "configurable_product_options": [
          {
            "attribute_id": "",
            "extension_attributes": {},
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": [
              {
                "extension_attributes": {},
                "value_index": 0
              }
            ]
          }
        ],
        "downloadable_product_links": [
          {
            "extension_attributes": {},
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": {
              "extension_attributes": {},
              "file_data": "",
              "name": ""
            },
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "downloadable_product_samples": [
          {
            "extension_attributes": {},
            "id": 0,
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "giftcard_amounts": [
          {
            "attribute_id": 0,
            "extension_attributes": {},
            "value": "",
            "website_id": 0,
            "website_value": ""
          }
        ],
        "stock_item": {
          "backorders": 0,
          "enable_qty_increments": false,
          "extension_attributes": {},
          "is_decimal_divided": false,
          "is_in_stock": false,
          "is_qty_decimal": false,
          "item_id": 0,
          "low_stock_date": "",
          "manage_stock": false,
          "max_sale_qty": "",
          "min_qty": "",
          "min_sale_qty": "",
          "notify_stock_qty": "",
          "product_id": 0,
          "qty": "",
          "qty_increments": "",
          "show_default_notification_message": false,
          "stock_id": 0,
          "stock_status_changed_auto": 0,
          "use_config_backorders": false,
          "use_config_enable_qty_inc": false,
          "use_config_manage_stock": false,
          "use_config_max_sale_qty": false,
          "use_config_min_qty": false,
          "use_config_min_sale_qty": 0,
          "use_config_notify_stock_qty": false,
          "use_config_qty_increments": false
        },
        "website_ids": []
      },
      "id": 0,
      "media_gallery_entries": [
        {
          "content": {
            "base64_encoded_data": "",
            "name": "",
            "type": ""
          },
          "disabled": false,
          "extension_attributes": {
            "video_content": {
              "media_type": "",
              "video_description": "",
              "video_metadata": "",
              "video_provider": "",
              "video_title": "",
              "video_url": ""
            }
          },
          "file": "",
          "id": 0,
          "label": "",
          "media_type": "",
          "position": 0,
          "types": []
        }
      ],
      "name": "",
      "options": [
        {
          "extension_attributes": {
            "vertex_flex_field": ""
          },
          "file_extension": "",
          "image_size_x": 0,
          "image_size_y": 0,
          "is_require": false,
          "max_characters": 0,
          "option_id": 0,
          "price": "",
          "price_type": "",
          "product_sku": "",
          "sku": "",
          "sort_order": 0,
          "title": "",
          "type": "",
          "values": [
            {
              "option_type_id": 0,
              "price": "",
              "price_type": "",
              "sku": "",
              "sort_order": 0,
              "title": ""
            }
          ]
        }
      ],
      "price": "",
      "product_links": [
        {
          "extension_attributes": {
            "qty": ""
          },
          "link_type": "",
          "linked_product_sku": "",
          "linked_product_type": "",
          "position": 0,
          "sku": ""
        }
      ],
      "sku": "",
      "status": 0,
      "tier_prices": [
        {
          "customer_group_id": 0,
          "extension_attributes": {
            "percentage_value": "",
            "website_id": 0
          },
          "qty": "",
          "value": ""
        }
      ],
      "type_id": "",
      "updated_at": "",
      "visibility": 0,
      "weight": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/sharedCatalog/:id/assignProducts');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'products' => [
    [
        'attribute_set_id' => 0,
        'created_at' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'extension_attributes' => [
                'bundle_product_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'position' => 0,
                                                                'product_links' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'can_change_quantity' => 0,
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'id' => '',
                                                                                                                                                                                                                                                                'is_default' => null,
                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                'position' => 0,
                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                'price_type' => 0,
                                                                                                                                                                                                                                                                'qty' => '',
                                                                                                                                                                                                                                                                'sku' => ''
                                                                                                                                ]
                                                                ],
                                                                'required' => null,
                                                                'sku' => '',
                                                                'title' => '',
                                                                'type' => ''
                                ]
                ],
                'category_links' => [
                                [
                                                                'category_id' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'position' => 0
                                ]
                ],
                'configurable_product_links' => [
                                
                ],
                'configurable_product_options' => [
                                [
                                                                'attribute_id' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'is_use_default' => null,
                                                                'label' => '',
                                                                'position' => 0,
                                                                'product_id' => 0,
                                                                'values' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'value_index' => 0
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'downloadable_product_links' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'is_shareable' => 0,
                                                                'link_file' => '',
                                                                'link_file_content' => [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'file_data' => '',
                                                                                                                                'name' => ''
                                                                ],
                                                                'link_type' => '',
                                                                'link_url' => '',
                                                                'number_of_downloads' => 0,
                                                                'price' => '',
                                                                'sample_file' => '',
                                                                'sample_file_content' => [
                                                                                                                                
                                                                ],
                                                                'sample_type' => '',
                                                                'sample_url' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ],
                'downloadable_product_samples' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'sample_file' => '',
                                                                'sample_file_content' => [
                                                                                                                                
                                                                ],
                                                                'sample_type' => '',
                                                                'sample_url' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ],
                'giftcard_amounts' => [
                                [
                                                                'attribute_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'value' => '',
                                                                'website_id' => 0,
                                                                'website_value' => ''
                                ]
                ],
                'stock_item' => [
                                'backorders' => 0,
                                'enable_qty_increments' => null,
                                'extension_attributes' => [
                                                                
                                ],
                                'is_decimal_divided' => null,
                                'is_in_stock' => null,
                                'is_qty_decimal' => null,
                                'item_id' => 0,
                                'low_stock_date' => '',
                                'manage_stock' => null,
                                'max_sale_qty' => '',
                                'min_qty' => '',
                                'min_sale_qty' => '',
                                'notify_stock_qty' => '',
                                'product_id' => 0,
                                'qty' => '',
                                'qty_increments' => '',
                                'show_default_notification_message' => null,
                                'stock_id' => 0,
                                'stock_status_changed_auto' => 0,
                                'use_config_backorders' => null,
                                'use_config_enable_qty_inc' => null,
                                'use_config_manage_stock' => null,
                                'use_config_max_sale_qty' => null,
                                'use_config_min_qty' => null,
                                'use_config_min_sale_qty' => 0,
                                'use_config_notify_stock_qty' => null,
                                'use_config_qty_increments' => null
                ],
                'website_ids' => [
                                
                ]
        ],
        'id' => 0,
        'media_gallery_entries' => [
                [
                                'content' => [
                                                                'base64_encoded_data' => '',
                                                                'name' => '',
                                                                'type' => ''
                                ],
                                'disabled' => null,
                                'extension_attributes' => [
                                                                'video_content' => [
                                                                                                                                'media_type' => '',
                                                                                                                                'video_description' => '',
                                                                                                                                'video_metadata' => '',
                                                                                                                                'video_provider' => '',
                                                                                                                                'video_title' => '',
                                                                                                                                'video_url' => ''
                                                                ]
                                ],
                                'file' => '',
                                'id' => 0,
                                'label' => '',
                                'media_type' => '',
                                'position' => 0,
                                'types' => [
                                                                
                                ]
                ]
        ],
        'name' => '',
        'options' => [
                [
                                'extension_attributes' => [
                                                                'vertex_flex_field' => ''
                                ],
                                'file_extension' => '',
                                'image_size_x' => 0,
                                'image_size_y' => 0,
                                'is_require' => null,
                                'max_characters' => 0,
                                'option_id' => 0,
                                'price' => '',
                                'price_type' => '',
                                'product_sku' => '',
                                'sku' => '',
                                'sort_order' => 0,
                                'title' => '',
                                'type' => '',
                                'values' => [
                                                                [
                                                                                                                                'option_type_id' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'price_type' => '',
                                                                                                                                'sku' => '',
                                                                                                                                'sort_order' => 0,
                                                                                                                                'title' => ''
                                                                ]
                                ]
                ]
        ],
        'price' => '',
        'product_links' => [
                [
                                'extension_attributes' => [
                                                                'qty' => ''
                                ],
                                'link_type' => '',
                                'linked_product_sku' => '',
                                'linked_product_type' => '',
                                'position' => 0,
                                'sku' => ''
                ]
        ],
        'sku' => '',
        'status' => 0,
        'tier_prices' => [
                [
                                'customer_group_id' => 0,
                                'extension_attributes' => [
                                                                'percentage_value' => '',
                                                                'website_id' => 0
                                ],
                                'qty' => '',
                                'value' => ''
                ]
        ],
        'type_id' => '',
        'updated_at' => '',
        'visibility' => 0,
        'weight' => ''
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'products' => [
    [
        'attribute_set_id' => 0,
        'created_at' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'extension_attributes' => [
                'bundle_product_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'position' => 0,
                                                                'product_links' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'can_change_quantity' => 0,
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'id' => '',
                                                                                                                                                                                                                                                                'is_default' => null,
                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                'position' => 0,
                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                'price_type' => 0,
                                                                                                                                                                                                                                                                'qty' => '',
                                                                                                                                                                                                                                                                'sku' => ''
                                                                                                                                ]
                                                                ],
                                                                'required' => null,
                                                                'sku' => '',
                                                                'title' => '',
                                                                'type' => ''
                                ]
                ],
                'category_links' => [
                                [
                                                                'category_id' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'position' => 0
                                ]
                ],
                'configurable_product_links' => [
                                
                ],
                'configurable_product_options' => [
                                [
                                                                'attribute_id' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'is_use_default' => null,
                                                                'label' => '',
                                                                'position' => 0,
                                                                'product_id' => 0,
                                                                'values' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'value_index' => 0
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'downloadable_product_links' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'is_shareable' => 0,
                                                                'link_file' => '',
                                                                'link_file_content' => [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'file_data' => '',
                                                                                                                                'name' => ''
                                                                ],
                                                                'link_type' => '',
                                                                'link_url' => '',
                                                                'number_of_downloads' => 0,
                                                                'price' => '',
                                                                'sample_file' => '',
                                                                'sample_file_content' => [
                                                                                                                                
                                                                ],
                                                                'sample_type' => '',
                                                                'sample_url' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ],
                'downloadable_product_samples' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'sample_file' => '',
                                                                'sample_file_content' => [
                                                                                                                                
                                                                ],
                                                                'sample_type' => '',
                                                                'sample_url' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ],
                'giftcard_amounts' => [
                                [
                                                                'attribute_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'value' => '',
                                                                'website_id' => 0,
                                                                'website_value' => ''
                                ]
                ],
                'stock_item' => [
                                'backorders' => 0,
                                'enable_qty_increments' => null,
                                'extension_attributes' => [
                                                                
                                ],
                                'is_decimal_divided' => null,
                                'is_in_stock' => null,
                                'is_qty_decimal' => null,
                                'item_id' => 0,
                                'low_stock_date' => '',
                                'manage_stock' => null,
                                'max_sale_qty' => '',
                                'min_qty' => '',
                                'min_sale_qty' => '',
                                'notify_stock_qty' => '',
                                'product_id' => 0,
                                'qty' => '',
                                'qty_increments' => '',
                                'show_default_notification_message' => null,
                                'stock_id' => 0,
                                'stock_status_changed_auto' => 0,
                                'use_config_backorders' => null,
                                'use_config_enable_qty_inc' => null,
                                'use_config_manage_stock' => null,
                                'use_config_max_sale_qty' => null,
                                'use_config_min_qty' => null,
                                'use_config_min_sale_qty' => 0,
                                'use_config_notify_stock_qty' => null,
                                'use_config_qty_increments' => null
                ],
                'website_ids' => [
                                
                ]
        ],
        'id' => 0,
        'media_gallery_entries' => [
                [
                                'content' => [
                                                                'base64_encoded_data' => '',
                                                                'name' => '',
                                                                'type' => ''
                                ],
                                'disabled' => null,
                                'extension_attributes' => [
                                                                'video_content' => [
                                                                                                                                'media_type' => '',
                                                                                                                                'video_description' => '',
                                                                                                                                'video_metadata' => '',
                                                                                                                                'video_provider' => '',
                                                                                                                                'video_title' => '',
                                                                                                                                'video_url' => ''
                                                                ]
                                ],
                                'file' => '',
                                'id' => 0,
                                'label' => '',
                                'media_type' => '',
                                'position' => 0,
                                'types' => [
                                                                
                                ]
                ]
        ],
        'name' => '',
        'options' => [
                [
                                'extension_attributes' => [
                                                                'vertex_flex_field' => ''
                                ],
                                'file_extension' => '',
                                'image_size_x' => 0,
                                'image_size_y' => 0,
                                'is_require' => null,
                                'max_characters' => 0,
                                'option_id' => 0,
                                'price' => '',
                                'price_type' => '',
                                'product_sku' => '',
                                'sku' => '',
                                'sort_order' => 0,
                                'title' => '',
                                'type' => '',
                                'values' => [
                                                                [
                                                                                                                                'option_type_id' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'price_type' => '',
                                                                                                                                'sku' => '',
                                                                                                                                'sort_order' => 0,
                                                                                                                                'title' => ''
                                                                ]
                                ]
                ]
        ],
        'price' => '',
        'product_links' => [
                [
                                'extension_attributes' => [
                                                                'qty' => ''
                                ],
                                'link_type' => '',
                                'linked_product_sku' => '',
                                'linked_product_type' => '',
                                'position' => 0,
                                'sku' => ''
                ]
        ],
        'sku' => '',
        'status' => 0,
        'tier_prices' => [
                [
                                'customer_group_id' => 0,
                                'extension_attributes' => [
                                                                'percentage_value' => '',
                                                                'website_id' => 0
                                ],
                                'qty' => '',
                                'value' => ''
                ]
        ],
        'type_id' => '',
        'updated_at' => '',
        'visibility' => 0,
        'weight' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/sharedCatalog/:id/assignProducts');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/sharedCatalog/:id/assignProducts' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "products": [
    {
      "attribute_set_id": 0,
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {
        "bundle_product_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "position": 0,
            "product_links": [
              {
                "can_change_quantity": 0,
                "extension_attributes": {},
                "id": "",
                "is_default": false,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
              }
            ],
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
          }
        ],
        "category_links": [
          {
            "category_id": "",
            "extension_attributes": {},
            "position": 0
          }
        ],
        "configurable_product_links": [],
        "configurable_product_options": [
          {
            "attribute_id": "",
            "extension_attributes": {},
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": [
              {
                "extension_attributes": {},
                "value_index": 0
              }
            ]
          }
        ],
        "downloadable_product_links": [
          {
            "extension_attributes": {},
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": {
              "extension_attributes": {},
              "file_data": "",
              "name": ""
            },
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "downloadable_product_samples": [
          {
            "extension_attributes": {},
            "id": 0,
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "giftcard_amounts": [
          {
            "attribute_id": 0,
            "extension_attributes": {},
            "value": "",
            "website_id": 0,
            "website_value": ""
          }
        ],
        "stock_item": {
          "backorders": 0,
          "enable_qty_increments": false,
          "extension_attributes": {},
          "is_decimal_divided": false,
          "is_in_stock": false,
          "is_qty_decimal": false,
          "item_id": 0,
          "low_stock_date": "",
          "manage_stock": false,
          "max_sale_qty": "",
          "min_qty": "",
          "min_sale_qty": "",
          "notify_stock_qty": "",
          "product_id": 0,
          "qty": "",
          "qty_increments": "",
          "show_default_notification_message": false,
          "stock_id": 0,
          "stock_status_changed_auto": 0,
          "use_config_backorders": false,
          "use_config_enable_qty_inc": false,
          "use_config_manage_stock": false,
          "use_config_max_sale_qty": false,
          "use_config_min_qty": false,
          "use_config_min_sale_qty": 0,
          "use_config_notify_stock_qty": false,
          "use_config_qty_increments": false
        },
        "website_ids": []
      },
      "id": 0,
      "media_gallery_entries": [
        {
          "content": {
            "base64_encoded_data": "",
            "name": "",
            "type": ""
          },
          "disabled": false,
          "extension_attributes": {
            "video_content": {
              "media_type": "",
              "video_description": "",
              "video_metadata": "",
              "video_provider": "",
              "video_title": "",
              "video_url": ""
            }
          },
          "file": "",
          "id": 0,
          "label": "",
          "media_type": "",
          "position": 0,
          "types": []
        }
      ],
      "name": "",
      "options": [
        {
          "extension_attributes": {
            "vertex_flex_field": ""
          },
          "file_extension": "",
          "image_size_x": 0,
          "image_size_y": 0,
          "is_require": false,
          "max_characters": 0,
          "option_id": 0,
          "price": "",
          "price_type": "",
          "product_sku": "",
          "sku": "",
          "sort_order": 0,
          "title": "",
          "type": "",
          "values": [
            {
              "option_type_id": 0,
              "price": "",
              "price_type": "",
              "sku": "",
              "sort_order": 0,
              "title": ""
            }
          ]
        }
      ],
      "price": "",
      "product_links": [
        {
          "extension_attributes": {
            "qty": ""
          },
          "link_type": "",
          "linked_product_sku": "",
          "linked_product_type": "",
          "position": 0,
          "sku": ""
        }
      ],
      "sku": "",
      "status": 0,
      "tier_prices": [
        {
          "customer_group_id": 0,
          "extension_attributes": {
            "percentage_value": "",
            "website_id": 0
          },
          "qty": "",
          "value": ""
        }
      ],
      "type_id": "",
      "updated_at": "",
      "visibility": 0,
      "weight": ""
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/sharedCatalog/:id/assignProducts' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "products": [
    {
      "attribute_set_id": 0,
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {
        "bundle_product_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "position": 0,
            "product_links": [
              {
                "can_change_quantity": 0,
                "extension_attributes": {},
                "id": "",
                "is_default": false,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
              }
            ],
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
          }
        ],
        "category_links": [
          {
            "category_id": "",
            "extension_attributes": {},
            "position": 0
          }
        ],
        "configurable_product_links": [],
        "configurable_product_options": [
          {
            "attribute_id": "",
            "extension_attributes": {},
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": [
              {
                "extension_attributes": {},
                "value_index": 0
              }
            ]
          }
        ],
        "downloadable_product_links": [
          {
            "extension_attributes": {},
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": {
              "extension_attributes": {},
              "file_data": "",
              "name": ""
            },
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "downloadable_product_samples": [
          {
            "extension_attributes": {},
            "id": 0,
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "giftcard_amounts": [
          {
            "attribute_id": 0,
            "extension_attributes": {},
            "value": "",
            "website_id": 0,
            "website_value": ""
          }
        ],
        "stock_item": {
          "backorders": 0,
          "enable_qty_increments": false,
          "extension_attributes": {},
          "is_decimal_divided": false,
          "is_in_stock": false,
          "is_qty_decimal": false,
          "item_id": 0,
          "low_stock_date": "",
          "manage_stock": false,
          "max_sale_qty": "",
          "min_qty": "",
          "min_sale_qty": "",
          "notify_stock_qty": "",
          "product_id": 0,
          "qty": "",
          "qty_increments": "",
          "show_default_notification_message": false,
          "stock_id": 0,
          "stock_status_changed_auto": 0,
          "use_config_backorders": false,
          "use_config_enable_qty_inc": false,
          "use_config_manage_stock": false,
          "use_config_max_sale_qty": false,
          "use_config_min_qty": false,
          "use_config_min_sale_qty": 0,
          "use_config_notify_stock_qty": false,
          "use_config_qty_increments": false
        },
        "website_ids": []
      },
      "id": 0,
      "media_gallery_entries": [
        {
          "content": {
            "base64_encoded_data": "",
            "name": "",
            "type": ""
          },
          "disabled": false,
          "extension_attributes": {
            "video_content": {
              "media_type": "",
              "video_description": "",
              "video_metadata": "",
              "video_provider": "",
              "video_title": "",
              "video_url": ""
            }
          },
          "file": "",
          "id": 0,
          "label": "",
          "media_type": "",
          "position": 0,
          "types": []
        }
      ],
      "name": "",
      "options": [
        {
          "extension_attributes": {
            "vertex_flex_field": ""
          },
          "file_extension": "",
          "image_size_x": 0,
          "image_size_y": 0,
          "is_require": false,
          "max_characters": 0,
          "option_id": 0,
          "price": "",
          "price_type": "",
          "product_sku": "",
          "sku": "",
          "sort_order": 0,
          "title": "",
          "type": "",
          "values": [
            {
              "option_type_id": 0,
              "price": "",
              "price_type": "",
              "sku": "",
              "sort_order": 0,
              "title": ""
            }
          ]
        }
      ],
      "price": "",
      "product_links": [
        {
          "extension_attributes": {
            "qty": ""
          },
          "link_type": "",
          "linked_product_sku": "",
          "linked_product_type": "",
          "position": 0,
          "sku": ""
        }
      ],
      "sku": "",
      "status": 0,
      "tier_prices": [
        {
          "customer_group_id": 0,
          "extension_attributes": {
            "percentage_value": "",
            "website_id": 0
          },
          "qty": "",
          "value": ""
        }
      ],
      "type_id": "",
      "updated_at": "",
      "visibility": 0,
      "weight": ""
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/sharedCatalog/:id/assignProducts", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/sharedCatalog/:id/assignProducts"

payload = { "products": [
        {
            "attribute_set_id": 0,
            "created_at": "",
            "custom_attributes": [
                {
                    "attribute_code": "",
                    "value": ""
                }
            ],
            "extension_attributes": {
                "bundle_product_options": [
                    {
                        "extension_attributes": {},
                        "option_id": 0,
                        "position": 0,
                        "product_links": [
                            {
                                "can_change_quantity": 0,
                                "extension_attributes": {},
                                "id": "",
                                "is_default": False,
                                "option_id": 0,
                                "position": 0,
                                "price": "",
                                "price_type": 0,
                                "qty": "",
                                "sku": ""
                            }
                        ],
                        "required": False,
                        "sku": "",
                        "title": "",
                        "type": ""
                    }
                ],
                "category_links": [
                    {
                        "category_id": "",
                        "extension_attributes": {},
                        "position": 0
                    }
                ],
                "configurable_product_links": [],
                "configurable_product_options": [
                    {
                        "attribute_id": "",
                        "extension_attributes": {},
                        "id": 0,
                        "is_use_default": False,
                        "label": "",
                        "position": 0,
                        "product_id": 0,
                        "values": [
                            {
                                "extension_attributes": {},
                                "value_index": 0
                            }
                        ]
                    }
                ],
                "downloadable_product_links": [
                    {
                        "extension_attributes": {},
                        "id": 0,
                        "is_shareable": 0,
                        "link_file": "",
                        "link_file_content": {
                            "extension_attributes": {},
                            "file_data": "",
                            "name": ""
                        },
                        "link_type": "",
                        "link_url": "",
                        "number_of_downloads": 0,
                        "price": "",
                        "sample_file": "",
                        "sample_file_content": {},
                        "sample_type": "",
                        "sample_url": "",
                        "sort_order": 0,
                        "title": ""
                    }
                ],
                "downloadable_product_samples": [
                    {
                        "extension_attributes": {},
                        "id": 0,
                        "sample_file": "",
                        "sample_file_content": {},
                        "sample_type": "",
                        "sample_url": "",
                        "sort_order": 0,
                        "title": ""
                    }
                ],
                "giftcard_amounts": [
                    {
                        "attribute_id": 0,
                        "extension_attributes": {},
                        "value": "",
                        "website_id": 0,
                        "website_value": ""
                    }
                ],
                "stock_item": {
                    "backorders": 0,
                    "enable_qty_increments": False,
                    "extension_attributes": {},
                    "is_decimal_divided": False,
                    "is_in_stock": False,
                    "is_qty_decimal": False,
                    "item_id": 0,
                    "low_stock_date": "",
                    "manage_stock": False,
                    "max_sale_qty": "",
                    "min_qty": "",
                    "min_sale_qty": "",
                    "notify_stock_qty": "",
                    "product_id": 0,
                    "qty": "",
                    "qty_increments": "",
                    "show_default_notification_message": False,
                    "stock_id": 0,
                    "stock_status_changed_auto": 0,
                    "use_config_backorders": False,
                    "use_config_enable_qty_inc": False,
                    "use_config_manage_stock": False,
                    "use_config_max_sale_qty": False,
                    "use_config_min_qty": False,
                    "use_config_min_sale_qty": 0,
                    "use_config_notify_stock_qty": False,
                    "use_config_qty_increments": False
                },
                "website_ids": []
            },
            "id": 0,
            "media_gallery_entries": [
                {
                    "content": {
                        "base64_encoded_data": "",
                        "name": "",
                        "type": ""
                    },
                    "disabled": False,
                    "extension_attributes": { "video_content": {
                            "media_type": "",
                            "video_description": "",
                            "video_metadata": "",
                            "video_provider": "",
                            "video_title": "",
                            "video_url": ""
                        } },
                    "file": "",
                    "id": 0,
                    "label": "",
                    "media_type": "",
                    "position": 0,
                    "types": []
                }
            ],
            "name": "",
            "options": [
                {
                    "extension_attributes": { "vertex_flex_field": "" },
                    "file_extension": "",
                    "image_size_x": 0,
                    "image_size_y": 0,
                    "is_require": False,
                    "max_characters": 0,
                    "option_id": 0,
                    "price": "",
                    "price_type": "",
                    "product_sku": "",
                    "sku": "",
                    "sort_order": 0,
                    "title": "",
                    "type": "",
                    "values": [
                        {
                            "option_type_id": 0,
                            "price": "",
                            "price_type": "",
                            "sku": "",
                            "sort_order": 0,
                            "title": ""
                        }
                    ]
                }
            ],
            "price": "",
            "product_links": [
                {
                    "extension_attributes": { "qty": "" },
                    "link_type": "",
                    "linked_product_sku": "",
                    "linked_product_type": "",
                    "position": 0,
                    "sku": ""
                }
            ],
            "sku": "",
            "status": 0,
            "tier_prices": [
                {
                    "customer_group_id": 0,
                    "extension_attributes": {
                        "percentage_value": "",
                        "website_id": 0
                    },
                    "qty": "",
                    "value": ""
                }
            ],
            "type_id": "",
            "updated_at": "",
            "visibility": 0,
            "weight": ""
        }
    ] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/sharedCatalog/:id/assignProducts"

payload <- "{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/sharedCatalog/:id/assignProducts")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\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/V1/sharedCatalog/:id/assignProducts') do |req|
  req.body = "{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\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}}/V1/sharedCatalog/:id/assignProducts";

    let payload = json!({"products": (
            json!({
                "attribute_set_id": 0,
                "created_at": "",
                "custom_attributes": (
                    json!({
                        "attribute_code": "",
                        "value": ""
                    })
                ),
                "extension_attributes": json!({
                    "bundle_product_options": (
                        json!({
                            "extension_attributes": json!({}),
                            "option_id": 0,
                            "position": 0,
                            "product_links": (
                                json!({
                                    "can_change_quantity": 0,
                                    "extension_attributes": json!({}),
                                    "id": "",
                                    "is_default": false,
                                    "option_id": 0,
                                    "position": 0,
                                    "price": "",
                                    "price_type": 0,
                                    "qty": "",
                                    "sku": ""
                                })
                            ),
                            "required": false,
                            "sku": "",
                            "title": "",
                            "type": ""
                        })
                    ),
                    "category_links": (
                        json!({
                            "category_id": "",
                            "extension_attributes": json!({}),
                            "position": 0
                        })
                    ),
                    "configurable_product_links": (),
                    "configurable_product_options": (
                        json!({
                            "attribute_id": "",
                            "extension_attributes": json!({}),
                            "id": 0,
                            "is_use_default": false,
                            "label": "",
                            "position": 0,
                            "product_id": 0,
                            "values": (
                                json!({
                                    "extension_attributes": json!({}),
                                    "value_index": 0
                                })
                            )
                        })
                    ),
                    "downloadable_product_links": (
                        json!({
                            "extension_attributes": json!({}),
                            "id": 0,
                            "is_shareable": 0,
                            "link_file": "",
                            "link_file_content": json!({
                                "extension_attributes": json!({}),
                                "file_data": "",
                                "name": ""
                            }),
                            "link_type": "",
                            "link_url": "",
                            "number_of_downloads": 0,
                            "price": "",
                            "sample_file": "",
                            "sample_file_content": json!({}),
                            "sample_type": "",
                            "sample_url": "",
                            "sort_order": 0,
                            "title": ""
                        })
                    ),
                    "downloadable_product_samples": (
                        json!({
                            "extension_attributes": json!({}),
                            "id": 0,
                            "sample_file": "",
                            "sample_file_content": json!({}),
                            "sample_type": "",
                            "sample_url": "",
                            "sort_order": 0,
                            "title": ""
                        })
                    ),
                    "giftcard_amounts": (
                        json!({
                            "attribute_id": 0,
                            "extension_attributes": json!({}),
                            "value": "",
                            "website_id": 0,
                            "website_value": ""
                        })
                    ),
                    "stock_item": json!({
                        "backorders": 0,
                        "enable_qty_increments": false,
                        "extension_attributes": json!({}),
                        "is_decimal_divided": false,
                        "is_in_stock": false,
                        "is_qty_decimal": false,
                        "item_id": 0,
                        "low_stock_date": "",
                        "manage_stock": false,
                        "max_sale_qty": "",
                        "min_qty": "",
                        "min_sale_qty": "",
                        "notify_stock_qty": "",
                        "product_id": 0,
                        "qty": "",
                        "qty_increments": "",
                        "show_default_notification_message": false,
                        "stock_id": 0,
                        "stock_status_changed_auto": 0,
                        "use_config_backorders": false,
                        "use_config_enable_qty_inc": false,
                        "use_config_manage_stock": false,
                        "use_config_max_sale_qty": false,
                        "use_config_min_qty": false,
                        "use_config_min_sale_qty": 0,
                        "use_config_notify_stock_qty": false,
                        "use_config_qty_increments": false
                    }),
                    "website_ids": ()
                }),
                "id": 0,
                "media_gallery_entries": (
                    json!({
                        "content": json!({
                            "base64_encoded_data": "",
                            "name": "",
                            "type": ""
                        }),
                        "disabled": false,
                        "extension_attributes": json!({"video_content": json!({
                                "media_type": "",
                                "video_description": "",
                                "video_metadata": "",
                                "video_provider": "",
                                "video_title": "",
                                "video_url": ""
                            })}),
                        "file": "",
                        "id": 0,
                        "label": "",
                        "media_type": "",
                        "position": 0,
                        "types": ()
                    })
                ),
                "name": "",
                "options": (
                    json!({
                        "extension_attributes": json!({"vertex_flex_field": ""}),
                        "file_extension": "",
                        "image_size_x": 0,
                        "image_size_y": 0,
                        "is_require": false,
                        "max_characters": 0,
                        "option_id": 0,
                        "price": "",
                        "price_type": "",
                        "product_sku": "",
                        "sku": "",
                        "sort_order": 0,
                        "title": "",
                        "type": "",
                        "values": (
                            json!({
                                "option_type_id": 0,
                                "price": "",
                                "price_type": "",
                                "sku": "",
                                "sort_order": 0,
                                "title": ""
                            })
                        )
                    })
                ),
                "price": "",
                "product_links": (
                    json!({
                        "extension_attributes": json!({"qty": ""}),
                        "link_type": "",
                        "linked_product_sku": "",
                        "linked_product_type": "",
                        "position": 0,
                        "sku": ""
                    })
                ),
                "sku": "",
                "status": 0,
                "tier_prices": (
                    json!({
                        "customer_group_id": 0,
                        "extension_attributes": json!({
                            "percentage_value": "",
                            "website_id": 0
                        }),
                        "qty": "",
                        "value": ""
                    })
                ),
                "type_id": "",
                "updated_at": "",
                "visibility": 0,
                "weight": ""
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/sharedCatalog/:id/assignProducts \
  --header 'content-type: application/json' \
  --data '{
  "products": [
    {
      "attribute_set_id": 0,
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {
        "bundle_product_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "position": 0,
            "product_links": [
              {
                "can_change_quantity": 0,
                "extension_attributes": {},
                "id": "",
                "is_default": false,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
              }
            ],
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
          }
        ],
        "category_links": [
          {
            "category_id": "",
            "extension_attributes": {},
            "position": 0
          }
        ],
        "configurable_product_links": [],
        "configurable_product_options": [
          {
            "attribute_id": "",
            "extension_attributes": {},
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": [
              {
                "extension_attributes": {},
                "value_index": 0
              }
            ]
          }
        ],
        "downloadable_product_links": [
          {
            "extension_attributes": {},
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": {
              "extension_attributes": {},
              "file_data": "",
              "name": ""
            },
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "downloadable_product_samples": [
          {
            "extension_attributes": {},
            "id": 0,
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "giftcard_amounts": [
          {
            "attribute_id": 0,
            "extension_attributes": {},
            "value": "",
            "website_id": 0,
            "website_value": ""
          }
        ],
        "stock_item": {
          "backorders": 0,
          "enable_qty_increments": false,
          "extension_attributes": {},
          "is_decimal_divided": false,
          "is_in_stock": false,
          "is_qty_decimal": false,
          "item_id": 0,
          "low_stock_date": "",
          "manage_stock": false,
          "max_sale_qty": "",
          "min_qty": "",
          "min_sale_qty": "",
          "notify_stock_qty": "",
          "product_id": 0,
          "qty": "",
          "qty_increments": "",
          "show_default_notification_message": false,
          "stock_id": 0,
          "stock_status_changed_auto": 0,
          "use_config_backorders": false,
          "use_config_enable_qty_inc": false,
          "use_config_manage_stock": false,
          "use_config_max_sale_qty": false,
          "use_config_min_qty": false,
          "use_config_min_sale_qty": 0,
          "use_config_notify_stock_qty": false,
          "use_config_qty_increments": false
        },
        "website_ids": []
      },
      "id": 0,
      "media_gallery_entries": [
        {
          "content": {
            "base64_encoded_data": "",
            "name": "",
            "type": ""
          },
          "disabled": false,
          "extension_attributes": {
            "video_content": {
              "media_type": "",
              "video_description": "",
              "video_metadata": "",
              "video_provider": "",
              "video_title": "",
              "video_url": ""
            }
          },
          "file": "",
          "id": 0,
          "label": "",
          "media_type": "",
          "position": 0,
          "types": []
        }
      ],
      "name": "",
      "options": [
        {
          "extension_attributes": {
            "vertex_flex_field": ""
          },
          "file_extension": "",
          "image_size_x": 0,
          "image_size_y": 0,
          "is_require": false,
          "max_characters": 0,
          "option_id": 0,
          "price": "",
          "price_type": "",
          "product_sku": "",
          "sku": "",
          "sort_order": 0,
          "title": "",
          "type": "",
          "values": [
            {
              "option_type_id": 0,
              "price": "",
              "price_type": "",
              "sku": "",
              "sort_order": 0,
              "title": ""
            }
          ]
        }
      ],
      "price": "",
      "product_links": [
        {
          "extension_attributes": {
            "qty": ""
          },
          "link_type": "",
          "linked_product_sku": "",
          "linked_product_type": "",
          "position": 0,
          "sku": ""
        }
      ],
      "sku": "",
      "status": 0,
      "tier_prices": [
        {
          "customer_group_id": 0,
          "extension_attributes": {
            "percentage_value": "",
            "website_id": 0
          },
          "qty": "",
          "value": ""
        }
      ],
      "type_id": "",
      "updated_at": "",
      "visibility": 0,
      "weight": ""
    }
  ]
}'
echo '{
  "products": [
    {
      "attribute_set_id": 0,
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {
        "bundle_product_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "position": 0,
            "product_links": [
              {
                "can_change_quantity": 0,
                "extension_attributes": {},
                "id": "",
                "is_default": false,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
              }
            ],
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
          }
        ],
        "category_links": [
          {
            "category_id": "",
            "extension_attributes": {},
            "position": 0
          }
        ],
        "configurable_product_links": [],
        "configurable_product_options": [
          {
            "attribute_id": "",
            "extension_attributes": {},
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": [
              {
                "extension_attributes": {},
                "value_index": 0
              }
            ]
          }
        ],
        "downloadable_product_links": [
          {
            "extension_attributes": {},
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": {
              "extension_attributes": {},
              "file_data": "",
              "name": ""
            },
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "downloadable_product_samples": [
          {
            "extension_attributes": {},
            "id": 0,
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "giftcard_amounts": [
          {
            "attribute_id": 0,
            "extension_attributes": {},
            "value": "",
            "website_id": 0,
            "website_value": ""
          }
        ],
        "stock_item": {
          "backorders": 0,
          "enable_qty_increments": false,
          "extension_attributes": {},
          "is_decimal_divided": false,
          "is_in_stock": false,
          "is_qty_decimal": false,
          "item_id": 0,
          "low_stock_date": "",
          "manage_stock": false,
          "max_sale_qty": "",
          "min_qty": "",
          "min_sale_qty": "",
          "notify_stock_qty": "",
          "product_id": 0,
          "qty": "",
          "qty_increments": "",
          "show_default_notification_message": false,
          "stock_id": 0,
          "stock_status_changed_auto": 0,
          "use_config_backorders": false,
          "use_config_enable_qty_inc": false,
          "use_config_manage_stock": false,
          "use_config_max_sale_qty": false,
          "use_config_min_qty": false,
          "use_config_min_sale_qty": 0,
          "use_config_notify_stock_qty": false,
          "use_config_qty_increments": false
        },
        "website_ids": []
      },
      "id": 0,
      "media_gallery_entries": [
        {
          "content": {
            "base64_encoded_data": "",
            "name": "",
            "type": ""
          },
          "disabled": false,
          "extension_attributes": {
            "video_content": {
              "media_type": "",
              "video_description": "",
              "video_metadata": "",
              "video_provider": "",
              "video_title": "",
              "video_url": ""
            }
          },
          "file": "",
          "id": 0,
          "label": "",
          "media_type": "",
          "position": 0,
          "types": []
        }
      ],
      "name": "",
      "options": [
        {
          "extension_attributes": {
            "vertex_flex_field": ""
          },
          "file_extension": "",
          "image_size_x": 0,
          "image_size_y": 0,
          "is_require": false,
          "max_characters": 0,
          "option_id": 0,
          "price": "",
          "price_type": "",
          "product_sku": "",
          "sku": "",
          "sort_order": 0,
          "title": "",
          "type": "",
          "values": [
            {
              "option_type_id": 0,
              "price": "",
              "price_type": "",
              "sku": "",
              "sort_order": 0,
              "title": ""
            }
          ]
        }
      ],
      "price": "",
      "product_links": [
        {
          "extension_attributes": {
            "qty": ""
          },
          "link_type": "",
          "linked_product_sku": "",
          "linked_product_type": "",
          "position": 0,
          "sku": ""
        }
      ],
      "sku": "",
      "status": 0,
      "tier_prices": [
        {
          "customer_group_id": 0,
          "extension_attributes": {
            "percentage_value": "",
            "website_id": 0
          },
          "qty": "",
          "value": ""
        }
      ],
      "type_id": "",
      "updated_at": "",
      "visibility": 0,
      "weight": ""
    }
  ]
}' |  \
  http POST {{baseUrl}}/V1/sharedCatalog/:id/assignProducts \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "products": [\n    {\n      "attribute_set_id": 0,\n      "created_at": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "extension_attributes": {\n        "bundle_product_options": [\n          {\n            "extension_attributes": {},\n            "option_id": 0,\n            "position": 0,\n            "product_links": [\n              {\n                "can_change_quantity": 0,\n                "extension_attributes": {},\n                "id": "",\n                "is_default": false,\n                "option_id": 0,\n                "position": 0,\n                "price": "",\n                "price_type": 0,\n                "qty": "",\n                "sku": ""\n              }\n            ],\n            "required": false,\n            "sku": "",\n            "title": "",\n            "type": ""\n          }\n        ],\n        "category_links": [\n          {\n            "category_id": "",\n            "extension_attributes": {},\n            "position": 0\n          }\n        ],\n        "configurable_product_links": [],\n        "configurable_product_options": [\n          {\n            "attribute_id": "",\n            "extension_attributes": {},\n            "id": 0,\n            "is_use_default": false,\n            "label": "",\n            "position": 0,\n            "product_id": 0,\n            "values": [\n              {\n                "extension_attributes": {},\n                "value_index": 0\n              }\n            ]\n          }\n        ],\n        "downloadable_product_links": [\n          {\n            "extension_attributes": {},\n            "id": 0,\n            "is_shareable": 0,\n            "link_file": "",\n            "link_file_content": {\n              "extension_attributes": {},\n              "file_data": "",\n              "name": ""\n            },\n            "link_type": "",\n            "link_url": "",\n            "number_of_downloads": 0,\n            "price": "",\n            "sample_file": "",\n            "sample_file_content": {},\n            "sample_type": "",\n            "sample_url": "",\n            "sort_order": 0,\n            "title": ""\n          }\n        ],\n        "downloadable_product_samples": [\n          {\n            "extension_attributes": {},\n            "id": 0,\n            "sample_file": "",\n            "sample_file_content": {},\n            "sample_type": "",\n            "sample_url": "",\n            "sort_order": 0,\n            "title": ""\n          }\n        ],\n        "giftcard_amounts": [\n          {\n            "attribute_id": 0,\n            "extension_attributes": {},\n            "value": "",\n            "website_id": 0,\n            "website_value": ""\n          }\n        ],\n        "stock_item": {\n          "backorders": 0,\n          "enable_qty_increments": false,\n          "extension_attributes": {},\n          "is_decimal_divided": false,\n          "is_in_stock": false,\n          "is_qty_decimal": false,\n          "item_id": 0,\n          "low_stock_date": "",\n          "manage_stock": false,\n          "max_sale_qty": "",\n          "min_qty": "",\n          "min_sale_qty": "",\n          "notify_stock_qty": "",\n          "product_id": 0,\n          "qty": "",\n          "qty_increments": "",\n          "show_default_notification_message": false,\n          "stock_id": 0,\n          "stock_status_changed_auto": 0,\n          "use_config_backorders": false,\n          "use_config_enable_qty_inc": false,\n          "use_config_manage_stock": false,\n          "use_config_max_sale_qty": false,\n          "use_config_min_qty": false,\n          "use_config_min_sale_qty": 0,\n          "use_config_notify_stock_qty": false,\n          "use_config_qty_increments": false\n        },\n        "website_ids": []\n      },\n      "id": 0,\n      "media_gallery_entries": [\n        {\n          "content": {\n            "base64_encoded_data": "",\n            "name": "",\n            "type": ""\n          },\n          "disabled": false,\n          "extension_attributes": {\n            "video_content": {\n              "media_type": "",\n              "video_description": "",\n              "video_metadata": "",\n              "video_provider": "",\n              "video_title": "",\n              "video_url": ""\n            }\n          },\n          "file": "",\n          "id": 0,\n          "label": "",\n          "media_type": "",\n          "position": 0,\n          "types": []\n        }\n      ],\n      "name": "",\n      "options": [\n        {\n          "extension_attributes": {\n            "vertex_flex_field": ""\n          },\n          "file_extension": "",\n          "image_size_x": 0,\n          "image_size_y": 0,\n          "is_require": false,\n          "max_characters": 0,\n          "option_id": 0,\n          "price": "",\n          "price_type": "",\n          "product_sku": "",\n          "sku": "",\n          "sort_order": 0,\n          "title": "",\n          "type": "",\n          "values": [\n            {\n              "option_type_id": 0,\n              "price": "",\n              "price_type": "",\n              "sku": "",\n              "sort_order": 0,\n              "title": ""\n            }\n          ]\n        }\n      ],\n      "price": "",\n      "product_links": [\n        {\n          "extension_attributes": {\n            "qty": ""\n          },\n          "link_type": "",\n          "linked_product_sku": "",\n          "linked_product_type": "",\n          "position": 0,\n          "sku": ""\n        }\n      ],\n      "sku": "",\n      "status": 0,\n      "tier_prices": [\n        {\n          "customer_group_id": 0,\n          "extension_attributes": {\n            "percentage_value": "",\n            "website_id": 0\n          },\n          "qty": "",\n          "value": ""\n        }\n      ],\n      "type_id": "",\n      "updated_at": "",\n      "visibility": 0,\n      "weight": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/V1/sharedCatalog/:id/assignProducts
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["products": [
    [
      "attribute_set_id": 0,
      "created_at": "",
      "custom_attributes": [
        [
          "attribute_code": "",
          "value": ""
        ]
      ],
      "extension_attributes": [
        "bundle_product_options": [
          [
            "extension_attributes": [],
            "option_id": 0,
            "position": 0,
            "product_links": [
              [
                "can_change_quantity": 0,
                "extension_attributes": [],
                "id": "",
                "is_default": false,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
              ]
            ],
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
          ]
        ],
        "category_links": [
          [
            "category_id": "",
            "extension_attributes": [],
            "position": 0
          ]
        ],
        "configurable_product_links": [],
        "configurable_product_options": [
          [
            "attribute_id": "",
            "extension_attributes": [],
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": [
              [
                "extension_attributes": [],
                "value_index": 0
              ]
            ]
          ]
        ],
        "downloadable_product_links": [
          [
            "extension_attributes": [],
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": [
              "extension_attributes": [],
              "file_data": "",
              "name": ""
            ],
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": [],
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          ]
        ],
        "downloadable_product_samples": [
          [
            "extension_attributes": [],
            "id": 0,
            "sample_file": "",
            "sample_file_content": [],
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          ]
        ],
        "giftcard_amounts": [
          [
            "attribute_id": 0,
            "extension_attributes": [],
            "value": "",
            "website_id": 0,
            "website_value": ""
          ]
        ],
        "stock_item": [
          "backorders": 0,
          "enable_qty_increments": false,
          "extension_attributes": [],
          "is_decimal_divided": false,
          "is_in_stock": false,
          "is_qty_decimal": false,
          "item_id": 0,
          "low_stock_date": "",
          "manage_stock": false,
          "max_sale_qty": "",
          "min_qty": "",
          "min_sale_qty": "",
          "notify_stock_qty": "",
          "product_id": 0,
          "qty": "",
          "qty_increments": "",
          "show_default_notification_message": false,
          "stock_id": 0,
          "stock_status_changed_auto": 0,
          "use_config_backorders": false,
          "use_config_enable_qty_inc": false,
          "use_config_manage_stock": false,
          "use_config_max_sale_qty": false,
          "use_config_min_qty": false,
          "use_config_min_sale_qty": 0,
          "use_config_notify_stock_qty": false,
          "use_config_qty_increments": false
        ],
        "website_ids": []
      ],
      "id": 0,
      "media_gallery_entries": [
        [
          "content": [
            "base64_encoded_data": "",
            "name": "",
            "type": ""
          ],
          "disabled": false,
          "extension_attributes": ["video_content": [
              "media_type": "",
              "video_description": "",
              "video_metadata": "",
              "video_provider": "",
              "video_title": "",
              "video_url": ""
            ]],
          "file": "",
          "id": 0,
          "label": "",
          "media_type": "",
          "position": 0,
          "types": []
        ]
      ],
      "name": "",
      "options": [
        [
          "extension_attributes": ["vertex_flex_field": ""],
          "file_extension": "",
          "image_size_x": 0,
          "image_size_y": 0,
          "is_require": false,
          "max_characters": 0,
          "option_id": 0,
          "price": "",
          "price_type": "",
          "product_sku": "",
          "sku": "",
          "sort_order": 0,
          "title": "",
          "type": "",
          "values": [
            [
              "option_type_id": 0,
              "price": "",
              "price_type": "",
              "sku": "",
              "sort_order": 0,
              "title": ""
            ]
          ]
        ]
      ],
      "price": "",
      "product_links": [
        [
          "extension_attributes": ["qty": ""],
          "link_type": "",
          "linked_product_sku": "",
          "linked_product_type": "",
          "position": 0,
          "sku": ""
        ]
      ],
      "sku": "",
      "status": 0,
      "tier_prices": [
        [
          "customer_group_id": 0,
          "extension_attributes": [
            "percentage_value": "",
            "website_id": 0
          ],
          "qty": "",
          "value": ""
        ]
      ],
      "type_id": "",
      "updated_at": "",
      "visibility": 0,
      "weight": ""
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/sharedCatalog/:id/assignProducts")! 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 sharedCatalog-{id}-categories
{{baseUrl}}/V1/sharedCatalog/:id/categories
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/sharedCatalog/:id/categories");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/sharedCatalog/:id/categories")
require "http/client"

url = "{{baseUrl}}/V1/sharedCatalog/:id/categories"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/sharedCatalog/:id/categories"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/sharedCatalog/:id/categories");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/sharedCatalog/:id/categories"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/sharedCatalog/:id/categories HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/sharedCatalog/:id/categories")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/sharedCatalog/:id/categories"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:id/categories")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/sharedCatalog/:id/categories")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/sharedCatalog/:id/categories');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/sharedCatalog/:id/categories'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/sharedCatalog/:id/categories';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/sharedCatalog/:id/categories',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:id/categories")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/sharedCatalog/:id/categories',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/sharedCatalog/:id/categories'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/sharedCatalog/:id/categories');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/sharedCatalog/:id/categories'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/sharedCatalog/:id/categories';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/sharedCatalog/:id/categories"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/sharedCatalog/:id/categories" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/sharedCatalog/:id/categories",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/sharedCatalog/:id/categories');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/sharedCatalog/:id/categories');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/sharedCatalog/:id/categories');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/sharedCatalog/:id/categories' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/sharedCatalog/:id/categories' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/sharedCatalog/:id/categories")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/sharedCatalog/:id/categories"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/sharedCatalog/:id/categories"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/sharedCatalog/:id/categories")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/sharedCatalog/:id/categories') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/sharedCatalog/:id/categories";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/sharedCatalog/:id/categories
http GET {{baseUrl}}/V1/sharedCatalog/:id/categories
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/sharedCatalog/:id/categories
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/sharedCatalog/:id/categories")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET sharedCatalog-{id}-products
{{baseUrl}}/V1/sharedCatalog/:id/products
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/sharedCatalog/:id/products");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/sharedCatalog/:id/products")
require "http/client"

url = "{{baseUrl}}/V1/sharedCatalog/:id/products"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/sharedCatalog/:id/products"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/sharedCatalog/:id/products");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/sharedCatalog/:id/products"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/sharedCatalog/:id/products HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/sharedCatalog/:id/products")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/sharedCatalog/:id/products"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:id/products")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/sharedCatalog/:id/products")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/sharedCatalog/:id/products');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/sharedCatalog/:id/products'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/sharedCatalog/:id/products';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/sharedCatalog/:id/products',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:id/products")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/sharedCatalog/:id/products',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/sharedCatalog/:id/products'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/sharedCatalog/:id/products');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/sharedCatalog/:id/products'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/sharedCatalog/:id/products';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/sharedCatalog/:id/products"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/sharedCatalog/:id/products" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/sharedCatalog/:id/products",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/sharedCatalog/:id/products');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/sharedCatalog/:id/products');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/sharedCatalog/:id/products');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/sharedCatalog/:id/products' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/sharedCatalog/:id/products' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/sharedCatalog/:id/products")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/sharedCatalog/:id/products"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/sharedCatalog/:id/products"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/sharedCatalog/:id/products")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/sharedCatalog/:id/products') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/sharedCatalog/:id/products";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/sharedCatalog/:id/products
http GET {{baseUrl}}/V1/sharedCatalog/:id/products
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/sharedCatalog/:id/products
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/sharedCatalog/:id/products")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST sharedCatalog-{id}-unassignCategories
{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories
QUERY PARAMS

id
BODY json

{
  "categories": [
    {
      "available_sort_by": [],
      "children": "",
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {},
      "id": 0,
      "include_in_menu": false,
      "is_active": false,
      "level": 0,
      "name": "",
      "parent_id": 0,
      "path": "",
      "position": 0,
      "updated_at": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories" {:content-type :json
                                                                                    :form-params {:categories [{:available_sort_by []
                                                                                                                :children ""
                                                                                                                :created_at ""
                                                                                                                :custom_attributes [{:attribute_code ""
                                                                                                                                     :value ""}]
                                                                                                                :extension_attributes {}
                                                                                                                :id 0
                                                                                                                :include_in_menu false
                                                                                                                :is_active false
                                                                                                                :level 0
                                                                                                                :name ""
                                                                                                                :parent_id 0
                                                                                                                :path ""
                                                                                                                :position 0
                                                                                                                :updated_at ""}]}})
require "http/client"

url = "{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\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}}/V1/sharedCatalog/:id/unassignCategories"),
    Content = new StringContent("{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\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}}/V1/sharedCatalog/:id/unassignCategories");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories"

	payload := strings.NewReader("{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/sharedCatalog/:id/unassignCategories HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 453

{
  "categories": [
    {
      "available_sort_by": [],
      "children": "",
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {},
      "id": 0,
      "include_in_menu": false,
      "is_active": false,
      "level": 0,
      "name": "",
      "parent_id": 0,
      "path": "",
      "position": 0,
      "updated_at": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\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  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories")
  .header("content-type", "application/json")
  .body("{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  categories: [
    {
      available_sort_by: [],
      children: '',
      created_at: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      extension_attributes: {},
      id: 0,
      include_in_menu: false,
      is_active: false,
      level: 0,
      name: '',
      parent_id: 0,
      path: '',
      position: 0,
      updated_at: ''
    }
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories',
  headers: {'content-type': 'application/json'},
  data: {
    categories: [
      {
        available_sort_by: [],
        children: '',
        created_at: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        extension_attributes: {},
        id: 0,
        include_in_menu: false,
        is_active: false,
        level: 0,
        name: '',
        parent_id: 0,
        path: '',
        position: 0,
        updated_at: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"categories":[{"available_sort_by":[],"children":"","created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{},"id":0,"include_in_menu":false,"is_active":false,"level":0,"name":"","parent_id":0,"path":"","position":0,"updated_at":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "categories": [\n    {\n      "available_sort_by": [],\n      "children": "",\n      "created_at": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "extension_attributes": {},\n      "id": 0,\n      "include_in_menu": false,\n      "is_active": false,\n      "level": 0,\n      "name": "",\n      "parent_id": 0,\n      "path": "",\n      "position": 0,\n      "updated_at": ""\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  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/sharedCatalog/:id/unassignCategories',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  categories: [
    {
      available_sort_by: [],
      children: '',
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {},
      id: 0,
      include_in_menu: false,
      is_active: false,
      level: 0,
      name: '',
      parent_id: 0,
      path: '',
      position: 0,
      updated_at: ''
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories',
  headers: {'content-type': 'application/json'},
  body: {
    categories: [
      {
        available_sort_by: [],
        children: '',
        created_at: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        extension_attributes: {},
        id: 0,
        include_in_menu: false,
        is_active: false,
        level: 0,
        name: '',
        parent_id: 0,
        path: '',
        position: 0,
        updated_at: ''
      }
    ]
  },
  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}}/V1/sharedCatalog/:id/unassignCategories');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  categories: [
    {
      available_sort_by: [],
      children: '',
      created_at: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      extension_attributes: {},
      id: 0,
      include_in_menu: false,
      is_active: false,
      level: 0,
      name: '',
      parent_id: 0,
      path: '',
      position: 0,
      updated_at: ''
    }
  ]
});

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}}/V1/sharedCatalog/:id/unassignCategories',
  headers: {'content-type': 'application/json'},
  data: {
    categories: [
      {
        available_sort_by: [],
        children: '',
        created_at: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        extension_attributes: {},
        id: 0,
        include_in_menu: false,
        is_active: false,
        level: 0,
        name: '',
        parent_id: 0,
        path: '',
        position: 0,
        updated_at: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"categories":[{"available_sort_by":[],"children":"","created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{},"id":0,"include_in_menu":false,"is_active":false,"level":0,"name":"","parent_id":0,"path":"","position":0,"updated_at":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"categories": @[ @{ @"available_sort_by": @[  ], @"children": @"", @"created_at": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"extension_attributes": @{  }, @"id": @0, @"include_in_menu": @NO, @"is_active": @NO, @"level": @0, @"name": @"", @"parent_id": @0, @"path": @"", @"position": @0, @"updated_at": @"" } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories"]
                                                       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}}/V1/sharedCatalog/:id/unassignCategories" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories",
  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([
    'categories' => [
        [
                'available_sort_by' => [
                                
                ],
                'children' => '',
                'created_at' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'extension_attributes' => [
                                
                ],
                'id' => 0,
                'include_in_menu' => null,
                'is_active' => null,
                'level' => 0,
                'name' => '',
                'parent_id' => 0,
                'path' => '',
                'position' => 0,
                'updated_at' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories', [
  'body' => '{
  "categories": [
    {
      "available_sort_by": [],
      "children": "",
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {},
      "id": 0,
      "include_in_menu": false,
      "is_active": false,
      "level": 0,
      "name": "",
      "parent_id": 0,
      "path": "",
      "position": 0,
      "updated_at": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'categories' => [
    [
        'available_sort_by' => [
                
        ],
        'children' => '',
        'created_at' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'include_in_menu' => null,
        'is_active' => null,
        'level' => 0,
        'name' => '',
        'parent_id' => 0,
        'path' => '',
        'position' => 0,
        'updated_at' => ''
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'categories' => [
    [
        'available_sort_by' => [
                
        ],
        'children' => '',
        'created_at' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'include_in_menu' => null,
        'is_active' => null,
        'level' => 0,
        'name' => '',
        'parent_id' => 0,
        'path' => '',
        'position' => 0,
        'updated_at' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "categories": [
    {
      "available_sort_by": [],
      "children": "",
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {},
      "id": 0,
      "include_in_menu": false,
      "is_active": false,
      "level": 0,
      "name": "",
      "parent_id": 0,
      "path": "",
      "position": 0,
      "updated_at": ""
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "categories": [
    {
      "available_sort_by": [],
      "children": "",
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {},
      "id": 0,
      "include_in_menu": false,
      "is_active": false,
      "level": 0,
      "name": "",
      "parent_id": 0,
      "path": "",
      "position": 0,
      "updated_at": ""
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/sharedCatalog/:id/unassignCategories", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories"

payload = { "categories": [
        {
            "available_sort_by": [],
            "children": "",
            "created_at": "",
            "custom_attributes": [
                {
                    "attribute_code": "",
                    "value": ""
                }
            ],
            "extension_attributes": {},
            "id": 0,
            "include_in_menu": False,
            "is_active": False,
            "level": 0,
            "name": "",
            "parent_id": 0,
            "path": "",
            "position": 0,
            "updated_at": ""
        }
    ] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories"

payload <- "{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\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/V1/sharedCatalog/:id/unassignCategories') do |req|
  req.body = "{\n  \"categories\": [\n    {\n      \"available_sort_by\": [],\n      \"children\": \"\",\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {},\n      \"id\": 0,\n      \"include_in_menu\": false,\n      \"is_active\": false,\n      \"level\": 0,\n      \"name\": \"\",\n      \"parent_id\": 0,\n      \"path\": \"\",\n      \"position\": 0,\n      \"updated_at\": \"\"\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}}/V1/sharedCatalog/:id/unassignCategories";

    let payload = json!({"categories": (
            json!({
                "available_sort_by": (),
                "children": "",
                "created_at": "",
                "custom_attributes": (
                    json!({
                        "attribute_code": "",
                        "value": ""
                    })
                ),
                "extension_attributes": json!({}),
                "id": 0,
                "include_in_menu": false,
                "is_active": false,
                "level": 0,
                "name": "",
                "parent_id": 0,
                "path": "",
                "position": 0,
                "updated_at": ""
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/sharedCatalog/:id/unassignCategories \
  --header 'content-type: application/json' \
  --data '{
  "categories": [
    {
      "available_sort_by": [],
      "children": "",
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {},
      "id": 0,
      "include_in_menu": false,
      "is_active": false,
      "level": 0,
      "name": "",
      "parent_id": 0,
      "path": "",
      "position": 0,
      "updated_at": ""
    }
  ]
}'
echo '{
  "categories": [
    {
      "available_sort_by": [],
      "children": "",
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {},
      "id": 0,
      "include_in_menu": false,
      "is_active": false,
      "level": 0,
      "name": "",
      "parent_id": 0,
      "path": "",
      "position": 0,
      "updated_at": ""
    }
  ]
}' |  \
  http POST {{baseUrl}}/V1/sharedCatalog/:id/unassignCategories \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "categories": [\n    {\n      "available_sort_by": [],\n      "children": "",\n      "created_at": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "extension_attributes": {},\n      "id": 0,\n      "include_in_menu": false,\n      "is_active": false,\n      "level": 0,\n      "name": "",\n      "parent_id": 0,\n      "path": "",\n      "position": 0,\n      "updated_at": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/V1/sharedCatalog/:id/unassignCategories
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["categories": [
    [
      "available_sort_by": [],
      "children": "",
      "created_at": "",
      "custom_attributes": [
        [
          "attribute_code": "",
          "value": ""
        ]
      ],
      "extension_attributes": [],
      "id": 0,
      "include_in_menu": false,
      "is_active": false,
      "level": 0,
      "name": "",
      "parent_id": 0,
      "path": "",
      "position": 0,
      "updated_at": ""
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/sharedCatalog/:id/unassignCategories")! 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 sharedCatalog-{id}-unassignProducts
{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts
QUERY PARAMS

id
BODY json

{
  "products": [
    {
      "attribute_set_id": 0,
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {
        "bundle_product_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "position": 0,
            "product_links": [
              {
                "can_change_quantity": 0,
                "extension_attributes": {},
                "id": "",
                "is_default": false,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
              }
            ],
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
          }
        ],
        "category_links": [
          {
            "category_id": "",
            "extension_attributes": {},
            "position": 0
          }
        ],
        "configurable_product_links": [],
        "configurable_product_options": [
          {
            "attribute_id": "",
            "extension_attributes": {},
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": [
              {
                "extension_attributes": {},
                "value_index": 0
              }
            ]
          }
        ],
        "downloadable_product_links": [
          {
            "extension_attributes": {},
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": {
              "extension_attributes": {},
              "file_data": "",
              "name": ""
            },
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "downloadable_product_samples": [
          {
            "extension_attributes": {},
            "id": 0,
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "giftcard_amounts": [
          {
            "attribute_id": 0,
            "extension_attributes": {},
            "value": "",
            "website_id": 0,
            "website_value": ""
          }
        ],
        "stock_item": {
          "backorders": 0,
          "enable_qty_increments": false,
          "extension_attributes": {},
          "is_decimal_divided": false,
          "is_in_stock": false,
          "is_qty_decimal": false,
          "item_id": 0,
          "low_stock_date": "",
          "manage_stock": false,
          "max_sale_qty": "",
          "min_qty": "",
          "min_sale_qty": "",
          "notify_stock_qty": "",
          "product_id": 0,
          "qty": "",
          "qty_increments": "",
          "show_default_notification_message": false,
          "stock_id": 0,
          "stock_status_changed_auto": 0,
          "use_config_backorders": false,
          "use_config_enable_qty_inc": false,
          "use_config_manage_stock": false,
          "use_config_max_sale_qty": false,
          "use_config_min_qty": false,
          "use_config_min_sale_qty": 0,
          "use_config_notify_stock_qty": false,
          "use_config_qty_increments": false
        },
        "website_ids": []
      },
      "id": 0,
      "media_gallery_entries": [
        {
          "content": {
            "base64_encoded_data": "",
            "name": "",
            "type": ""
          },
          "disabled": false,
          "extension_attributes": {
            "video_content": {
              "media_type": "",
              "video_description": "",
              "video_metadata": "",
              "video_provider": "",
              "video_title": "",
              "video_url": ""
            }
          },
          "file": "",
          "id": 0,
          "label": "",
          "media_type": "",
          "position": 0,
          "types": []
        }
      ],
      "name": "",
      "options": [
        {
          "extension_attributes": {
            "vertex_flex_field": ""
          },
          "file_extension": "",
          "image_size_x": 0,
          "image_size_y": 0,
          "is_require": false,
          "max_characters": 0,
          "option_id": 0,
          "price": "",
          "price_type": "",
          "product_sku": "",
          "sku": "",
          "sort_order": 0,
          "title": "",
          "type": "",
          "values": [
            {
              "option_type_id": 0,
              "price": "",
              "price_type": "",
              "sku": "",
              "sort_order": 0,
              "title": ""
            }
          ]
        }
      ],
      "price": "",
      "product_links": [
        {
          "extension_attributes": {
            "qty": ""
          },
          "link_type": "",
          "linked_product_sku": "",
          "linked_product_type": "",
          "position": 0,
          "sku": ""
        }
      ],
      "sku": "",
      "status": 0,
      "tier_prices": [
        {
          "customer_group_id": 0,
          "extension_attributes": {
            "percentage_value": "",
            "website_id": 0
          },
          "qty": "",
          "value": ""
        }
      ],
      "type_id": "",
      "updated_at": "",
      "visibility": 0,
      "weight": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts" {:content-type :json
                                                                                  :form-params {:products [{:attribute_set_id 0
                                                                                                            :created_at ""
                                                                                                            :custom_attributes [{:attribute_code ""
                                                                                                                                 :value ""}]
                                                                                                            :extension_attributes {:bundle_product_options [{:extension_attributes {}
                                                                                                                                                             :option_id 0
                                                                                                                                                             :position 0
                                                                                                                                                             :product_links [{:can_change_quantity 0
                                                                                                                                                                              :extension_attributes {}
                                                                                                                                                                              :id ""
                                                                                                                                                                              :is_default false
                                                                                                                                                                              :option_id 0
                                                                                                                                                                              :position 0
                                                                                                                                                                              :price ""
                                                                                                                                                                              :price_type 0
                                                                                                                                                                              :qty ""
                                                                                                                                                                              :sku ""}]
                                                                                                                                                             :required false
                                                                                                                                                             :sku ""
                                                                                                                                                             :title ""
                                                                                                                                                             :type ""}]
                                                                                                                                   :category_links [{:category_id ""
                                                                                                                                                     :extension_attributes {}
                                                                                                                                                     :position 0}]
                                                                                                                                   :configurable_product_links []
                                                                                                                                   :configurable_product_options [{:attribute_id ""
                                                                                                                                                                   :extension_attributes {}
                                                                                                                                                                   :id 0
                                                                                                                                                                   :is_use_default false
                                                                                                                                                                   :label ""
                                                                                                                                                                   :position 0
                                                                                                                                                                   :product_id 0
                                                                                                                                                                   :values [{:extension_attributes {}
                                                                                                                                                                             :value_index 0}]}]
                                                                                                                                   :downloadable_product_links [{:extension_attributes {}
                                                                                                                                                                 :id 0
                                                                                                                                                                 :is_shareable 0
                                                                                                                                                                 :link_file ""
                                                                                                                                                                 :link_file_content {:extension_attributes {}
                                                                                                                                                                                     :file_data ""
                                                                                                                                                                                     :name ""}
                                                                                                                                                                 :link_type ""
                                                                                                                                                                 :link_url ""
                                                                                                                                                                 :number_of_downloads 0
                                                                                                                                                                 :price ""
                                                                                                                                                                 :sample_file ""
                                                                                                                                                                 :sample_file_content {}
                                                                                                                                                                 :sample_type ""
                                                                                                                                                                 :sample_url ""
                                                                                                                                                                 :sort_order 0
                                                                                                                                                                 :title ""}]
                                                                                                                                   :downloadable_product_samples [{:extension_attributes {}
                                                                                                                                                                   :id 0
                                                                                                                                                                   :sample_file ""
                                                                                                                                                                   :sample_file_content {}
                                                                                                                                                                   :sample_type ""
                                                                                                                                                                   :sample_url ""
                                                                                                                                                                   :sort_order 0
                                                                                                                                                                   :title ""}]
                                                                                                                                   :giftcard_amounts [{:attribute_id 0
                                                                                                                                                       :extension_attributes {}
                                                                                                                                                       :value ""
                                                                                                                                                       :website_id 0
                                                                                                                                                       :website_value ""}]
                                                                                                                                   :stock_item {:backorders 0
                                                                                                                                                :enable_qty_increments false
                                                                                                                                                :extension_attributes {}
                                                                                                                                                :is_decimal_divided false
                                                                                                                                                :is_in_stock false
                                                                                                                                                :is_qty_decimal false
                                                                                                                                                :item_id 0
                                                                                                                                                :low_stock_date ""
                                                                                                                                                :manage_stock false
                                                                                                                                                :max_sale_qty ""
                                                                                                                                                :min_qty ""
                                                                                                                                                :min_sale_qty ""
                                                                                                                                                :notify_stock_qty ""
                                                                                                                                                :product_id 0
                                                                                                                                                :qty ""
                                                                                                                                                :qty_increments ""
                                                                                                                                                :show_default_notification_message false
                                                                                                                                                :stock_id 0
                                                                                                                                                :stock_status_changed_auto 0
                                                                                                                                                :use_config_backorders false
                                                                                                                                                :use_config_enable_qty_inc false
                                                                                                                                                :use_config_manage_stock false
                                                                                                                                                :use_config_max_sale_qty false
                                                                                                                                                :use_config_min_qty false
                                                                                                                                                :use_config_min_sale_qty 0
                                                                                                                                                :use_config_notify_stock_qty false
                                                                                                                                                :use_config_qty_increments false}
                                                                                                                                   :website_ids []}
                                                                                                            :id 0
                                                                                                            :media_gallery_entries [{:content {:base64_encoded_data ""
                                                                                                                                               :name ""
                                                                                                                                               :type ""}
                                                                                                                                     :disabled false
                                                                                                                                     :extension_attributes {:video_content {:media_type ""
                                                                                                                                                                            :video_description ""
                                                                                                                                                                            :video_metadata ""
                                                                                                                                                                            :video_provider ""
                                                                                                                                                                            :video_title ""
                                                                                                                                                                            :video_url ""}}
                                                                                                                                     :file ""
                                                                                                                                     :id 0
                                                                                                                                     :label ""
                                                                                                                                     :media_type ""
                                                                                                                                     :position 0
                                                                                                                                     :types []}]
                                                                                                            :name ""
                                                                                                            :options [{:extension_attributes {:vertex_flex_field ""}
                                                                                                                       :file_extension ""
                                                                                                                       :image_size_x 0
                                                                                                                       :image_size_y 0
                                                                                                                       :is_require false
                                                                                                                       :max_characters 0
                                                                                                                       :option_id 0
                                                                                                                       :price ""
                                                                                                                       :price_type ""
                                                                                                                       :product_sku ""
                                                                                                                       :sku ""
                                                                                                                       :sort_order 0
                                                                                                                       :title ""
                                                                                                                       :type ""
                                                                                                                       :values [{:option_type_id 0
                                                                                                                                 :price ""
                                                                                                                                 :price_type ""
                                                                                                                                 :sku ""
                                                                                                                                 :sort_order 0
                                                                                                                                 :title ""}]}]
                                                                                                            :price ""
                                                                                                            :product_links [{:extension_attributes {:qty ""}
                                                                                                                             :link_type ""
                                                                                                                             :linked_product_sku ""
                                                                                                                             :linked_product_type ""
                                                                                                                             :position 0
                                                                                                                             :sku ""}]
                                                                                                            :sku ""
                                                                                                            :status 0
                                                                                                            :tier_prices [{:customer_group_id 0
                                                                                                                           :extension_attributes {:percentage_value ""
                                                                                                                                                  :website_id 0}
                                                                                                                           :qty ""
                                                                                                                           :value ""}]
                                                                                                            :type_id ""
                                                                                                            :updated_at ""
                                                                                                            :visibility 0
                                                                                                            :weight ""}]}})
require "http/client"

url = "{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\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}}/V1/sharedCatalog/:id/unassignProducts"),
    Content = new StringContent("{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\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}}/V1/sharedCatalog/:id/unassignProducts");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts"

	payload := strings.NewReader("{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/sharedCatalog/:id/unassignProducts HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 5835

{
  "products": [
    {
      "attribute_set_id": 0,
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {
        "bundle_product_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "position": 0,
            "product_links": [
              {
                "can_change_quantity": 0,
                "extension_attributes": {},
                "id": "",
                "is_default": false,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
              }
            ],
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
          }
        ],
        "category_links": [
          {
            "category_id": "",
            "extension_attributes": {},
            "position": 0
          }
        ],
        "configurable_product_links": [],
        "configurable_product_options": [
          {
            "attribute_id": "",
            "extension_attributes": {},
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": [
              {
                "extension_attributes": {},
                "value_index": 0
              }
            ]
          }
        ],
        "downloadable_product_links": [
          {
            "extension_attributes": {},
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": {
              "extension_attributes": {},
              "file_data": "",
              "name": ""
            },
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "downloadable_product_samples": [
          {
            "extension_attributes": {},
            "id": 0,
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "giftcard_amounts": [
          {
            "attribute_id": 0,
            "extension_attributes": {},
            "value": "",
            "website_id": 0,
            "website_value": ""
          }
        ],
        "stock_item": {
          "backorders": 0,
          "enable_qty_increments": false,
          "extension_attributes": {},
          "is_decimal_divided": false,
          "is_in_stock": false,
          "is_qty_decimal": false,
          "item_id": 0,
          "low_stock_date": "",
          "manage_stock": false,
          "max_sale_qty": "",
          "min_qty": "",
          "min_sale_qty": "",
          "notify_stock_qty": "",
          "product_id": 0,
          "qty": "",
          "qty_increments": "",
          "show_default_notification_message": false,
          "stock_id": 0,
          "stock_status_changed_auto": 0,
          "use_config_backorders": false,
          "use_config_enable_qty_inc": false,
          "use_config_manage_stock": false,
          "use_config_max_sale_qty": false,
          "use_config_min_qty": false,
          "use_config_min_sale_qty": 0,
          "use_config_notify_stock_qty": false,
          "use_config_qty_increments": false
        },
        "website_ids": []
      },
      "id": 0,
      "media_gallery_entries": [
        {
          "content": {
            "base64_encoded_data": "",
            "name": "",
            "type": ""
          },
          "disabled": false,
          "extension_attributes": {
            "video_content": {
              "media_type": "",
              "video_description": "",
              "video_metadata": "",
              "video_provider": "",
              "video_title": "",
              "video_url": ""
            }
          },
          "file": "",
          "id": 0,
          "label": "",
          "media_type": "",
          "position": 0,
          "types": []
        }
      ],
      "name": "",
      "options": [
        {
          "extension_attributes": {
            "vertex_flex_field": ""
          },
          "file_extension": "",
          "image_size_x": 0,
          "image_size_y": 0,
          "is_require": false,
          "max_characters": 0,
          "option_id": 0,
          "price": "",
          "price_type": "",
          "product_sku": "",
          "sku": "",
          "sort_order": 0,
          "title": "",
          "type": "",
          "values": [
            {
              "option_type_id": 0,
              "price": "",
              "price_type": "",
              "sku": "",
              "sort_order": 0,
              "title": ""
            }
          ]
        }
      ],
      "price": "",
      "product_links": [
        {
          "extension_attributes": {
            "qty": ""
          },
          "link_type": "",
          "linked_product_sku": "",
          "linked_product_type": "",
          "position": 0,
          "sku": ""
        }
      ],
      "sku": "",
      "status": 0,
      "tier_prices": [
        {
          "customer_group_id": 0,
          "extension_attributes": {
            "percentage_value": "",
            "website_id": 0
          },
          "qty": "",
          "value": ""
        }
      ],
      "type_id": "",
      "updated_at": "",
      "visibility": 0,
      "weight": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\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  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts")
  .header("content-type", "application/json")
  .body("{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  products: [
    {
      attribute_set_id: 0,
      created_at: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      extension_attributes: {
        bundle_product_options: [
          {
            extension_attributes: {},
            option_id: 0,
            position: 0,
            product_links: [
              {
                can_change_quantity: 0,
                extension_attributes: {},
                id: '',
                is_default: false,
                option_id: 0,
                position: 0,
                price: '',
                price_type: 0,
                qty: '',
                sku: ''
              }
            ],
            required: false,
            sku: '',
            title: '',
            type: ''
          }
        ],
        category_links: [
          {
            category_id: '',
            extension_attributes: {},
            position: 0
          }
        ],
        configurable_product_links: [],
        configurable_product_options: [
          {
            attribute_id: '',
            extension_attributes: {},
            id: 0,
            is_use_default: false,
            label: '',
            position: 0,
            product_id: 0,
            values: [
              {
                extension_attributes: {},
                value_index: 0
              }
            ]
          }
        ],
        downloadable_product_links: [
          {
            extension_attributes: {},
            id: 0,
            is_shareable: 0,
            link_file: '',
            link_file_content: {
              extension_attributes: {},
              file_data: '',
              name: ''
            },
            link_type: '',
            link_url: '',
            number_of_downloads: 0,
            price: '',
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        downloadable_product_samples: [
          {
            extension_attributes: {},
            id: 0,
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        giftcard_amounts: [
          {
            attribute_id: 0,
            extension_attributes: {},
            value: '',
            website_id: 0,
            website_value: ''
          }
        ],
        stock_item: {
          backorders: 0,
          enable_qty_increments: false,
          extension_attributes: {},
          is_decimal_divided: false,
          is_in_stock: false,
          is_qty_decimal: false,
          item_id: 0,
          low_stock_date: '',
          manage_stock: false,
          max_sale_qty: '',
          min_qty: '',
          min_sale_qty: '',
          notify_stock_qty: '',
          product_id: 0,
          qty: '',
          qty_increments: '',
          show_default_notification_message: false,
          stock_id: 0,
          stock_status_changed_auto: 0,
          use_config_backorders: false,
          use_config_enable_qty_inc: false,
          use_config_manage_stock: false,
          use_config_max_sale_qty: false,
          use_config_min_qty: false,
          use_config_min_sale_qty: 0,
          use_config_notify_stock_qty: false,
          use_config_qty_increments: false
        },
        website_ids: []
      },
      id: 0,
      media_gallery_entries: [
        {
          content: {
            base64_encoded_data: '',
            name: '',
            type: ''
          },
          disabled: false,
          extension_attributes: {
            video_content: {
              media_type: '',
              video_description: '',
              video_metadata: '',
              video_provider: '',
              video_title: '',
              video_url: ''
            }
          },
          file: '',
          id: 0,
          label: '',
          media_type: '',
          position: 0,
          types: []
        }
      ],
      name: '',
      options: [
        {
          extension_attributes: {
            vertex_flex_field: ''
          },
          file_extension: '',
          image_size_x: 0,
          image_size_y: 0,
          is_require: false,
          max_characters: 0,
          option_id: 0,
          price: '',
          price_type: '',
          product_sku: '',
          sku: '',
          sort_order: 0,
          title: '',
          type: '',
          values: [
            {
              option_type_id: 0,
              price: '',
              price_type: '',
              sku: '',
              sort_order: 0,
              title: ''
            }
          ]
        }
      ],
      price: '',
      product_links: [
        {
          extension_attributes: {
            qty: ''
          },
          link_type: '',
          linked_product_sku: '',
          linked_product_type: '',
          position: 0,
          sku: ''
        }
      ],
      sku: '',
      status: 0,
      tier_prices: [
        {
          customer_group_id: 0,
          extension_attributes: {
            percentage_value: '',
            website_id: 0
          },
          qty: '',
          value: ''
        }
      ],
      type_id: '',
      updated_at: '',
      visibility: 0,
      weight: ''
    }
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts',
  headers: {'content-type': 'application/json'},
  data: {
    products: [
      {
        attribute_set_id: 0,
        created_at: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        extension_attributes: {
          bundle_product_options: [
            {
              extension_attributes: {},
              option_id: 0,
              position: 0,
              product_links: [
                {
                  can_change_quantity: 0,
                  extension_attributes: {},
                  id: '',
                  is_default: false,
                  option_id: 0,
                  position: 0,
                  price: '',
                  price_type: 0,
                  qty: '',
                  sku: ''
                }
              ],
              required: false,
              sku: '',
              title: '',
              type: ''
            }
          ],
          category_links: [{category_id: '', extension_attributes: {}, position: 0}],
          configurable_product_links: [],
          configurable_product_options: [
            {
              attribute_id: '',
              extension_attributes: {},
              id: 0,
              is_use_default: false,
              label: '',
              position: 0,
              product_id: 0,
              values: [{extension_attributes: {}, value_index: 0}]
            }
          ],
          downloadable_product_links: [
            {
              extension_attributes: {},
              id: 0,
              is_shareable: 0,
              link_file: '',
              link_file_content: {extension_attributes: {}, file_data: '', name: ''},
              link_type: '',
              link_url: '',
              number_of_downloads: 0,
              price: '',
              sample_file: '',
              sample_file_content: {},
              sample_type: '',
              sample_url: '',
              sort_order: 0,
              title: ''
            }
          ],
          downloadable_product_samples: [
            {
              extension_attributes: {},
              id: 0,
              sample_file: '',
              sample_file_content: {},
              sample_type: '',
              sample_url: '',
              sort_order: 0,
              title: ''
            }
          ],
          giftcard_amounts: [
            {
              attribute_id: 0,
              extension_attributes: {},
              value: '',
              website_id: 0,
              website_value: ''
            }
          ],
          stock_item: {
            backorders: 0,
            enable_qty_increments: false,
            extension_attributes: {},
            is_decimal_divided: false,
            is_in_stock: false,
            is_qty_decimal: false,
            item_id: 0,
            low_stock_date: '',
            manage_stock: false,
            max_sale_qty: '',
            min_qty: '',
            min_sale_qty: '',
            notify_stock_qty: '',
            product_id: 0,
            qty: '',
            qty_increments: '',
            show_default_notification_message: false,
            stock_id: 0,
            stock_status_changed_auto: 0,
            use_config_backorders: false,
            use_config_enable_qty_inc: false,
            use_config_manage_stock: false,
            use_config_max_sale_qty: false,
            use_config_min_qty: false,
            use_config_min_sale_qty: 0,
            use_config_notify_stock_qty: false,
            use_config_qty_increments: false
          },
          website_ids: []
        },
        id: 0,
        media_gallery_entries: [
          {
            content: {base64_encoded_data: '', name: '', type: ''},
            disabled: false,
            extension_attributes: {
              video_content: {
                media_type: '',
                video_description: '',
                video_metadata: '',
                video_provider: '',
                video_title: '',
                video_url: ''
              }
            },
            file: '',
            id: 0,
            label: '',
            media_type: '',
            position: 0,
            types: []
          }
        ],
        name: '',
        options: [
          {
            extension_attributes: {vertex_flex_field: ''},
            file_extension: '',
            image_size_x: 0,
            image_size_y: 0,
            is_require: false,
            max_characters: 0,
            option_id: 0,
            price: '',
            price_type: '',
            product_sku: '',
            sku: '',
            sort_order: 0,
            title: '',
            type: '',
            values: [
              {
                option_type_id: 0,
                price: '',
                price_type: '',
                sku: '',
                sort_order: 0,
                title: ''
              }
            ]
          }
        ],
        price: '',
        product_links: [
          {
            extension_attributes: {qty: ''},
            link_type: '',
            linked_product_sku: '',
            linked_product_type: '',
            position: 0,
            sku: ''
          }
        ],
        sku: '',
        status: 0,
        tier_prices: [
          {
            customer_group_id: 0,
            extension_attributes: {percentage_value: '', website_id: 0},
            qty: '',
            value: ''
          }
        ],
        type_id: '',
        updated_at: '',
        visibility: 0,
        weight: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"products":[{"attribute_set_id":0,"created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{"bundle_product_options":[{"extension_attributes":{},"option_id":0,"position":0,"product_links":[{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}],"required":false,"sku":"","title":"","type":""}],"category_links":[{"category_id":"","extension_attributes":{},"position":0}],"configurable_product_links":[],"configurable_product_options":[{"attribute_id":"","extension_attributes":{},"id":0,"is_use_default":false,"label":"","position":0,"product_id":0,"values":[{"extension_attributes":{},"value_index":0}]}],"downloadable_product_links":[{"extension_attributes":{},"id":0,"is_shareable":0,"link_file":"","link_file_content":{"extension_attributes":{},"file_data":"","name":""},"link_type":"","link_url":"","number_of_downloads":0,"price":"","sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"downloadable_product_samples":[{"extension_attributes":{},"id":0,"sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"giftcard_amounts":[{"attribute_id":0,"extension_attributes":{},"value":"","website_id":0,"website_value":""}],"stock_item":{"backorders":0,"enable_qty_increments":false,"extension_attributes":{},"is_decimal_divided":false,"is_in_stock":false,"is_qty_decimal":false,"item_id":0,"low_stock_date":"","manage_stock":false,"max_sale_qty":"","min_qty":"","min_sale_qty":"","notify_stock_qty":"","product_id":0,"qty":"","qty_increments":"","show_default_notification_message":false,"stock_id":0,"stock_status_changed_auto":0,"use_config_backorders":false,"use_config_enable_qty_inc":false,"use_config_manage_stock":false,"use_config_max_sale_qty":false,"use_config_min_qty":false,"use_config_min_sale_qty":0,"use_config_notify_stock_qty":false,"use_config_qty_increments":false},"website_ids":[]},"id":0,"media_gallery_entries":[{"content":{"base64_encoded_data":"","name":"","type":""},"disabled":false,"extension_attributes":{"video_content":{"media_type":"","video_description":"","video_metadata":"","video_provider":"","video_title":"","video_url":""}},"file":"","id":0,"label":"","media_type":"","position":0,"types":[]}],"name":"","options":[{"extension_attributes":{"vertex_flex_field":""},"file_extension":"","image_size_x":0,"image_size_y":0,"is_require":false,"max_characters":0,"option_id":0,"price":"","price_type":"","product_sku":"","sku":"","sort_order":0,"title":"","type":"","values":[{"option_type_id":0,"price":"","price_type":"","sku":"","sort_order":0,"title":""}]}],"price":"","product_links":[{"extension_attributes":{"qty":""},"link_type":"","linked_product_sku":"","linked_product_type":"","position":0,"sku":""}],"sku":"","status":0,"tier_prices":[{"customer_group_id":0,"extension_attributes":{"percentage_value":"","website_id":0},"qty":"","value":""}],"type_id":"","updated_at":"","visibility":0,"weight":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "products": [\n    {\n      "attribute_set_id": 0,\n      "created_at": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "extension_attributes": {\n        "bundle_product_options": [\n          {\n            "extension_attributes": {},\n            "option_id": 0,\n            "position": 0,\n            "product_links": [\n              {\n                "can_change_quantity": 0,\n                "extension_attributes": {},\n                "id": "",\n                "is_default": false,\n                "option_id": 0,\n                "position": 0,\n                "price": "",\n                "price_type": 0,\n                "qty": "",\n                "sku": ""\n              }\n            ],\n            "required": false,\n            "sku": "",\n            "title": "",\n            "type": ""\n          }\n        ],\n        "category_links": [\n          {\n            "category_id": "",\n            "extension_attributes": {},\n            "position": 0\n          }\n        ],\n        "configurable_product_links": [],\n        "configurable_product_options": [\n          {\n            "attribute_id": "",\n            "extension_attributes": {},\n            "id": 0,\n            "is_use_default": false,\n            "label": "",\n            "position": 0,\n            "product_id": 0,\n            "values": [\n              {\n                "extension_attributes": {},\n                "value_index": 0\n              }\n            ]\n          }\n        ],\n        "downloadable_product_links": [\n          {\n            "extension_attributes": {},\n            "id": 0,\n            "is_shareable": 0,\n            "link_file": "",\n            "link_file_content": {\n              "extension_attributes": {},\n              "file_data": "",\n              "name": ""\n            },\n            "link_type": "",\n            "link_url": "",\n            "number_of_downloads": 0,\n            "price": "",\n            "sample_file": "",\n            "sample_file_content": {},\n            "sample_type": "",\n            "sample_url": "",\n            "sort_order": 0,\n            "title": ""\n          }\n        ],\n        "downloadable_product_samples": [\n          {\n            "extension_attributes": {},\n            "id": 0,\n            "sample_file": "",\n            "sample_file_content": {},\n            "sample_type": "",\n            "sample_url": "",\n            "sort_order": 0,\n            "title": ""\n          }\n        ],\n        "giftcard_amounts": [\n          {\n            "attribute_id": 0,\n            "extension_attributes": {},\n            "value": "",\n            "website_id": 0,\n            "website_value": ""\n          }\n        ],\n        "stock_item": {\n          "backorders": 0,\n          "enable_qty_increments": false,\n          "extension_attributes": {},\n          "is_decimal_divided": false,\n          "is_in_stock": false,\n          "is_qty_decimal": false,\n          "item_id": 0,\n          "low_stock_date": "",\n          "manage_stock": false,\n          "max_sale_qty": "",\n          "min_qty": "",\n          "min_sale_qty": "",\n          "notify_stock_qty": "",\n          "product_id": 0,\n          "qty": "",\n          "qty_increments": "",\n          "show_default_notification_message": false,\n          "stock_id": 0,\n          "stock_status_changed_auto": 0,\n          "use_config_backorders": false,\n          "use_config_enable_qty_inc": false,\n          "use_config_manage_stock": false,\n          "use_config_max_sale_qty": false,\n          "use_config_min_qty": false,\n          "use_config_min_sale_qty": 0,\n          "use_config_notify_stock_qty": false,\n          "use_config_qty_increments": false\n        },\n        "website_ids": []\n      },\n      "id": 0,\n      "media_gallery_entries": [\n        {\n          "content": {\n            "base64_encoded_data": "",\n            "name": "",\n            "type": ""\n          },\n          "disabled": false,\n          "extension_attributes": {\n            "video_content": {\n              "media_type": "",\n              "video_description": "",\n              "video_metadata": "",\n              "video_provider": "",\n              "video_title": "",\n              "video_url": ""\n            }\n          },\n          "file": "",\n          "id": 0,\n          "label": "",\n          "media_type": "",\n          "position": 0,\n          "types": []\n        }\n      ],\n      "name": "",\n      "options": [\n        {\n          "extension_attributes": {\n            "vertex_flex_field": ""\n          },\n          "file_extension": "",\n          "image_size_x": 0,\n          "image_size_y": 0,\n          "is_require": false,\n          "max_characters": 0,\n          "option_id": 0,\n          "price": "",\n          "price_type": "",\n          "product_sku": "",\n          "sku": "",\n          "sort_order": 0,\n          "title": "",\n          "type": "",\n          "values": [\n            {\n              "option_type_id": 0,\n              "price": "",\n              "price_type": "",\n              "sku": "",\n              "sort_order": 0,\n              "title": ""\n            }\n          ]\n        }\n      ],\n      "price": "",\n      "product_links": [\n        {\n          "extension_attributes": {\n            "qty": ""\n          },\n          "link_type": "",\n          "linked_product_sku": "",\n          "linked_product_type": "",\n          "position": 0,\n          "sku": ""\n        }\n      ],\n      "sku": "",\n      "status": 0,\n      "tier_prices": [\n        {\n          "customer_group_id": 0,\n          "extension_attributes": {\n            "percentage_value": "",\n            "website_id": 0\n          },\n          "qty": "",\n          "value": ""\n        }\n      ],\n      "type_id": "",\n      "updated_at": "",\n      "visibility": 0,\n      "weight": ""\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  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/sharedCatalog/:id/unassignProducts',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  products: [
    {
      attribute_set_id: 0,
      created_at: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      extension_attributes: {
        bundle_product_options: [
          {
            extension_attributes: {},
            option_id: 0,
            position: 0,
            product_links: [
              {
                can_change_quantity: 0,
                extension_attributes: {},
                id: '',
                is_default: false,
                option_id: 0,
                position: 0,
                price: '',
                price_type: 0,
                qty: '',
                sku: ''
              }
            ],
            required: false,
            sku: '',
            title: '',
            type: ''
          }
        ],
        category_links: [{category_id: '', extension_attributes: {}, position: 0}],
        configurable_product_links: [],
        configurable_product_options: [
          {
            attribute_id: '',
            extension_attributes: {},
            id: 0,
            is_use_default: false,
            label: '',
            position: 0,
            product_id: 0,
            values: [{extension_attributes: {}, value_index: 0}]
          }
        ],
        downloadable_product_links: [
          {
            extension_attributes: {},
            id: 0,
            is_shareable: 0,
            link_file: '',
            link_file_content: {extension_attributes: {}, file_data: '', name: ''},
            link_type: '',
            link_url: '',
            number_of_downloads: 0,
            price: '',
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        downloadable_product_samples: [
          {
            extension_attributes: {},
            id: 0,
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        giftcard_amounts: [
          {
            attribute_id: 0,
            extension_attributes: {},
            value: '',
            website_id: 0,
            website_value: ''
          }
        ],
        stock_item: {
          backorders: 0,
          enable_qty_increments: false,
          extension_attributes: {},
          is_decimal_divided: false,
          is_in_stock: false,
          is_qty_decimal: false,
          item_id: 0,
          low_stock_date: '',
          manage_stock: false,
          max_sale_qty: '',
          min_qty: '',
          min_sale_qty: '',
          notify_stock_qty: '',
          product_id: 0,
          qty: '',
          qty_increments: '',
          show_default_notification_message: false,
          stock_id: 0,
          stock_status_changed_auto: 0,
          use_config_backorders: false,
          use_config_enable_qty_inc: false,
          use_config_manage_stock: false,
          use_config_max_sale_qty: false,
          use_config_min_qty: false,
          use_config_min_sale_qty: 0,
          use_config_notify_stock_qty: false,
          use_config_qty_increments: false
        },
        website_ids: []
      },
      id: 0,
      media_gallery_entries: [
        {
          content: {base64_encoded_data: '', name: '', type: ''},
          disabled: false,
          extension_attributes: {
            video_content: {
              media_type: '',
              video_description: '',
              video_metadata: '',
              video_provider: '',
              video_title: '',
              video_url: ''
            }
          },
          file: '',
          id: 0,
          label: '',
          media_type: '',
          position: 0,
          types: []
        }
      ],
      name: '',
      options: [
        {
          extension_attributes: {vertex_flex_field: ''},
          file_extension: '',
          image_size_x: 0,
          image_size_y: 0,
          is_require: false,
          max_characters: 0,
          option_id: 0,
          price: '',
          price_type: '',
          product_sku: '',
          sku: '',
          sort_order: 0,
          title: '',
          type: '',
          values: [
            {
              option_type_id: 0,
              price: '',
              price_type: '',
              sku: '',
              sort_order: 0,
              title: ''
            }
          ]
        }
      ],
      price: '',
      product_links: [
        {
          extension_attributes: {qty: ''},
          link_type: '',
          linked_product_sku: '',
          linked_product_type: '',
          position: 0,
          sku: ''
        }
      ],
      sku: '',
      status: 0,
      tier_prices: [
        {
          customer_group_id: 0,
          extension_attributes: {percentage_value: '', website_id: 0},
          qty: '',
          value: ''
        }
      ],
      type_id: '',
      updated_at: '',
      visibility: 0,
      weight: ''
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts',
  headers: {'content-type': 'application/json'},
  body: {
    products: [
      {
        attribute_set_id: 0,
        created_at: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        extension_attributes: {
          bundle_product_options: [
            {
              extension_attributes: {},
              option_id: 0,
              position: 0,
              product_links: [
                {
                  can_change_quantity: 0,
                  extension_attributes: {},
                  id: '',
                  is_default: false,
                  option_id: 0,
                  position: 0,
                  price: '',
                  price_type: 0,
                  qty: '',
                  sku: ''
                }
              ],
              required: false,
              sku: '',
              title: '',
              type: ''
            }
          ],
          category_links: [{category_id: '', extension_attributes: {}, position: 0}],
          configurable_product_links: [],
          configurable_product_options: [
            {
              attribute_id: '',
              extension_attributes: {},
              id: 0,
              is_use_default: false,
              label: '',
              position: 0,
              product_id: 0,
              values: [{extension_attributes: {}, value_index: 0}]
            }
          ],
          downloadable_product_links: [
            {
              extension_attributes: {},
              id: 0,
              is_shareable: 0,
              link_file: '',
              link_file_content: {extension_attributes: {}, file_data: '', name: ''},
              link_type: '',
              link_url: '',
              number_of_downloads: 0,
              price: '',
              sample_file: '',
              sample_file_content: {},
              sample_type: '',
              sample_url: '',
              sort_order: 0,
              title: ''
            }
          ],
          downloadable_product_samples: [
            {
              extension_attributes: {},
              id: 0,
              sample_file: '',
              sample_file_content: {},
              sample_type: '',
              sample_url: '',
              sort_order: 0,
              title: ''
            }
          ],
          giftcard_amounts: [
            {
              attribute_id: 0,
              extension_attributes: {},
              value: '',
              website_id: 0,
              website_value: ''
            }
          ],
          stock_item: {
            backorders: 0,
            enable_qty_increments: false,
            extension_attributes: {},
            is_decimal_divided: false,
            is_in_stock: false,
            is_qty_decimal: false,
            item_id: 0,
            low_stock_date: '',
            manage_stock: false,
            max_sale_qty: '',
            min_qty: '',
            min_sale_qty: '',
            notify_stock_qty: '',
            product_id: 0,
            qty: '',
            qty_increments: '',
            show_default_notification_message: false,
            stock_id: 0,
            stock_status_changed_auto: 0,
            use_config_backorders: false,
            use_config_enable_qty_inc: false,
            use_config_manage_stock: false,
            use_config_max_sale_qty: false,
            use_config_min_qty: false,
            use_config_min_sale_qty: 0,
            use_config_notify_stock_qty: false,
            use_config_qty_increments: false
          },
          website_ids: []
        },
        id: 0,
        media_gallery_entries: [
          {
            content: {base64_encoded_data: '', name: '', type: ''},
            disabled: false,
            extension_attributes: {
              video_content: {
                media_type: '',
                video_description: '',
                video_metadata: '',
                video_provider: '',
                video_title: '',
                video_url: ''
              }
            },
            file: '',
            id: 0,
            label: '',
            media_type: '',
            position: 0,
            types: []
          }
        ],
        name: '',
        options: [
          {
            extension_attributes: {vertex_flex_field: ''},
            file_extension: '',
            image_size_x: 0,
            image_size_y: 0,
            is_require: false,
            max_characters: 0,
            option_id: 0,
            price: '',
            price_type: '',
            product_sku: '',
            sku: '',
            sort_order: 0,
            title: '',
            type: '',
            values: [
              {
                option_type_id: 0,
                price: '',
                price_type: '',
                sku: '',
                sort_order: 0,
                title: ''
              }
            ]
          }
        ],
        price: '',
        product_links: [
          {
            extension_attributes: {qty: ''},
            link_type: '',
            linked_product_sku: '',
            linked_product_type: '',
            position: 0,
            sku: ''
          }
        ],
        sku: '',
        status: 0,
        tier_prices: [
          {
            customer_group_id: 0,
            extension_attributes: {percentage_value: '', website_id: 0},
            qty: '',
            value: ''
          }
        ],
        type_id: '',
        updated_at: '',
        visibility: 0,
        weight: ''
      }
    ]
  },
  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}}/V1/sharedCatalog/:id/unassignProducts');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  products: [
    {
      attribute_set_id: 0,
      created_at: '',
      custom_attributes: [
        {
          attribute_code: '',
          value: ''
        }
      ],
      extension_attributes: {
        bundle_product_options: [
          {
            extension_attributes: {},
            option_id: 0,
            position: 0,
            product_links: [
              {
                can_change_quantity: 0,
                extension_attributes: {},
                id: '',
                is_default: false,
                option_id: 0,
                position: 0,
                price: '',
                price_type: 0,
                qty: '',
                sku: ''
              }
            ],
            required: false,
            sku: '',
            title: '',
            type: ''
          }
        ],
        category_links: [
          {
            category_id: '',
            extension_attributes: {},
            position: 0
          }
        ],
        configurable_product_links: [],
        configurable_product_options: [
          {
            attribute_id: '',
            extension_attributes: {},
            id: 0,
            is_use_default: false,
            label: '',
            position: 0,
            product_id: 0,
            values: [
              {
                extension_attributes: {},
                value_index: 0
              }
            ]
          }
        ],
        downloadable_product_links: [
          {
            extension_attributes: {},
            id: 0,
            is_shareable: 0,
            link_file: '',
            link_file_content: {
              extension_attributes: {},
              file_data: '',
              name: ''
            },
            link_type: '',
            link_url: '',
            number_of_downloads: 0,
            price: '',
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        downloadable_product_samples: [
          {
            extension_attributes: {},
            id: 0,
            sample_file: '',
            sample_file_content: {},
            sample_type: '',
            sample_url: '',
            sort_order: 0,
            title: ''
          }
        ],
        giftcard_amounts: [
          {
            attribute_id: 0,
            extension_attributes: {},
            value: '',
            website_id: 0,
            website_value: ''
          }
        ],
        stock_item: {
          backorders: 0,
          enable_qty_increments: false,
          extension_attributes: {},
          is_decimal_divided: false,
          is_in_stock: false,
          is_qty_decimal: false,
          item_id: 0,
          low_stock_date: '',
          manage_stock: false,
          max_sale_qty: '',
          min_qty: '',
          min_sale_qty: '',
          notify_stock_qty: '',
          product_id: 0,
          qty: '',
          qty_increments: '',
          show_default_notification_message: false,
          stock_id: 0,
          stock_status_changed_auto: 0,
          use_config_backorders: false,
          use_config_enable_qty_inc: false,
          use_config_manage_stock: false,
          use_config_max_sale_qty: false,
          use_config_min_qty: false,
          use_config_min_sale_qty: 0,
          use_config_notify_stock_qty: false,
          use_config_qty_increments: false
        },
        website_ids: []
      },
      id: 0,
      media_gallery_entries: [
        {
          content: {
            base64_encoded_data: '',
            name: '',
            type: ''
          },
          disabled: false,
          extension_attributes: {
            video_content: {
              media_type: '',
              video_description: '',
              video_metadata: '',
              video_provider: '',
              video_title: '',
              video_url: ''
            }
          },
          file: '',
          id: 0,
          label: '',
          media_type: '',
          position: 0,
          types: []
        }
      ],
      name: '',
      options: [
        {
          extension_attributes: {
            vertex_flex_field: ''
          },
          file_extension: '',
          image_size_x: 0,
          image_size_y: 0,
          is_require: false,
          max_characters: 0,
          option_id: 0,
          price: '',
          price_type: '',
          product_sku: '',
          sku: '',
          sort_order: 0,
          title: '',
          type: '',
          values: [
            {
              option_type_id: 0,
              price: '',
              price_type: '',
              sku: '',
              sort_order: 0,
              title: ''
            }
          ]
        }
      ],
      price: '',
      product_links: [
        {
          extension_attributes: {
            qty: ''
          },
          link_type: '',
          linked_product_sku: '',
          linked_product_type: '',
          position: 0,
          sku: ''
        }
      ],
      sku: '',
      status: 0,
      tier_prices: [
        {
          customer_group_id: 0,
          extension_attributes: {
            percentage_value: '',
            website_id: 0
          },
          qty: '',
          value: ''
        }
      ],
      type_id: '',
      updated_at: '',
      visibility: 0,
      weight: ''
    }
  ]
});

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}}/V1/sharedCatalog/:id/unassignProducts',
  headers: {'content-type': 'application/json'},
  data: {
    products: [
      {
        attribute_set_id: 0,
        created_at: '',
        custom_attributes: [{attribute_code: '', value: ''}],
        extension_attributes: {
          bundle_product_options: [
            {
              extension_attributes: {},
              option_id: 0,
              position: 0,
              product_links: [
                {
                  can_change_quantity: 0,
                  extension_attributes: {},
                  id: '',
                  is_default: false,
                  option_id: 0,
                  position: 0,
                  price: '',
                  price_type: 0,
                  qty: '',
                  sku: ''
                }
              ],
              required: false,
              sku: '',
              title: '',
              type: ''
            }
          ],
          category_links: [{category_id: '', extension_attributes: {}, position: 0}],
          configurable_product_links: [],
          configurable_product_options: [
            {
              attribute_id: '',
              extension_attributes: {},
              id: 0,
              is_use_default: false,
              label: '',
              position: 0,
              product_id: 0,
              values: [{extension_attributes: {}, value_index: 0}]
            }
          ],
          downloadable_product_links: [
            {
              extension_attributes: {},
              id: 0,
              is_shareable: 0,
              link_file: '',
              link_file_content: {extension_attributes: {}, file_data: '', name: ''},
              link_type: '',
              link_url: '',
              number_of_downloads: 0,
              price: '',
              sample_file: '',
              sample_file_content: {},
              sample_type: '',
              sample_url: '',
              sort_order: 0,
              title: ''
            }
          ],
          downloadable_product_samples: [
            {
              extension_attributes: {},
              id: 0,
              sample_file: '',
              sample_file_content: {},
              sample_type: '',
              sample_url: '',
              sort_order: 0,
              title: ''
            }
          ],
          giftcard_amounts: [
            {
              attribute_id: 0,
              extension_attributes: {},
              value: '',
              website_id: 0,
              website_value: ''
            }
          ],
          stock_item: {
            backorders: 0,
            enable_qty_increments: false,
            extension_attributes: {},
            is_decimal_divided: false,
            is_in_stock: false,
            is_qty_decimal: false,
            item_id: 0,
            low_stock_date: '',
            manage_stock: false,
            max_sale_qty: '',
            min_qty: '',
            min_sale_qty: '',
            notify_stock_qty: '',
            product_id: 0,
            qty: '',
            qty_increments: '',
            show_default_notification_message: false,
            stock_id: 0,
            stock_status_changed_auto: 0,
            use_config_backorders: false,
            use_config_enable_qty_inc: false,
            use_config_manage_stock: false,
            use_config_max_sale_qty: false,
            use_config_min_qty: false,
            use_config_min_sale_qty: 0,
            use_config_notify_stock_qty: false,
            use_config_qty_increments: false
          },
          website_ids: []
        },
        id: 0,
        media_gallery_entries: [
          {
            content: {base64_encoded_data: '', name: '', type: ''},
            disabled: false,
            extension_attributes: {
              video_content: {
                media_type: '',
                video_description: '',
                video_metadata: '',
                video_provider: '',
                video_title: '',
                video_url: ''
              }
            },
            file: '',
            id: 0,
            label: '',
            media_type: '',
            position: 0,
            types: []
          }
        ],
        name: '',
        options: [
          {
            extension_attributes: {vertex_flex_field: ''},
            file_extension: '',
            image_size_x: 0,
            image_size_y: 0,
            is_require: false,
            max_characters: 0,
            option_id: 0,
            price: '',
            price_type: '',
            product_sku: '',
            sku: '',
            sort_order: 0,
            title: '',
            type: '',
            values: [
              {
                option_type_id: 0,
                price: '',
                price_type: '',
                sku: '',
                sort_order: 0,
                title: ''
              }
            ]
          }
        ],
        price: '',
        product_links: [
          {
            extension_attributes: {qty: ''},
            link_type: '',
            linked_product_sku: '',
            linked_product_type: '',
            position: 0,
            sku: ''
          }
        ],
        sku: '',
        status: 0,
        tier_prices: [
          {
            customer_group_id: 0,
            extension_attributes: {percentage_value: '', website_id: 0},
            qty: '',
            value: ''
          }
        ],
        type_id: '',
        updated_at: '',
        visibility: 0,
        weight: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"products":[{"attribute_set_id":0,"created_at":"","custom_attributes":[{"attribute_code":"","value":""}],"extension_attributes":{"bundle_product_options":[{"extension_attributes":{},"option_id":0,"position":0,"product_links":[{"can_change_quantity":0,"extension_attributes":{},"id":"","is_default":false,"option_id":0,"position":0,"price":"","price_type":0,"qty":"","sku":""}],"required":false,"sku":"","title":"","type":""}],"category_links":[{"category_id":"","extension_attributes":{},"position":0}],"configurable_product_links":[],"configurable_product_options":[{"attribute_id":"","extension_attributes":{},"id":0,"is_use_default":false,"label":"","position":0,"product_id":0,"values":[{"extension_attributes":{},"value_index":0}]}],"downloadable_product_links":[{"extension_attributes":{},"id":0,"is_shareable":0,"link_file":"","link_file_content":{"extension_attributes":{},"file_data":"","name":""},"link_type":"","link_url":"","number_of_downloads":0,"price":"","sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"downloadable_product_samples":[{"extension_attributes":{},"id":0,"sample_file":"","sample_file_content":{},"sample_type":"","sample_url":"","sort_order":0,"title":""}],"giftcard_amounts":[{"attribute_id":0,"extension_attributes":{},"value":"","website_id":0,"website_value":""}],"stock_item":{"backorders":0,"enable_qty_increments":false,"extension_attributes":{},"is_decimal_divided":false,"is_in_stock":false,"is_qty_decimal":false,"item_id":0,"low_stock_date":"","manage_stock":false,"max_sale_qty":"","min_qty":"","min_sale_qty":"","notify_stock_qty":"","product_id":0,"qty":"","qty_increments":"","show_default_notification_message":false,"stock_id":0,"stock_status_changed_auto":0,"use_config_backorders":false,"use_config_enable_qty_inc":false,"use_config_manage_stock":false,"use_config_max_sale_qty":false,"use_config_min_qty":false,"use_config_min_sale_qty":0,"use_config_notify_stock_qty":false,"use_config_qty_increments":false},"website_ids":[]},"id":0,"media_gallery_entries":[{"content":{"base64_encoded_data":"","name":"","type":""},"disabled":false,"extension_attributes":{"video_content":{"media_type":"","video_description":"","video_metadata":"","video_provider":"","video_title":"","video_url":""}},"file":"","id":0,"label":"","media_type":"","position":0,"types":[]}],"name":"","options":[{"extension_attributes":{"vertex_flex_field":""},"file_extension":"","image_size_x":0,"image_size_y":0,"is_require":false,"max_characters":0,"option_id":0,"price":"","price_type":"","product_sku":"","sku":"","sort_order":0,"title":"","type":"","values":[{"option_type_id":0,"price":"","price_type":"","sku":"","sort_order":0,"title":""}]}],"price":"","product_links":[{"extension_attributes":{"qty":""},"link_type":"","linked_product_sku":"","linked_product_type":"","position":0,"sku":""}],"sku":"","status":0,"tier_prices":[{"customer_group_id":0,"extension_attributes":{"percentage_value":"","website_id":0},"qty":"","value":""}],"type_id":"","updated_at":"","visibility":0,"weight":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"products": @[ @{ @"attribute_set_id": @0, @"created_at": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"extension_attributes": @{ @"bundle_product_options": @[ @{ @"extension_attributes": @{  }, @"option_id": @0, @"position": @0, @"product_links": @[ @{ @"can_change_quantity": @0, @"extension_attributes": @{  }, @"id": @"", @"is_default": @NO, @"option_id": @0, @"position": @0, @"price": @"", @"price_type": @0, @"qty": @"", @"sku": @"" } ], @"required": @NO, @"sku": @"", @"title": @"", @"type": @"" } ], @"category_links": @[ @{ @"category_id": @"", @"extension_attributes": @{  }, @"position": @0 } ], @"configurable_product_links": @[  ], @"configurable_product_options": @[ @{ @"attribute_id": @"", @"extension_attributes": @{  }, @"id": @0, @"is_use_default": @NO, @"label": @"", @"position": @0, @"product_id": @0, @"values": @[ @{ @"extension_attributes": @{  }, @"value_index": @0 } ] } ], @"downloadable_product_links": @[ @{ @"extension_attributes": @{  }, @"id": @0, @"is_shareable": @0, @"link_file": @"", @"link_file_content": @{ @"extension_attributes": @{  }, @"file_data": @"", @"name": @"" }, @"link_type": @"", @"link_url": @"", @"number_of_downloads": @0, @"price": @"", @"sample_file": @"", @"sample_file_content": @{  }, @"sample_type": @"", @"sample_url": @"", @"sort_order": @0, @"title": @"" } ], @"downloadable_product_samples": @[ @{ @"extension_attributes": @{  }, @"id": @0, @"sample_file": @"", @"sample_file_content": @{  }, @"sample_type": @"", @"sample_url": @"", @"sort_order": @0, @"title": @"" } ], @"giftcard_amounts": @[ @{ @"attribute_id": @0, @"extension_attributes": @{  }, @"value": @"", @"website_id": @0, @"website_value": @"" } ], @"stock_item": @{ @"backorders": @0, @"enable_qty_increments": @NO, @"extension_attributes": @{  }, @"is_decimal_divided": @NO, @"is_in_stock": @NO, @"is_qty_decimal": @NO, @"item_id": @0, @"low_stock_date": @"", @"manage_stock": @NO, @"max_sale_qty": @"", @"min_qty": @"", @"min_sale_qty": @"", @"notify_stock_qty": @"", @"product_id": @0, @"qty": @"", @"qty_increments": @"", @"show_default_notification_message": @NO, @"stock_id": @0, @"stock_status_changed_auto": @0, @"use_config_backorders": @NO, @"use_config_enable_qty_inc": @NO, @"use_config_manage_stock": @NO, @"use_config_max_sale_qty": @NO, @"use_config_min_qty": @NO, @"use_config_min_sale_qty": @0, @"use_config_notify_stock_qty": @NO, @"use_config_qty_increments": @NO }, @"website_ids": @[  ] }, @"id": @0, @"media_gallery_entries": @[ @{ @"content": @{ @"base64_encoded_data": @"", @"name": @"", @"type": @"" }, @"disabled": @NO, @"extension_attributes": @{ @"video_content": @{ @"media_type": @"", @"video_description": @"", @"video_metadata": @"", @"video_provider": @"", @"video_title": @"", @"video_url": @"" } }, @"file": @"", @"id": @0, @"label": @"", @"media_type": @"", @"position": @0, @"types": @[  ] } ], @"name": @"", @"options": @[ @{ @"extension_attributes": @{ @"vertex_flex_field": @"" }, @"file_extension": @"", @"image_size_x": @0, @"image_size_y": @0, @"is_require": @NO, @"max_characters": @0, @"option_id": @0, @"price": @"", @"price_type": @"", @"product_sku": @"", @"sku": @"", @"sort_order": @0, @"title": @"", @"type": @"", @"values": @[ @{ @"option_type_id": @0, @"price": @"", @"price_type": @"", @"sku": @"", @"sort_order": @0, @"title": @"" } ] } ], @"price": @"", @"product_links": @[ @{ @"extension_attributes": @{ @"qty": @"" }, @"link_type": @"", @"linked_product_sku": @"", @"linked_product_type": @"", @"position": @0, @"sku": @"" } ], @"sku": @"", @"status": @0, @"tier_prices": @[ @{ @"customer_group_id": @0, @"extension_attributes": @{ @"percentage_value": @"", @"website_id": @0 }, @"qty": @"", @"value": @"" } ], @"type_id": @"", @"updated_at": @"", @"visibility": @0, @"weight": @"" } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts"]
                                                       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}}/V1/sharedCatalog/:id/unassignProducts" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts",
  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([
    'products' => [
        [
                'attribute_set_id' => 0,
                'created_at' => '',
                'custom_attributes' => [
                                [
                                                                'attribute_code' => '',
                                                                'value' => ''
                                ]
                ],
                'extension_attributes' => [
                                'bundle_product_options' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'option_id' => 0,
                                                                                                                                'position' => 0,
                                                                                                                                'product_links' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'can_change_quantity' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'id' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'is_default' => null,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'position' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'price_type' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'qty' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'sku' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'required' => null,
                                                                                                                                'sku' => '',
                                                                                                                                'title' => '',
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'category_links' => [
                                                                [
                                                                                                                                'category_id' => '',
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'position' => 0
                                                                ]
                                ],
                                'configurable_product_links' => [
                                                                
                                ],
                                'configurable_product_options' => [
                                                                [
                                                                                                                                'attribute_id' => '',
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'is_use_default' => null,
                                                                                                                                'label' => '',
                                                                                                                                'position' => 0,
                                                                                                                                'product_id' => 0,
                                                                                                                                'values' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'value_index' => 0
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ]
                                ],
                                'downloadable_product_links' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'is_shareable' => 0,
                                                                                                                                'link_file' => '',
                                                                                                                                'link_file_content' => [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'file_data' => '',
                                                                                                                                                                                                                                                                'name' => ''
                                                                                                                                ],
                                                                                                                                'link_type' => '',
                                                                                                                                'link_url' => '',
                                                                                                                                'number_of_downloads' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'sample_file' => '',
                                                                                                                                'sample_file_content' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'sample_type' => '',
                                                                                                                                'sample_url' => '',
                                                                                                                                'sort_order' => 0,
                                                                                                                                'title' => ''
                                                                ]
                                ],
                                'downloadable_product_samples' => [
                                                                [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'sample_file' => '',
                                                                                                                                'sample_file_content' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'sample_type' => '',
                                                                                                                                'sample_url' => '',
                                                                                                                                'sort_order' => 0,
                                                                                                                                'title' => ''
                                                                ]
                                ],
                                'giftcard_amounts' => [
                                                                [
                                                                                                                                'attribute_id' => 0,
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'value' => '',
                                                                                                                                'website_id' => 0,
                                                                                                                                'website_value' => ''
                                                                ]
                                ],
                                'stock_item' => [
                                                                'backorders' => 0,
                                                                'enable_qty_increments' => null,
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'is_decimal_divided' => null,
                                                                'is_in_stock' => null,
                                                                'is_qty_decimal' => null,
                                                                'item_id' => 0,
                                                                'low_stock_date' => '',
                                                                'manage_stock' => null,
                                                                'max_sale_qty' => '',
                                                                'min_qty' => '',
                                                                'min_sale_qty' => '',
                                                                'notify_stock_qty' => '',
                                                                'product_id' => 0,
                                                                'qty' => '',
                                                                'qty_increments' => '',
                                                                'show_default_notification_message' => null,
                                                                'stock_id' => 0,
                                                                'stock_status_changed_auto' => 0,
                                                                'use_config_backorders' => null,
                                                                'use_config_enable_qty_inc' => null,
                                                                'use_config_manage_stock' => null,
                                                                'use_config_max_sale_qty' => null,
                                                                'use_config_min_qty' => null,
                                                                'use_config_min_sale_qty' => 0,
                                                                'use_config_notify_stock_qty' => null,
                                                                'use_config_qty_increments' => null
                                ],
                                'website_ids' => [
                                                                
                                ]
                ],
                'id' => 0,
                'media_gallery_entries' => [
                                [
                                                                'content' => [
                                                                                                                                'base64_encoded_data' => '',
                                                                                                                                'name' => '',
                                                                                                                                'type' => ''
                                                                ],
                                                                'disabled' => null,
                                                                'extension_attributes' => [
                                                                                                                                'video_content' => [
                                                                                                                                                                                                                                                                'media_type' => '',
                                                                                                                                                                                                                                                                'video_description' => '',
                                                                                                                                                                                                                                                                'video_metadata' => '',
                                                                                                                                                                                                                                                                'video_provider' => '',
                                                                                                                                                                                                                                                                'video_title' => '',
                                                                                                                                                                                                                                                                'video_url' => ''
                                                                                                                                ]
                                                                ],
                                                                'file' => '',
                                                                'id' => 0,
                                                                'label' => '',
                                                                'media_type' => '',
                                                                'position' => 0,
                                                                'types' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'name' => '',
                'options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                'vertex_flex_field' => ''
                                                                ],
                                                                'file_extension' => '',
                                                                'image_size_x' => 0,
                                                                'image_size_y' => 0,
                                                                'is_require' => null,
                                                                'max_characters' => 0,
                                                                'option_id' => 0,
                                                                'price' => '',
                                                                'price_type' => '',
                                                                'product_sku' => '',
                                                                'sku' => '',
                                                                'sort_order' => 0,
                                                                'title' => '',
                                                                'type' => '',
                                                                'values' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'option_type_id' => 0,
                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                'price_type' => '',
                                                                                                                                                                                                                                                                'sku' => '',
                                                                                                                                                                                                                                                                'sort_order' => 0,
                                                                                                                                                                                                                                                                'title' => ''
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'price' => '',
                'product_links' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                'qty' => ''
                                                                ],
                                                                'link_type' => '',
                                                                'linked_product_sku' => '',
                                                                'linked_product_type' => '',
                                                                'position' => 0,
                                                                'sku' => ''
                                ]
                ],
                'sku' => '',
                'status' => 0,
                'tier_prices' => [
                                [
                                                                'customer_group_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                'percentage_value' => '',
                                                                                                                                'website_id' => 0
                                                                ],
                                                                'qty' => '',
                                                                'value' => ''
                                ]
                ],
                'type_id' => '',
                'updated_at' => '',
                'visibility' => 0,
                'weight' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts', [
  'body' => '{
  "products": [
    {
      "attribute_set_id": 0,
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {
        "bundle_product_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "position": 0,
            "product_links": [
              {
                "can_change_quantity": 0,
                "extension_attributes": {},
                "id": "",
                "is_default": false,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
              }
            ],
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
          }
        ],
        "category_links": [
          {
            "category_id": "",
            "extension_attributes": {},
            "position": 0
          }
        ],
        "configurable_product_links": [],
        "configurable_product_options": [
          {
            "attribute_id": "",
            "extension_attributes": {},
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": [
              {
                "extension_attributes": {},
                "value_index": 0
              }
            ]
          }
        ],
        "downloadable_product_links": [
          {
            "extension_attributes": {},
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": {
              "extension_attributes": {},
              "file_data": "",
              "name": ""
            },
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "downloadable_product_samples": [
          {
            "extension_attributes": {},
            "id": 0,
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "giftcard_amounts": [
          {
            "attribute_id": 0,
            "extension_attributes": {},
            "value": "",
            "website_id": 0,
            "website_value": ""
          }
        ],
        "stock_item": {
          "backorders": 0,
          "enable_qty_increments": false,
          "extension_attributes": {},
          "is_decimal_divided": false,
          "is_in_stock": false,
          "is_qty_decimal": false,
          "item_id": 0,
          "low_stock_date": "",
          "manage_stock": false,
          "max_sale_qty": "",
          "min_qty": "",
          "min_sale_qty": "",
          "notify_stock_qty": "",
          "product_id": 0,
          "qty": "",
          "qty_increments": "",
          "show_default_notification_message": false,
          "stock_id": 0,
          "stock_status_changed_auto": 0,
          "use_config_backorders": false,
          "use_config_enable_qty_inc": false,
          "use_config_manage_stock": false,
          "use_config_max_sale_qty": false,
          "use_config_min_qty": false,
          "use_config_min_sale_qty": 0,
          "use_config_notify_stock_qty": false,
          "use_config_qty_increments": false
        },
        "website_ids": []
      },
      "id": 0,
      "media_gallery_entries": [
        {
          "content": {
            "base64_encoded_data": "",
            "name": "",
            "type": ""
          },
          "disabled": false,
          "extension_attributes": {
            "video_content": {
              "media_type": "",
              "video_description": "",
              "video_metadata": "",
              "video_provider": "",
              "video_title": "",
              "video_url": ""
            }
          },
          "file": "",
          "id": 0,
          "label": "",
          "media_type": "",
          "position": 0,
          "types": []
        }
      ],
      "name": "",
      "options": [
        {
          "extension_attributes": {
            "vertex_flex_field": ""
          },
          "file_extension": "",
          "image_size_x": 0,
          "image_size_y": 0,
          "is_require": false,
          "max_characters": 0,
          "option_id": 0,
          "price": "",
          "price_type": "",
          "product_sku": "",
          "sku": "",
          "sort_order": 0,
          "title": "",
          "type": "",
          "values": [
            {
              "option_type_id": 0,
              "price": "",
              "price_type": "",
              "sku": "",
              "sort_order": 0,
              "title": ""
            }
          ]
        }
      ],
      "price": "",
      "product_links": [
        {
          "extension_attributes": {
            "qty": ""
          },
          "link_type": "",
          "linked_product_sku": "",
          "linked_product_type": "",
          "position": 0,
          "sku": ""
        }
      ],
      "sku": "",
      "status": 0,
      "tier_prices": [
        {
          "customer_group_id": 0,
          "extension_attributes": {
            "percentage_value": "",
            "website_id": 0
          },
          "qty": "",
          "value": ""
        }
      ],
      "type_id": "",
      "updated_at": "",
      "visibility": 0,
      "weight": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'products' => [
    [
        'attribute_set_id' => 0,
        'created_at' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'extension_attributes' => [
                'bundle_product_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'position' => 0,
                                                                'product_links' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'can_change_quantity' => 0,
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'id' => '',
                                                                                                                                                                                                                                                                'is_default' => null,
                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                'position' => 0,
                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                'price_type' => 0,
                                                                                                                                                                                                                                                                'qty' => '',
                                                                                                                                                                                                                                                                'sku' => ''
                                                                                                                                ]
                                                                ],
                                                                'required' => null,
                                                                'sku' => '',
                                                                'title' => '',
                                                                'type' => ''
                                ]
                ],
                'category_links' => [
                                [
                                                                'category_id' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'position' => 0
                                ]
                ],
                'configurable_product_links' => [
                                
                ],
                'configurable_product_options' => [
                                [
                                                                'attribute_id' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'is_use_default' => null,
                                                                'label' => '',
                                                                'position' => 0,
                                                                'product_id' => 0,
                                                                'values' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'value_index' => 0
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'downloadable_product_links' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'is_shareable' => 0,
                                                                'link_file' => '',
                                                                'link_file_content' => [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'file_data' => '',
                                                                                                                                'name' => ''
                                                                ],
                                                                'link_type' => '',
                                                                'link_url' => '',
                                                                'number_of_downloads' => 0,
                                                                'price' => '',
                                                                'sample_file' => '',
                                                                'sample_file_content' => [
                                                                                                                                
                                                                ],
                                                                'sample_type' => '',
                                                                'sample_url' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ],
                'downloadable_product_samples' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'sample_file' => '',
                                                                'sample_file_content' => [
                                                                                                                                
                                                                ],
                                                                'sample_type' => '',
                                                                'sample_url' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ],
                'giftcard_amounts' => [
                                [
                                                                'attribute_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'value' => '',
                                                                'website_id' => 0,
                                                                'website_value' => ''
                                ]
                ],
                'stock_item' => [
                                'backorders' => 0,
                                'enable_qty_increments' => null,
                                'extension_attributes' => [
                                                                
                                ],
                                'is_decimal_divided' => null,
                                'is_in_stock' => null,
                                'is_qty_decimal' => null,
                                'item_id' => 0,
                                'low_stock_date' => '',
                                'manage_stock' => null,
                                'max_sale_qty' => '',
                                'min_qty' => '',
                                'min_sale_qty' => '',
                                'notify_stock_qty' => '',
                                'product_id' => 0,
                                'qty' => '',
                                'qty_increments' => '',
                                'show_default_notification_message' => null,
                                'stock_id' => 0,
                                'stock_status_changed_auto' => 0,
                                'use_config_backorders' => null,
                                'use_config_enable_qty_inc' => null,
                                'use_config_manage_stock' => null,
                                'use_config_max_sale_qty' => null,
                                'use_config_min_qty' => null,
                                'use_config_min_sale_qty' => 0,
                                'use_config_notify_stock_qty' => null,
                                'use_config_qty_increments' => null
                ],
                'website_ids' => [
                                
                ]
        ],
        'id' => 0,
        'media_gallery_entries' => [
                [
                                'content' => [
                                                                'base64_encoded_data' => '',
                                                                'name' => '',
                                                                'type' => ''
                                ],
                                'disabled' => null,
                                'extension_attributes' => [
                                                                'video_content' => [
                                                                                                                                'media_type' => '',
                                                                                                                                'video_description' => '',
                                                                                                                                'video_metadata' => '',
                                                                                                                                'video_provider' => '',
                                                                                                                                'video_title' => '',
                                                                                                                                'video_url' => ''
                                                                ]
                                ],
                                'file' => '',
                                'id' => 0,
                                'label' => '',
                                'media_type' => '',
                                'position' => 0,
                                'types' => [
                                                                
                                ]
                ]
        ],
        'name' => '',
        'options' => [
                [
                                'extension_attributes' => [
                                                                'vertex_flex_field' => ''
                                ],
                                'file_extension' => '',
                                'image_size_x' => 0,
                                'image_size_y' => 0,
                                'is_require' => null,
                                'max_characters' => 0,
                                'option_id' => 0,
                                'price' => '',
                                'price_type' => '',
                                'product_sku' => '',
                                'sku' => '',
                                'sort_order' => 0,
                                'title' => '',
                                'type' => '',
                                'values' => [
                                                                [
                                                                                                                                'option_type_id' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'price_type' => '',
                                                                                                                                'sku' => '',
                                                                                                                                'sort_order' => 0,
                                                                                                                                'title' => ''
                                                                ]
                                ]
                ]
        ],
        'price' => '',
        'product_links' => [
                [
                                'extension_attributes' => [
                                                                'qty' => ''
                                ],
                                'link_type' => '',
                                'linked_product_sku' => '',
                                'linked_product_type' => '',
                                'position' => 0,
                                'sku' => ''
                ]
        ],
        'sku' => '',
        'status' => 0,
        'tier_prices' => [
                [
                                'customer_group_id' => 0,
                                'extension_attributes' => [
                                                                'percentage_value' => '',
                                                                'website_id' => 0
                                ],
                                'qty' => '',
                                'value' => ''
                ]
        ],
        'type_id' => '',
        'updated_at' => '',
        'visibility' => 0,
        'weight' => ''
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'products' => [
    [
        'attribute_set_id' => 0,
        'created_at' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'extension_attributes' => [
                'bundle_product_options' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'option_id' => 0,
                                                                'position' => 0,
                                                                'product_links' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'can_change_quantity' => 0,
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'id' => '',
                                                                                                                                                                                                                                                                'is_default' => null,
                                                                                                                                                                                                                                                                'option_id' => 0,
                                                                                                                                                                                                                                                                'position' => 0,
                                                                                                                                                                                                                                                                'price' => '',
                                                                                                                                                                                                                                                                'price_type' => 0,
                                                                                                                                                                                                                                                                'qty' => '',
                                                                                                                                                                                                                                                                'sku' => ''
                                                                                                                                ]
                                                                ],
                                                                'required' => null,
                                                                'sku' => '',
                                                                'title' => '',
                                                                'type' => ''
                                ]
                ],
                'category_links' => [
                                [
                                                                'category_id' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'position' => 0
                                ]
                ],
                'configurable_product_links' => [
                                
                ],
                'configurable_product_options' => [
                                [
                                                                'attribute_id' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'is_use_default' => null,
                                                                'label' => '',
                                                                'position' => 0,
                                                                'product_id' => 0,
                                                                'values' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'value_index' => 0
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'downloadable_product_links' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'is_shareable' => 0,
                                                                'link_file' => '',
                                                                'link_file_content' => [
                                                                                                                                'extension_attributes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'file_data' => '',
                                                                                                                                'name' => ''
                                                                ],
                                                                'link_type' => '',
                                                                'link_url' => '',
                                                                'number_of_downloads' => 0,
                                                                'price' => '',
                                                                'sample_file' => '',
                                                                'sample_file_content' => [
                                                                                                                                
                                                                ],
                                                                'sample_type' => '',
                                                                'sample_url' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ],
                'downloadable_product_samples' => [
                                [
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'sample_file' => '',
                                                                'sample_file_content' => [
                                                                                                                                
                                                                ],
                                                                'sample_type' => '',
                                                                'sample_url' => '',
                                                                'sort_order' => 0,
                                                                'title' => ''
                                ]
                ],
                'giftcard_amounts' => [
                                [
                                                                'attribute_id' => 0,
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'value' => '',
                                                                'website_id' => 0,
                                                                'website_value' => ''
                                ]
                ],
                'stock_item' => [
                                'backorders' => 0,
                                'enable_qty_increments' => null,
                                'extension_attributes' => [
                                                                
                                ],
                                'is_decimal_divided' => null,
                                'is_in_stock' => null,
                                'is_qty_decimal' => null,
                                'item_id' => 0,
                                'low_stock_date' => '',
                                'manage_stock' => null,
                                'max_sale_qty' => '',
                                'min_qty' => '',
                                'min_sale_qty' => '',
                                'notify_stock_qty' => '',
                                'product_id' => 0,
                                'qty' => '',
                                'qty_increments' => '',
                                'show_default_notification_message' => null,
                                'stock_id' => 0,
                                'stock_status_changed_auto' => 0,
                                'use_config_backorders' => null,
                                'use_config_enable_qty_inc' => null,
                                'use_config_manage_stock' => null,
                                'use_config_max_sale_qty' => null,
                                'use_config_min_qty' => null,
                                'use_config_min_sale_qty' => 0,
                                'use_config_notify_stock_qty' => null,
                                'use_config_qty_increments' => null
                ],
                'website_ids' => [
                                
                ]
        ],
        'id' => 0,
        'media_gallery_entries' => [
                [
                                'content' => [
                                                                'base64_encoded_data' => '',
                                                                'name' => '',
                                                                'type' => ''
                                ],
                                'disabled' => null,
                                'extension_attributes' => [
                                                                'video_content' => [
                                                                                                                                'media_type' => '',
                                                                                                                                'video_description' => '',
                                                                                                                                'video_metadata' => '',
                                                                                                                                'video_provider' => '',
                                                                                                                                'video_title' => '',
                                                                                                                                'video_url' => ''
                                                                ]
                                ],
                                'file' => '',
                                'id' => 0,
                                'label' => '',
                                'media_type' => '',
                                'position' => 0,
                                'types' => [
                                                                
                                ]
                ]
        ],
        'name' => '',
        'options' => [
                [
                                'extension_attributes' => [
                                                                'vertex_flex_field' => ''
                                ],
                                'file_extension' => '',
                                'image_size_x' => 0,
                                'image_size_y' => 0,
                                'is_require' => null,
                                'max_characters' => 0,
                                'option_id' => 0,
                                'price' => '',
                                'price_type' => '',
                                'product_sku' => '',
                                'sku' => '',
                                'sort_order' => 0,
                                'title' => '',
                                'type' => '',
                                'values' => [
                                                                [
                                                                                                                                'option_type_id' => 0,
                                                                                                                                'price' => '',
                                                                                                                                'price_type' => '',
                                                                                                                                'sku' => '',
                                                                                                                                'sort_order' => 0,
                                                                                                                                'title' => ''
                                                                ]
                                ]
                ]
        ],
        'price' => '',
        'product_links' => [
                [
                                'extension_attributes' => [
                                                                'qty' => ''
                                ],
                                'link_type' => '',
                                'linked_product_sku' => '',
                                'linked_product_type' => '',
                                'position' => 0,
                                'sku' => ''
                ]
        ],
        'sku' => '',
        'status' => 0,
        'tier_prices' => [
                [
                                'customer_group_id' => 0,
                                'extension_attributes' => [
                                                                'percentage_value' => '',
                                                                'website_id' => 0
                                ],
                                'qty' => '',
                                'value' => ''
                ]
        ],
        'type_id' => '',
        'updated_at' => '',
        'visibility' => 0,
        'weight' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "products": [
    {
      "attribute_set_id": 0,
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {
        "bundle_product_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "position": 0,
            "product_links": [
              {
                "can_change_quantity": 0,
                "extension_attributes": {},
                "id": "",
                "is_default": false,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
              }
            ],
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
          }
        ],
        "category_links": [
          {
            "category_id": "",
            "extension_attributes": {},
            "position": 0
          }
        ],
        "configurable_product_links": [],
        "configurable_product_options": [
          {
            "attribute_id": "",
            "extension_attributes": {},
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": [
              {
                "extension_attributes": {},
                "value_index": 0
              }
            ]
          }
        ],
        "downloadable_product_links": [
          {
            "extension_attributes": {},
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": {
              "extension_attributes": {},
              "file_data": "",
              "name": ""
            },
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "downloadable_product_samples": [
          {
            "extension_attributes": {},
            "id": 0,
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "giftcard_amounts": [
          {
            "attribute_id": 0,
            "extension_attributes": {},
            "value": "",
            "website_id": 0,
            "website_value": ""
          }
        ],
        "stock_item": {
          "backorders": 0,
          "enable_qty_increments": false,
          "extension_attributes": {},
          "is_decimal_divided": false,
          "is_in_stock": false,
          "is_qty_decimal": false,
          "item_id": 0,
          "low_stock_date": "",
          "manage_stock": false,
          "max_sale_qty": "",
          "min_qty": "",
          "min_sale_qty": "",
          "notify_stock_qty": "",
          "product_id": 0,
          "qty": "",
          "qty_increments": "",
          "show_default_notification_message": false,
          "stock_id": 0,
          "stock_status_changed_auto": 0,
          "use_config_backorders": false,
          "use_config_enable_qty_inc": false,
          "use_config_manage_stock": false,
          "use_config_max_sale_qty": false,
          "use_config_min_qty": false,
          "use_config_min_sale_qty": 0,
          "use_config_notify_stock_qty": false,
          "use_config_qty_increments": false
        },
        "website_ids": []
      },
      "id": 0,
      "media_gallery_entries": [
        {
          "content": {
            "base64_encoded_data": "",
            "name": "",
            "type": ""
          },
          "disabled": false,
          "extension_attributes": {
            "video_content": {
              "media_type": "",
              "video_description": "",
              "video_metadata": "",
              "video_provider": "",
              "video_title": "",
              "video_url": ""
            }
          },
          "file": "",
          "id": 0,
          "label": "",
          "media_type": "",
          "position": 0,
          "types": []
        }
      ],
      "name": "",
      "options": [
        {
          "extension_attributes": {
            "vertex_flex_field": ""
          },
          "file_extension": "",
          "image_size_x": 0,
          "image_size_y": 0,
          "is_require": false,
          "max_characters": 0,
          "option_id": 0,
          "price": "",
          "price_type": "",
          "product_sku": "",
          "sku": "",
          "sort_order": 0,
          "title": "",
          "type": "",
          "values": [
            {
              "option_type_id": 0,
              "price": "",
              "price_type": "",
              "sku": "",
              "sort_order": 0,
              "title": ""
            }
          ]
        }
      ],
      "price": "",
      "product_links": [
        {
          "extension_attributes": {
            "qty": ""
          },
          "link_type": "",
          "linked_product_sku": "",
          "linked_product_type": "",
          "position": 0,
          "sku": ""
        }
      ],
      "sku": "",
      "status": 0,
      "tier_prices": [
        {
          "customer_group_id": 0,
          "extension_attributes": {
            "percentage_value": "",
            "website_id": 0
          },
          "qty": "",
          "value": ""
        }
      ],
      "type_id": "",
      "updated_at": "",
      "visibility": 0,
      "weight": ""
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "products": [
    {
      "attribute_set_id": 0,
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {
        "bundle_product_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "position": 0,
            "product_links": [
              {
                "can_change_quantity": 0,
                "extension_attributes": {},
                "id": "",
                "is_default": false,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
              }
            ],
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
          }
        ],
        "category_links": [
          {
            "category_id": "",
            "extension_attributes": {},
            "position": 0
          }
        ],
        "configurable_product_links": [],
        "configurable_product_options": [
          {
            "attribute_id": "",
            "extension_attributes": {},
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": [
              {
                "extension_attributes": {},
                "value_index": 0
              }
            ]
          }
        ],
        "downloadable_product_links": [
          {
            "extension_attributes": {},
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": {
              "extension_attributes": {},
              "file_data": "",
              "name": ""
            },
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "downloadable_product_samples": [
          {
            "extension_attributes": {},
            "id": 0,
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "giftcard_amounts": [
          {
            "attribute_id": 0,
            "extension_attributes": {},
            "value": "",
            "website_id": 0,
            "website_value": ""
          }
        ],
        "stock_item": {
          "backorders": 0,
          "enable_qty_increments": false,
          "extension_attributes": {},
          "is_decimal_divided": false,
          "is_in_stock": false,
          "is_qty_decimal": false,
          "item_id": 0,
          "low_stock_date": "",
          "manage_stock": false,
          "max_sale_qty": "",
          "min_qty": "",
          "min_sale_qty": "",
          "notify_stock_qty": "",
          "product_id": 0,
          "qty": "",
          "qty_increments": "",
          "show_default_notification_message": false,
          "stock_id": 0,
          "stock_status_changed_auto": 0,
          "use_config_backorders": false,
          "use_config_enable_qty_inc": false,
          "use_config_manage_stock": false,
          "use_config_max_sale_qty": false,
          "use_config_min_qty": false,
          "use_config_min_sale_qty": 0,
          "use_config_notify_stock_qty": false,
          "use_config_qty_increments": false
        },
        "website_ids": []
      },
      "id": 0,
      "media_gallery_entries": [
        {
          "content": {
            "base64_encoded_data": "",
            "name": "",
            "type": ""
          },
          "disabled": false,
          "extension_attributes": {
            "video_content": {
              "media_type": "",
              "video_description": "",
              "video_metadata": "",
              "video_provider": "",
              "video_title": "",
              "video_url": ""
            }
          },
          "file": "",
          "id": 0,
          "label": "",
          "media_type": "",
          "position": 0,
          "types": []
        }
      ],
      "name": "",
      "options": [
        {
          "extension_attributes": {
            "vertex_flex_field": ""
          },
          "file_extension": "",
          "image_size_x": 0,
          "image_size_y": 0,
          "is_require": false,
          "max_characters": 0,
          "option_id": 0,
          "price": "",
          "price_type": "",
          "product_sku": "",
          "sku": "",
          "sort_order": 0,
          "title": "",
          "type": "",
          "values": [
            {
              "option_type_id": 0,
              "price": "",
              "price_type": "",
              "sku": "",
              "sort_order": 0,
              "title": ""
            }
          ]
        }
      ],
      "price": "",
      "product_links": [
        {
          "extension_attributes": {
            "qty": ""
          },
          "link_type": "",
          "linked_product_sku": "",
          "linked_product_type": "",
          "position": 0,
          "sku": ""
        }
      ],
      "sku": "",
      "status": 0,
      "tier_prices": [
        {
          "customer_group_id": 0,
          "extension_attributes": {
            "percentage_value": "",
            "website_id": 0
          },
          "qty": "",
          "value": ""
        }
      ],
      "type_id": "",
      "updated_at": "",
      "visibility": 0,
      "weight": ""
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/sharedCatalog/:id/unassignProducts", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts"

payload = { "products": [
        {
            "attribute_set_id": 0,
            "created_at": "",
            "custom_attributes": [
                {
                    "attribute_code": "",
                    "value": ""
                }
            ],
            "extension_attributes": {
                "bundle_product_options": [
                    {
                        "extension_attributes": {},
                        "option_id": 0,
                        "position": 0,
                        "product_links": [
                            {
                                "can_change_quantity": 0,
                                "extension_attributes": {},
                                "id": "",
                                "is_default": False,
                                "option_id": 0,
                                "position": 0,
                                "price": "",
                                "price_type": 0,
                                "qty": "",
                                "sku": ""
                            }
                        ],
                        "required": False,
                        "sku": "",
                        "title": "",
                        "type": ""
                    }
                ],
                "category_links": [
                    {
                        "category_id": "",
                        "extension_attributes": {},
                        "position": 0
                    }
                ],
                "configurable_product_links": [],
                "configurable_product_options": [
                    {
                        "attribute_id": "",
                        "extension_attributes": {},
                        "id": 0,
                        "is_use_default": False,
                        "label": "",
                        "position": 0,
                        "product_id": 0,
                        "values": [
                            {
                                "extension_attributes": {},
                                "value_index": 0
                            }
                        ]
                    }
                ],
                "downloadable_product_links": [
                    {
                        "extension_attributes": {},
                        "id": 0,
                        "is_shareable": 0,
                        "link_file": "",
                        "link_file_content": {
                            "extension_attributes": {},
                            "file_data": "",
                            "name": ""
                        },
                        "link_type": "",
                        "link_url": "",
                        "number_of_downloads": 0,
                        "price": "",
                        "sample_file": "",
                        "sample_file_content": {},
                        "sample_type": "",
                        "sample_url": "",
                        "sort_order": 0,
                        "title": ""
                    }
                ],
                "downloadable_product_samples": [
                    {
                        "extension_attributes": {},
                        "id": 0,
                        "sample_file": "",
                        "sample_file_content": {},
                        "sample_type": "",
                        "sample_url": "",
                        "sort_order": 0,
                        "title": ""
                    }
                ],
                "giftcard_amounts": [
                    {
                        "attribute_id": 0,
                        "extension_attributes": {},
                        "value": "",
                        "website_id": 0,
                        "website_value": ""
                    }
                ],
                "stock_item": {
                    "backorders": 0,
                    "enable_qty_increments": False,
                    "extension_attributes": {},
                    "is_decimal_divided": False,
                    "is_in_stock": False,
                    "is_qty_decimal": False,
                    "item_id": 0,
                    "low_stock_date": "",
                    "manage_stock": False,
                    "max_sale_qty": "",
                    "min_qty": "",
                    "min_sale_qty": "",
                    "notify_stock_qty": "",
                    "product_id": 0,
                    "qty": "",
                    "qty_increments": "",
                    "show_default_notification_message": False,
                    "stock_id": 0,
                    "stock_status_changed_auto": 0,
                    "use_config_backorders": False,
                    "use_config_enable_qty_inc": False,
                    "use_config_manage_stock": False,
                    "use_config_max_sale_qty": False,
                    "use_config_min_qty": False,
                    "use_config_min_sale_qty": 0,
                    "use_config_notify_stock_qty": False,
                    "use_config_qty_increments": False
                },
                "website_ids": []
            },
            "id": 0,
            "media_gallery_entries": [
                {
                    "content": {
                        "base64_encoded_data": "",
                        "name": "",
                        "type": ""
                    },
                    "disabled": False,
                    "extension_attributes": { "video_content": {
                            "media_type": "",
                            "video_description": "",
                            "video_metadata": "",
                            "video_provider": "",
                            "video_title": "",
                            "video_url": ""
                        } },
                    "file": "",
                    "id": 0,
                    "label": "",
                    "media_type": "",
                    "position": 0,
                    "types": []
                }
            ],
            "name": "",
            "options": [
                {
                    "extension_attributes": { "vertex_flex_field": "" },
                    "file_extension": "",
                    "image_size_x": 0,
                    "image_size_y": 0,
                    "is_require": False,
                    "max_characters": 0,
                    "option_id": 0,
                    "price": "",
                    "price_type": "",
                    "product_sku": "",
                    "sku": "",
                    "sort_order": 0,
                    "title": "",
                    "type": "",
                    "values": [
                        {
                            "option_type_id": 0,
                            "price": "",
                            "price_type": "",
                            "sku": "",
                            "sort_order": 0,
                            "title": ""
                        }
                    ]
                }
            ],
            "price": "",
            "product_links": [
                {
                    "extension_attributes": { "qty": "" },
                    "link_type": "",
                    "linked_product_sku": "",
                    "linked_product_type": "",
                    "position": 0,
                    "sku": ""
                }
            ],
            "sku": "",
            "status": 0,
            "tier_prices": [
                {
                    "customer_group_id": 0,
                    "extension_attributes": {
                        "percentage_value": "",
                        "website_id": 0
                    },
                    "qty": "",
                    "value": ""
                }
            ],
            "type_id": "",
            "updated_at": "",
            "visibility": 0,
            "weight": ""
        }
    ] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts"

payload <- "{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\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/V1/sharedCatalog/:id/unassignProducts') do |req|
  req.body = "{\n  \"products\": [\n    {\n      \"attribute_set_id\": 0,\n      \"created_at\": \"\",\n      \"custom_attributes\": [\n        {\n          \"attribute_code\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"extension_attributes\": {\n        \"bundle_product_options\": [\n          {\n            \"extension_attributes\": {},\n            \"option_id\": 0,\n            \"position\": 0,\n            \"product_links\": [\n              {\n                \"can_change_quantity\": 0,\n                \"extension_attributes\": {},\n                \"id\": \"\",\n                \"is_default\": false,\n                \"option_id\": 0,\n                \"position\": 0,\n                \"price\": \"\",\n                \"price_type\": 0,\n                \"qty\": \"\",\n                \"sku\": \"\"\n              }\n            ],\n            \"required\": false,\n            \"sku\": \"\",\n            \"title\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"category_links\": [\n          {\n            \"category_id\": \"\",\n            \"extension_attributes\": {},\n            \"position\": 0\n          }\n        ],\n        \"configurable_product_links\": [],\n        \"configurable_product_options\": [\n          {\n            \"attribute_id\": \"\",\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_use_default\": false,\n            \"label\": \"\",\n            \"position\": 0,\n            \"product_id\": 0,\n            \"values\": [\n              {\n                \"extension_attributes\": {},\n                \"value_index\": 0\n              }\n            ]\n          }\n        ],\n        \"downloadable_product_links\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"is_shareable\": 0,\n            \"link_file\": \"\",\n            \"link_file_content\": {\n              \"extension_attributes\": {},\n              \"file_data\": \"\",\n              \"name\": \"\"\n            },\n            \"link_type\": \"\",\n            \"link_url\": \"\",\n            \"number_of_downloads\": 0,\n            \"price\": \"\",\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"downloadable_product_samples\": [\n          {\n            \"extension_attributes\": {},\n            \"id\": 0,\n            \"sample_file\": \"\",\n            \"sample_file_content\": {},\n            \"sample_type\": \"\",\n            \"sample_url\": \"\",\n            \"sort_order\": 0,\n            \"title\": \"\"\n          }\n        ],\n        \"giftcard_amounts\": [\n          {\n            \"attribute_id\": 0,\n            \"extension_attributes\": {},\n            \"value\": \"\",\n            \"website_id\": 0,\n            \"website_value\": \"\"\n          }\n        ],\n        \"stock_item\": {\n          \"backorders\": 0,\n          \"enable_qty_increments\": false,\n          \"extension_attributes\": {},\n          \"is_decimal_divided\": false,\n          \"is_in_stock\": false,\n          \"is_qty_decimal\": false,\n          \"item_id\": 0,\n          \"low_stock_date\": \"\",\n          \"manage_stock\": false,\n          \"max_sale_qty\": \"\",\n          \"min_qty\": \"\",\n          \"min_sale_qty\": \"\",\n          \"notify_stock_qty\": \"\",\n          \"product_id\": 0,\n          \"qty\": \"\",\n          \"qty_increments\": \"\",\n          \"show_default_notification_message\": false,\n          \"stock_id\": 0,\n          \"stock_status_changed_auto\": 0,\n          \"use_config_backorders\": false,\n          \"use_config_enable_qty_inc\": false,\n          \"use_config_manage_stock\": false,\n          \"use_config_max_sale_qty\": false,\n          \"use_config_min_qty\": false,\n          \"use_config_min_sale_qty\": 0,\n          \"use_config_notify_stock_qty\": false,\n          \"use_config_qty_increments\": false\n        },\n        \"website_ids\": []\n      },\n      \"id\": 0,\n      \"media_gallery_entries\": [\n        {\n          \"content\": {\n            \"base64_encoded_data\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          },\n          \"disabled\": false,\n          \"extension_attributes\": {\n            \"video_content\": {\n              \"media_type\": \"\",\n              \"video_description\": \"\",\n              \"video_metadata\": \"\",\n              \"video_provider\": \"\",\n              \"video_title\": \"\",\n              \"video_url\": \"\"\n            }\n          },\n          \"file\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"media_type\": \"\",\n          \"position\": 0,\n          \"types\": []\n        }\n      ],\n      \"name\": \"\",\n      \"options\": [\n        {\n          \"extension_attributes\": {\n            \"vertex_flex_field\": \"\"\n          },\n          \"file_extension\": \"\",\n          \"image_size_x\": 0,\n          \"image_size_y\": 0,\n          \"is_require\": false,\n          \"max_characters\": 0,\n          \"option_id\": 0,\n          \"price\": \"\",\n          \"price_type\": \"\",\n          \"product_sku\": \"\",\n          \"sku\": \"\",\n          \"sort_order\": 0,\n          \"title\": \"\",\n          \"type\": \"\",\n          \"values\": [\n            {\n              \"option_type_id\": 0,\n              \"price\": \"\",\n              \"price_type\": \"\",\n              \"sku\": \"\",\n              \"sort_order\": 0,\n              \"title\": \"\"\n            }\n          ]\n        }\n      ],\n      \"price\": \"\",\n      \"product_links\": [\n        {\n          \"extension_attributes\": {\n            \"qty\": \"\"\n          },\n          \"link_type\": \"\",\n          \"linked_product_sku\": \"\",\n          \"linked_product_type\": \"\",\n          \"position\": 0,\n          \"sku\": \"\"\n        }\n      ],\n      \"sku\": \"\",\n      \"status\": 0,\n      \"tier_prices\": [\n        {\n          \"customer_group_id\": 0,\n          \"extension_attributes\": {\n            \"percentage_value\": \"\",\n            \"website_id\": 0\n          },\n          \"qty\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"type_id\": \"\",\n      \"updated_at\": \"\",\n      \"visibility\": 0,\n      \"weight\": \"\"\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}}/V1/sharedCatalog/:id/unassignProducts";

    let payload = json!({"products": (
            json!({
                "attribute_set_id": 0,
                "created_at": "",
                "custom_attributes": (
                    json!({
                        "attribute_code": "",
                        "value": ""
                    })
                ),
                "extension_attributes": json!({
                    "bundle_product_options": (
                        json!({
                            "extension_attributes": json!({}),
                            "option_id": 0,
                            "position": 0,
                            "product_links": (
                                json!({
                                    "can_change_quantity": 0,
                                    "extension_attributes": json!({}),
                                    "id": "",
                                    "is_default": false,
                                    "option_id": 0,
                                    "position": 0,
                                    "price": "",
                                    "price_type": 0,
                                    "qty": "",
                                    "sku": ""
                                })
                            ),
                            "required": false,
                            "sku": "",
                            "title": "",
                            "type": ""
                        })
                    ),
                    "category_links": (
                        json!({
                            "category_id": "",
                            "extension_attributes": json!({}),
                            "position": 0
                        })
                    ),
                    "configurable_product_links": (),
                    "configurable_product_options": (
                        json!({
                            "attribute_id": "",
                            "extension_attributes": json!({}),
                            "id": 0,
                            "is_use_default": false,
                            "label": "",
                            "position": 0,
                            "product_id": 0,
                            "values": (
                                json!({
                                    "extension_attributes": json!({}),
                                    "value_index": 0
                                })
                            )
                        })
                    ),
                    "downloadable_product_links": (
                        json!({
                            "extension_attributes": json!({}),
                            "id": 0,
                            "is_shareable": 0,
                            "link_file": "",
                            "link_file_content": json!({
                                "extension_attributes": json!({}),
                                "file_data": "",
                                "name": ""
                            }),
                            "link_type": "",
                            "link_url": "",
                            "number_of_downloads": 0,
                            "price": "",
                            "sample_file": "",
                            "sample_file_content": json!({}),
                            "sample_type": "",
                            "sample_url": "",
                            "sort_order": 0,
                            "title": ""
                        })
                    ),
                    "downloadable_product_samples": (
                        json!({
                            "extension_attributes": json!({}),
                            "id": 0,
                            "sample_file": "",
                            "sample_file_content": json!({}),
                            "sample_type": "",
                            "sample_url": "",
                            "sort_order": 0,
                            "title": ""
                        })
                    ),
                    "giftcard_amounts": (
                        json!({
                            "attribute_id": 0,
                            "extension_attributes": json!({}),
                            "value": "",
                            "website_id": 0,
                            "website_value": ""
                        })
                    ),
                    "stock_item": json!({
                        "backorders": 0,
                        "enable_qty_increments": false,
                        "extension_attributes": json!({}),
                        "is_decimal_divided": false,
                        "is_in_stock": false,
                        "is_qty_decimal": false,
                        "item_id": 0,
                        "low_stock_date": "",
                        "manage_stock": false,
                        "max_sale_qty": "",
                        "min_qty": "",
                        "min_sale_qty": "",
                        "notify_stock_qty": "",
                        "product_id": 0,
                        "qty": "",
                        "qty_increments": "",
                        "show_default_notification_message": false,
                        "stock_id": 0,
                        "stock_status_changed_auto": 0,
                        "use_config_backorders": false,
                        "use_config_enable_qty_inc": false,
                        "use_config_manage_stock": false,
                        "use_config_max_sale_qty": false,
                        "use_config_min_qty": false,
                        "use_config_min_sale_qty": 0,
                        "use_config_notify_stock_qty": false,
                        "use_config_qty_increments": false
                    }),
                    "website_ids": ()
                }),
                "id": 0,
                "media_gallery_entries": (
                    json!({
                        "content": json!({
                            "base64_encoded_data": "",
                            "name": "",
                            "type": ""
                        }),
                        "disabled": false,
                        "extension_attributes": json!({"video_content": json!({
                                "media_type": "",
                                "video_description": "",
                                "video_metadata": "",
                                "video_provider": "",
                                "video_title": "",
                                "video_url": ""
                            })}),
                        "file": "",
                        "id": 0,
                        "label": "",
                        "media_type": "",
                        "position": 0,
                        "types": ()
                    })
                ),
                "name": "",
                "options": (
                    json!({
                        "extension_attributes": json!({"vertex_flex_field": ""}),
                        "file_extension": "",
                        "image_size_x": 0,
                        "image_size_y": 0,
                        "is_require": false,
                        "max_characters": 0,
                        "option_id": 0,
                        "price": "",
                        "price_type": "",
                        "product_sku": "",
                        "sku": "",
                        "sort_order": 0,
                        "title": "",
                        "type": "",
                        "values": (
                            json!({
                                "option_type_id": 0,
                                "price": "",
                                "price_type": "",
                                "sku": "",
                                "sort_order": 0,
                                "title": ""
                            })
                        )
                    })
                ),
                "price": "",
                "product_links": (
                    json!({
                        "extension_attributes": json!({"qty": ""}),
                        "link_type": "",
                        "linked_product_sku": "",
                        "linked_product_type": "",
                        "position": 0,
                        "sku": ""
                    })
                ),
                "sku": "",
                "status": 0,
                "tier_prices": (
                    json!({
                        "customer_group_id": 0,
                        "extension_attributes": json!({
                            "percentage_value": "",
                            "website_id": 0
                        }),
                        "qty": "",
                        "value": ""
                    })
                ),
                "type_id": "",
                "updated_at": "",
                "visibility": 0,
                "weight": ""
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/sharedCatalog/:id/unassignProducts \
  --header 'content-type: application/json' \
  --data '{
  "products": [
    {
      "attribute_set_id": 0,
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {
        "bundle_product_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "position": 0,
            "product_links": [
              {
                "can_change_quantity": 0,
                "extension_attributes": {},
                "id": "",
                "is_default": false,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
              }
            ],
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
          }
        ],
        "category_links": [
          {
            "category_id": "",
            "extension_attributes": {},
            "position": 0
          }
        ],
        "configurable_product_links": [],
        "configurable_product_options": [
          {
            "attribute_id": "",
            "extension_attributes": {},
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": [
              {
                "extension_attributes": {},
                "value_index": 0
              }
            ]
          }
        ],
        "downloadable_product_links": [
          {
            "extension_attributes": {},
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": {
              "extension_attributes": {},
              "file_data": "",
              "name": ""
            },
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "downloadable_product_samples": [
          {
            "extension_attributes": {},
            "id": 0,
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "giftcard_amounts": [
          {
            "attribute_id": 0,
            "extension_attributes": {},
            "value": "",
            "website_id": 0,
            "website_value": ""
          }
        ],
        "stock_item": {
          "backorders": 0,
          "enable_qty_increments": false,
          "extension_attributes": {},
          "is_decimal_divided": false,
          "is_in_stock": false,
          "is_qty_decimal": false,
          "item_id": 0,
          "low_stock_date": "",
          "manage_stock": false,
          "max_sale_qty": "",
          "min_qty": "",
          "min_sale_qty": "",
          "notify_stock_qty": "",
          "product_id": 0,
          "qty": "",
          "qty_increments": "",
          "show_default_notification_message": false,
          "stock_id": 0,
          "stock_status_changed_auto": 0,
          "use_config_backorders": false,
          "use_config_enable_qty_inc": false,
          "use_config_manage_stock": false,
          "use_config_max_sale_qty": false,
          "use_config_min_qty": false,
          "use_config_min_sale_qty": 0,
          "use_config_notify_stock_qty": false,
          "use_config_qty_increments": false
        },
        "website_ids": []
      },
      "id": 0,
      "media_gallery_entries": [
        {
          "content": {
            "base64_encoded_data": "",
            "name": "",
            "type": ""
          },
          "disabled": false,
          "extension_attributes": {
            "video_content": {
              "media_type": "",
              "video_description": "",
              "video_metadata": "",
              "video_provider": "",
              "video_title": "",
              "video_url": ""
            }
          },
          "file": "",
          "id": 0,
          "label": "",
          "media_type": "",
          "position": 0,
          "types": []
        }
      ],
      "name": "",
      "options": [
        {
          "extension_attributes": {
            "vertex_flex_field": ""
          },
          "file_extension": "",
          "image_size_x": 0,
          "image_size_y": 0,
          "is_require": false,
          "max_characters": 0,
          "option_id": 0,
          "price": "",
          "price_type": "",
          "product_sku": "",
          "sku": "",
          "sort_order": 0,
          "title": "",
          "type": "",
          "values": [
            {
              "option_type_id": 0,
              "price": "",
              "price_type": "",
              "sku": "",
              "sort_order": 0,
              "title": ""
            }
          ]
        }
      ],
      "price": "",
      "product_links": [
        {
          "extension_attributes": {
            "qty": ""
          },
          "link_type": "",
          "linked_product_sku": "",
          "linked_product_type": "",
          "position": 0,
          "sku": ""
        }
      ],
      "sku": "",
      "status": 0,
      "tier_prices": [
        {
          "customer_group_id": 0,
          "extension_attributes": {
            "percentage_value": "",
            "website_id": 0
          },
          "qty": "",
          "value": ""
        }
      ],
      "type_id": "",
      "updated_at": "",
      "visibility": 0,
      "weight": ""
    }
  ]
}'
echo '{
  "products": [
    {
      "attribute_set_id": 0,
      "created_at": "",
      "custom_attributes": [
        {
          "attribute_code": "",
          "value": ""
        }
      ],
      "extension_attributes": {
        "bundle_product_options": [
          {
            "extension_attributes": {},
            "option_id": 0,
            "position": 0,
            "product_links": [
              {
                "can_change_quantity": 0,
                "extension_attributes": {},
                "id": "",
                "is_default": false,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
              }
            ],
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
          }
        ],
        "category_links": [
          {
            "category_id": "",
            "extension_attributes": {},
            "position": 0
          }
        ],
        "configurable_product_links": [],
        "configurable_product_options": [
          {
            "attribute_id": "",
            "extension_attributes": {},
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": [
              {
                "extension_attributes": {},
                "value_index": 0
              }
            ]
          }
        ],
        "downloadable_product_links": [
          {
            "extension_attributes": {},
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": {
              "extension_attributes": {},
              "file_data": "",
              "name": ""
            },
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "downloadable_product_samples": [
          {
            "extension_attributes": {},
            "id": 0,
            "sample_file": "",
            "sample_file_content": {},
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          }
        ],
        "giftcard_amounts": [
          {
            "attribute_id": 0,
            "extension_attributes": {},
            "value": "",
            "website_id": 0,
            "website_value": ""
          }
        ],
        "stock_item": {
          "backorders": 0,
          "enable_qty_increments": false,
          "extension_attributes": {},
          "is_decimal_divided": false,
          "is_in_stock": false,
          "is_qty_decimal": false,
          "item_id": 0,
          "low_stock_date": "",
          "manage_stock": false,
          "max_sale_qty": "",
          "min_qty": "",
          "min_sale_qty": "",
          "notify_stock_qty": "",
          "product_id": 0,
          "qty": "",
          "qty_increments": "",
          "show_default_notification_message": false,
          "stock_id": 0,
          "stock_status_changed_auto": 0,
          "use_config_backorders": false,
          "use_config_enable_qty_inc": false,
          "use_config_manage_stock": false,
          "use_config_max_sale_qty": false,
          "use_config_min_qty": false,
          "use_config_min_sale_qty": 0,
          "use_config_notify_stock_qty": false,
          "use_config_qty_increments": false
        },
        "website_ids": []
      },
      "id": 0,
      "media_gallery_entries": [
        {
          "content": {
            "base64_encoded_data": "",
            "name": "",
            "type": ""
          },
          "disabled": false,
          "extension_attributes": {
            "video_content": {
              "media_type": "",
              "video_description": "",
              "video_metadata": "",
              "video_provider": "",
              "video_title": "",
              "video_url": ""
            }
          },
          "file": "",
          "id": 0,
          "label": "",
          "media_type": "",
          "position": 0,
          "types": []
        }
      ],
      "name": "",
      "options": [
        {
          "extension_attributes": {
            "vertex_flex_field": ""
          },
          "file_extension": "",
          "image_size_x": 0,
          "image_size_y": 0,
          "is_require": false,
          "max_characters": 0,
          "option_id": 0,
          "price": "",
          "price_type": "",
          "product_sku": "",
          "sku": "",
          "sort_order": 0,
          "title": "",
          "type": "",
          "values": [
            {
              "option_type_id": 0,
              "price": "",
              "price_type": "",
              "sku": "",
              "sort_order": 0,
              "title": ""
            }
          ]
        }
      ],
      "price": "",
      "product_links": [
        {
          "extension_attributes": {
            "qty": ""
          },
          "link_type": "",
          "linked_product_sku": "",
          "linked_product_type": "",
          "position": 0,
          "sku": ""
        }
      ],
      "sku": "",
      "status": 0,
      "tier_prices": [
        {
          "customer_group_id": 0,
          "extension_attributes": {
            "percentage_value": "",
            "website_id": 0
          },
          "qty": "",
          "value": ""
        }
      ],
      "type_id": "",
      "updated_at": "",
      "visibility": 0,
      "weight": ""
    }
  ]
}' |  \
  http POST {{baseUrl}}/V1/sharedCatalog/:id/unassignProducts \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "products": [\n    {\n      "attribute_set_id": 0,\n      "created_at": "",\n      "custom_attributes": [\n        {\n          "attribute_code": "",\n          "value": ""\n        }\n      ],\n      "extension_attributes": {\n        "bundle_product_options": [\n          {\n            "extension_attributes": {},\n            "option_id": 0,\n            "position": 0,\n            "product_links": [\n              {\n                "can_change_quantity": 0,\n                "extension_attributes": {},\n                "id": "",\n                "is_default": false,\n                "option_id": 0,\n                "position": 0,\n                "price": "",\n                "price_type": 0,\n                "qty": "",\n                "sku": ""\n              }\n            ],\n            "required": false,\n            "sku": "",\n            "title": "",\n            "type": ""\n          }\n        ],\n        "category_links": [\n          {\n            "category_id": "",\n            "extension_attributes": {},\n            "position": 0\n          }\n        ],\n        "configurable_product_links": [],\n        "configurable_product_options": [\n          {\n            "attribute_id": "",\n            "extension_attributes": {},\n            "id": 0,\n            "is_use_default": false,\n            "label": "",\n            "position": 0,\n            "product_id": 0,\n            "values": [\n              {\n                "extension_attributes": {},\n                "value_index": 0\n              }\n            ]\n          }\n        ],\n        "downloadable_product_links": [\n          {\n            "extension_attributes": {},\n            "id": 0,\n            "is_shareable": 0,\n            "link_file": "",\n            "link_file_content": {\n              "extension_attributes": {},\n              "file_data": "",\n              "name": ""\n            },\n            "link_type": "",\n            "link_url": "",\n            "number_of_downloads": 0,\n            "price": "",\n            "sample_file": "",\n            "sample_file_content": {},\n            "sample_type": "",\n            "sample_url": "",\n            "sort_order": 0,\n            "title": ""\n          }\n        ],\n        "downloadable_product_samples": [\n          {\n            "extension_attributes": {},\n            "id": 0,\n            "sample_file": "",\n            "sample_file_content": {},\n            "sample_type": "",\n            "sample_url": "",\n            "sort_order": 0,\n            "title": ""\n          }\n        ],\n        "giftcard_amounts": [\n          {\n            "attribute_id": 0,\n            "extension_attributes": {},\n            "value": "",\n            "website_id": 0,\n            "website_value": ""\n          }\n        ],\n        "stock_item": {\n          "backorders": 0,\n          "enable_qty_increments": false,\n          "extension_attributes": {},\n          "is_decimal_divided": false,\n          "is_in_stock": false,\n          "is_qty_decimal": false,\n          "item_id": 0,\n          "low_stock_date": "",\n          "manage_stock": false,\n          "max_sale_qty": "",\n          "min_qty": "",\n          "min_sale_qty": "",\n          "notify_stock_qty": "",\n          "product_id": 0,\n          "qty": "",\n          "qty_increments": "",\n          "show_default_notification_message": false,\n          "stock_id": 0,\n          "stock_status_changed_auto": 0,\n          "use_config_backorders": false,\n          "use_config_enable_qty_inc": false,\n          "use_config_manage_stock": false,\n          "use_config_max_sale_qty": false,\n          "use_config_min_qty": false,\n          "use_config_min_sale_qty": 0,\n          "use_config_notify_stock_qty": false,\n          "use_config_qty_increments": false\n        },\n        "website_ids": []\n      },\n      "id": 0,\n      "media_gallery_entries": [\n        {\n          "content": {\n            "base64_encoded_data": "",\n            "name": "",\n            "type": ""\n          },\n          "disabled": false,\n          "extension_attributes": {\n            "video_content": {\n              "media_type": "",\n              "video_description": "",\n              "video_metadata": "",\n              "video_provider": "",\n              "video_title": "",\n              "video_url": ""\n            }\n          },\n          "file": "",\n          "id": 0,\n          "label": "",\n          "media_type": "",\n          "position": 0,\n          "types": []\n        }\n      ],\n      "name": "",\n      "options": [\n        {\n          "extension_attributes": {\n            "vertex_flex_field": ""\n          },\n          "file_extension": "",\n          "image_size_x": 0,\n          "image_size_y": 0,\n          "is_require": false,\n          "max_characters": 0,\n          "option_id": 0,\n          "price": "",\n          "price_type": "",\n          "product_sku": "",\n          "sku": "",\n          "sort_order": 0,\n          "title": "",\n          "type": "",\n          "values": [\n            {\n              "option_type_id": 0,\n              "price": "",\n              "price_type": "",\n              "sku": "",\n              "sort_order": 0,\n              "title": ""\n            }\n          ]\n        }\n      ],\n      "price": "",\n      "product_links": [\n        {\n          "extension_attributes": {\n            "qty": ""\n          },\n          "link_type": "",\n          "linked_product_sku": "",\n          "linked_product_type": "",\n          "position": 0,\n          "sku": ""\n        }\n      ],\n      "sku": "",\n      "status": 0,\n      "tier_prices": [\n        {\n          "customer_group_id": 0,\n          "extension_attributes": {\n            "percentage_value": "",\n            "website_id": 0\n          },\n          "qty": "",\n          "value": ""\n        }\n      ],\n      "type_id": "",\n      "updated_at": "",\n      "visibility": 0,\n      "weight": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/V1/sharedCatalog/:id/unassignProducts
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["products": [
    [
      "attribute_set_id": 0,
      "created_at": "",
      "custom_attributes": [
        [
          "attribute_code": "",
          "value": ""
        ]
      ],
      "extension_attributes": [
        "bundle_product_options": [
          [
            "extension_attributes": [],
            "option_id": 0,
            "position": 0,
            "product_links": [
              [
                "can_change_quantity": 0,
                "extension_attributes": [],
                "id": "",
                "is_default": false,
                "option_id": 0,
                "position": 0,
                "price": "",
                "price_type": 0,
                "qty": "",
                "sku": ""
              ]
            ],
            "required": false,
            "sku": "",
            "title": "",
            "type": ""
          ]
        ],
        "category_links": [
          [
            "category_id": "",
            "extension_attributes": [],
            "position": 0
          ]
        ],
        "configurable_product_links": [],
        "configurable_product_options": [
          [
            "attribute_id": "",
            "extension_attributes": [],
            "id": 0,
            "is_use_default": false,
            "label": "",
            "position": 0,
            "product_id": 0,
            "values": [
              [
                "extension_attributes": [],
                "value_index": 0
              ]
            ]
          ]
        ],
        "downloadable_product_links": [
          [
            "extension_attributes": [],
            "id": 0,
            "is_shareable": 0,
            "link_file": "",
            "link_file_content": [
              "extension_attributes": [],
              "file_data": "",
              "name": ""
            ],
            "link_type": "",
            "link_url": "",
            "number_of_downloads": 0,
            "price": "",
            "sample_file": "",
            "sample_file_content": [],
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          ]
        ],
        "downloadable_product_samples": [
          [
            "extension_attributes": [],
            "id": 0,
            "sample_file": "",
            "sample_file_content": [],
            "sample_type": "",
            "sample_url": "",
            "sort_order": 0,
            "title": ""
          ]
        ],
        "giftcard_amounts": [
          [
            "attribute_id": 0,
            "extension_attributes": [],
            "value": "",
            "website_id": 0,
            "website_value": ""
          ]
        ],
        "stock_item": [
          "backorders": 0,
          "enable_qty_increments": false,
          "extension_attributes": [],
          "is_decimal_divided": false,
          "is_in_stock": false,
          "is_qty_decimal": false,
          "item_id": 0,
          "low_stock_date": "",
          "manage_stock": false,
          "max_sale_qty": "",
          "min_qty": "",
          "min_sale_qty": "",
          "notify_stock_qty": "",
          "product_id": 0,
          "qty": "",
          "qty_increments": "",
          "show_default_notification_message": false,
          "stock_id": 0,
          "stock_status_changed_auto": 0,
          "use_config_backorders": false,
          "use_config_enable_qty_inc": false,
          "use_config_manage_stock": false,
          "use_config_max_sale_qty": false,
          "use_config_min_qty": false,
          "use_config_min_sale_qty": 0,
          "use_config_notify_stock_qty": false,
          "use_config_qty_increments": false
        ],
        "website_ids": []
      ],
      "id": 0,
      "media_gallery_entries": [
        [
          "content": [
            "base64_encoded_data": "",
            "name": "",
            "type": ""
          ],
          "disabled": false,
          "extension_attributes": ["video_content": [
              "media_type": "",
              "video_description": "",
              "video_metadata": "",
              "video_provider": "",
              "video_title": "",
              "video_url": ""
            ]],
          "file": "",
          "id": 0,
          "label": "",
          "media_type": "",
          "position": 0,
          "types": []
        ]
      ],
      "name": "",
      "options": [
        [
          "extension_attributes": ["vertex_flex_field": ""],
          "file_extension": "",
          "image_size_x": 0,
          "image_size_y": 0,
          "is_require": false,
          "max_characters": 0,
          "option_id": 0,
          "price": "",
          "price_type": "",
          "product_sku": "",
          "sku": "",
          "sort_order": 0,
          "title": "",
          "type": "",
          "values": [
            [
              "option_type_id": 0,
              "price": "",
              "price_type": "",
              "sku": "",
              "sort_order": 0,
              "title": ""
            ]
          ]
        ]
      ],
      "price": "",
      "product_links": [
        [
          "extension_attributes": ["qty": ""],
          "link_type": "",
          "linked_product_sku": "",
          "linked_product_type": "",
          "position": 0,
          "sku": ""
        ]
      ],
      "sku": "",
      "status": 0,
      "tier_prices": [
        [
          "customer_group_id": 0,
          "extension_attributes": [
            "percentage_value": "",
            "website_id": 0
          ],
          "qty": "",
          "value": ""
        ]
      ],
      "type_id": "",
      "updated_at": "",
      "visibility": 0,
      "weight": ""
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/sharedCatalog/:id/unassignProducts")! 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 sharedCatalog-{sharedCatalogId} (GET)
{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId
QUERY PARAMS

sharedCatalogId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId")
require "http/client"

url = "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/sharedCatalog/:sharedCatalogId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/sharedCatalog/:sharedCatalogId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/sharedCatalog/:sharedCatalogId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/sharedCatalog/:sharedCatalogId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/sharedCatalog/:sharedCatalogId
http GET {{baseUrl}}/V1/sharedCatalog/:sharedCatalogId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/sharedCatalog/:sharedCatalogId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE sharedCatalog-{sharedCatalogId}
{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId
QUERY PARAMS

sharedCatalogId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId")
require "http/client"

url = "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/sharedCatalog/:sharedCatalogId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId"))
    .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}}/V1/sharedCatalog/:sharedCatalogId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId")
  .asString();
const 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}}/V1/sharedCatalog/:sharedCatalogId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/sharedCatalog/:sharedCatalogId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId');

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}}/V1/sharedCatalog/:sharedCatalogId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/sharedCatalog/:sharedCatalogId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/sharedCatalog/:sharedCatalogId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/sharedCatalog/:sharedCatalogId
http DELETE {{baseUrl}}/V1/sharedCatalog/:sharedCatalogId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/sharedCatalog/:sharedCatalogId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST sharedCatalog-{sharedCatalogId}-assignCompanies
{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies
QUERY PARAMS

sharedCatalogId
BODY json

{
  "companies": [
    {
      "city": "",
      "comment": "",
      "company_email": "",
      "company_name": "",
      "country_id": "",
      "customer_group_id": 0,
      "extension_attributes": {
        "applicable_payment_method": 0,
        "available_payment_methods": "",
        "quote_config": {
          "company_id": "",
          "extension_attributes": {},
          "is_quote_enabled": false
        },
        "use_config_settings": 0
      },
      "id": 0,
      "legal_name": "",
      "postcode": "",
      "region": "",
      "region_id": "",
      "reject_reason": "",
      "rejected_at": "",
      "reseller_id": "",
      "sales_representative_id": 0,
      "status": 0,
      "street": [],
      "super_user_id": 0,
      "telephone": "",
      "vat_tax_id": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies" {:content-type :json
                                                                                              :form-params {:companies [{:city ""
                                                                                                                         :comment ""
                                                                                                                         :company_email ""
                                                                                                                         :company_name ""
                                                                                                                         :country_id ""
                                                                                                                         :customer_group_id 0
                                                                                                                         :extension_attributes {:applicable_payment_method 0
                                                                                                                                                :available_payment_methods ""
                                                                                                                                                :quote_config {:company_id ""
                                                                                                                                                               :extension_attributes {}
                                                                                                                                                               :is_quote_enabled false}
                                                                                                                                                :use_config_settings 0}
                                                                                                                         :id 0
                                                                                                                         :legal_name ""
                                                                                                                         :postcode ""
                                                                                                                         :region ""
                                                                                                                         :region_id ""
                                                                                                                         :reject_reason ""
                                                                                                                         :rejected_at ""
                                                                                                                         :reseller_id ""
                                                                                                                         :sales_representative_id 0
                                                                                                                         :status 0
                                                                                                                         :street []
                                                                                                                         :super_user_id 0
                                                                                                                         :telephone ""
                                                                                                                         :vat_tax_id ""}]}})
require "http/client"

url = "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\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}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies"),
    Content = new StringContent("{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\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}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies"

	payload := strings.NewReader("{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/sharedCatalog/:sharedCatalogId/assignCompanies HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 804

{
  "companies": [
    {
      "city": "",
      "comment": "",
      "company_email": "",
      "company_name": "",
      "country_id": "",
      "customer_group_id": 0,
      "extension_attributes": {
        "applicable_payment_method": 0,
        "available_payment_methods": "",
        "quote_config": {
          "company_id": "",
          "extension_attributes": {},
          "is_quote_enabled": false
        },
        "use_config_settings": 0
      },
      "id": 0,
      "legal_name": "",
      "postcode": "",
      "region": "",
      "region_id": "",
      "reject_reason": "",
      "rejected_at": "",
      "reseller_id": "",
      "sales_representative_id": 0,
      "status": 0,
      "street": [],
      "super_user_id": 0,
      "telephone": "",
      "vat_tax_id": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\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  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies")
  .header("content-type", "application/json")
  .body("{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  companies: [
    {
      city: '',
      comment: '',
      company_email: '',
      company_name: '',
      country_id: '',
      customer_group_id: 0,
      extension_attributes: {
        applicable_payment_method: 0,
        available_payment_methods: '',
        quote_config: {
          company_id: '',
          extension_attributes: {},
          is_quote_enabled: false
        },
        use_config_settings: 0
      },
      id: 0,
      legal_name: '',
      postcode: '',
      region: '',
      region_id: '',
      reject_reason: '',
      rejected_at: '',
      reseller_id: '',
      sales_representative_id: 0,
      status: 0,
      street: [],
      super_user_id: 0,
      telephone: '',
      vat_tax_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}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies',
  headers: {'content-type': 'application/json'},
  data: {
    companies: [
      {
        city: '',
        comment: '',
        company_email: '',
        company_name: '',
        country_id: '',
        customer_group_id: 0,
        extension_attributes: {
          applicable_payment_method: 0,
          available_payment_methods: '',
          quote_config: {company_id: '', extension_attributes: {}, is_quote_enabled: false},
          use_config_settings: 0
        },
        id: 0,
        legal_name: '',
        postcode: '',
        region: '',
        region_id: '',
        reject_reason: '',
        rejected_at: '',
        reseller_id: '',
        sales_representative_id: 0,
        status: 0,
        street: [],
        super_user_id: 0,
        telephone: '',
        vat_tax_id: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"companies":[{"city":"","comment":"","company_email":"","company_name":"","country_id":"","customer_group_id":0,"extension_attributes":{"applicable_payment_method":0,"available_payment_methods":"","quote_config":{"company_id":"","extension_attributes":{},"is_quote_enabled":false},"use_config_settings":0},"id":0,"legal_name":"","postcode":"","region":"","region_id":"","reject_reason":"","rejected_at":"","reseller_id":"","sales_representative_id":0,"status":0,"street":[],"super_user_id":0,"telephone":"","vat_tax_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}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "companies": [\n    {\n      "city": "",\n      "comment": "",\n      "company_email": "",\n      "company_name": "",\n      "country_id": "",\n      "customer_group_id": 0,\n      "extension_attributes": {\n        "applicable_payment_method": 0,\n        "available_payment_methods": "",\n        "quote_config": {\n          "company_id": "",\n          "extension_attributes": {},\n          "is_quote_enabled": false\n        },\n        "use_config_settings": 0\n      },\n      "id": 0,\n      "legal_name": "",\n      "postcode": "",\n      "region": "",\n      "region_id": "",\n      "reject_reason": "",\n      "rejected_at": "",\n      "reseller_id": "",\n      "sales_representative_id": 0,\n      "status": 0,\n      "street": [],\n      "super_user_id": 0,\n      "telephone": "",\n      "vat_tax_id": ""\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  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/sharedCatalog/:sharedCatalogId/assignCompanies',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  companies: [
    {
      city: '',
      comment: '',
      company_email: '',
      company_name: '',
      country_id: '',
      customer_group_id: 0,
      extension_attributes: {
        applicable_payment_method: 0,
        available_payment_methods: '',
        quote_config: {company_id: '', extension_attributes: {}, is_quote_enabled: false},
        use_config_settings: 0
      },
      id: 0,
      legal_name: '',
      postcode: '',
      region: '',
      region_id: '',
      reject_reason: '',
      rejected_at: '',
      reseller_id: '',
      sales_representative_id: 0,
      status: 0,
      street: [],
      super_user_id: 0,
      telephone: '',
      vat_tax_id: ''
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies',
  headers: {'content-type': 'application/json'},
  body: {
    companies: [
      {
        city: '',
        comment: '',
        company_email: '',
        company_name: '',
        country_id: '',
        customer_group_id: 0,
        extension_attributes: {
          applicable_payment_method: 0,
          available_payment_methods: '',
          quote_config: {company_id: '', extension_attributes: {}, is_quote_enabled: false},
          use_config_settings: 0
        },
        id: 0,
        legal_name: '',
        postcode: '',
        region: '',
        region_id: '',
        reject_reason: '',
        rejected_at: '',
        reseller_id: '',
        sales_representative_id: 0,
        status: 0,
        street: [],
        super_user_id: 0,
        telephone: '',
        vat_tax_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}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  companies: [
    {
      city: '',
      comment: '',
      company_email: '',
      company_name: '',
      country_id: '',
      customer_group_id: 0,
      extension_attributes: {
        applicable_payment_method: 0,
        available_payment_methods: '',
        quote_config: {
          company_id: '',
          extension_attributes: {},
          is_quote_enabled: false
        },
        use_config_settings: 0
      },
      id: 0,
      legal_name: '',
      postcode: '',
      region: '',
      region_id: '',
      reject_reason: '',
      rejected_at: '',
      reseller_id: '',
      sales_representative_id: 0,
      status: 0,
      street: [],
      super_user_id: 0,
      telephone: '',
      vat_tax_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}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies',
  headers: {'content-type': 'application/json'},
  data: {
    companies: [
      {
        city: '',
        comment: '',
        company_email: '',
        company_name: '',
        country_id: '',
        customer_group_id: 0,
        extension_attributes: {
          applicable_payment_method: 0,
          available_payment_methods: '',
          quote_config: {company_id: '', extension_attributes: {}, is_quote_enabled: false},
          use_config_settings: 0
        },
        id: 0,
        legal_name: '',
        postcode: '',
        region: '',
        region_id: '',
        reject_reason: '',
        rejected_at: '',
        reseller_id: '',
        sales_representative_id: 0,
        status: 0,
        street: [],
        super_user_id: 0,
        telephone: '',
        vat_tax_id: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"companies":[{"city":"","comment":"","company_email":"","company_name":"","country_id":"","customer_group_id":0,"extension_attributes":{"applicable_payment_method":0,"available_payment_methods":"","quote_config":{"company_id":"","extension_attributes":{},"is_quote_enabled":false},"use_config_settings":0},"id":0,"legal_name":"","postcode":"","region":"","region_id":"","reject_reason":"","rejected_at":"","reseller_id":"","sales_representative_id":0,"status":0,"street":[],"super_user_id":0,"telephone":"","vat_tax_id":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"companies": @[ @{ @"city": @"", @"comment": @"", @"company_email": @"", @"company_name": @"", @"country_id": @"", @"customer_group_id": @0, @"extension_attributes": @{ @"applicable_payment_method": @0, @"available_payment_methods": @"", @"quote_config": @{ @"company_id": @"", @"extension_attributes": @{  }, @"is_quote_enabled": @NO }, @"use_config_settings": @0 }, @"id": @0, @"legal_name": @"", @"postcode": @"", @"region": @"", @"region_id": @"", @"reject_reason": @"", @"rejected_at": @"", @"reseller_id": @"", @"sales_representative_id": @0, @"status": @0, @"street": @[  ], @"super_user_id": @0, @"telephone": @"", @"vat_tax_id": @"" } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies"]
                                                       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}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies",
  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([
    'companies' => [
        [
                'city' => '',
                'comment' => '',
                'company_email' => '',
                'company_name' => '',
                'country_id' => '',
                'customer_group_id' => 0,
                'extension_attributes' => [
                                'applicable_payment_method' => 0,
                                'available_payment_methods' => '',
                                'quote_config' => [
                                                                'company_id' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'is_quote_enabled' => null
                                ],
                                'use_config_settings' => 0
                ],
                'id' => 0,
                'legal_name' => '',
                'postcode' => '',
                'region' => '',
                'region_id' => '',
                'reject_reason' => '',
                'rejected_at' => '',
                'reseller_id' => '',
                'sales_representative_id' => 0,
                'status' => 0,
                'street' => [
                                
                ],
                'super_user_id' => 0,
                'telephone' => '',
                'vat_tax_id' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies', [
  'body' => '{
  "companies": [
    {
      "city": "",
      "comment": "",
      "company_email": "",
      "company_name": "",
      "country_id": "",
      "customer_group_id": 0,
      "extension_attributes": {
        "applicable_payment_method": 0,
        "available_payment_methods": "",
        "quote_config": {
          "company_id": "",
          "extension_attributes": {},
          "is_quote_enabled": false
        },
        "use_config_settings": 0
      },
      "id": 0,
      "legal_name": "",
      "postcode": "",
      "region": "",
      "region_id": "",
      "reject_reason": "",
      "rejected_at": "",
      "reseller_id": "",
      "sales_representative_id": 0,
      "status": 0,
      "street": [],
      "super_user_id": 0,
      "telephone": "",
      "vat_tax_id": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'companies' => [
    [
        'city' => '',
        'comment' => '',
        'company_email' => '',
        'company_name' => '',
        'country_id' => '',
        'customer_group_id' => 0,
        'extension_attributes' => [
                'applicable_payment_method' => 0,
                'available_payment_methods' => '',
                'quote_config' => [
                                'company_id' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'is_quote_enabled' => null
                ],
                'use_config_settings' => 0
        ],
        'id' => 0,
        'legal_name' => '',
        'postcode' => '',
        'region' => '',
        'region_id' => '',
        'reject_reason' => '',
        'rejected_at' => '',
        'reseller_id' => '',
        'sales_representative_id' => 0,
        'status' => 0,
        'street' => [
                
        ],
        'super_user_id' => 0,
        'telephone' => '',
        'vat_tax_id' => ''
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'companies' => [
    [
        'city' => '',
        'comment' => '',
        'company_email' => '',
        'company_name' => '',
        'country_id' => '',
        'customer_group_id' => 0,
        'extension_attributes' => [
                'applicable_payment_method' => 0,
                'available_payment_methods' => '',
                'quote_config' => [
                                'company_id' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'is_quote_enabled' => null
                ],
                'use_config_settings' => 0
        ],
        'id' => 0,
        'legal_name' => '',
        'postcode' => '',
        'region' => '',
        'region_id' => '',
        'reject_reason' => '',
        'rejected_at' => '',
        'reseller_id' => '',
        'sales_representative_id' => 0,
        'status' => 0,
        'street' => [
                
        ],
        'super_user_id' => 0,
        'telephone' => '',
        'vat_tax_id' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "companies": [
    {
      "city": "",
      "comment": "",
      "company_email": "",
      "company_name": "",
      "country_id": "",
      "customer_group_id": 0,
      "extension_attributes": {
        "applicable_payment_method": 0,
        "available_payment_methods": "",
        "quote_config": {
          "company_id": "",
          "extension_attributes": {},
          "is_quote_enabled": false
        },
        "use_config_settings": 0
      },
      "id": 0,
      "legal_name": "",
      "postcode": "",
      "region": "",
      "region_id": "",
      "reject_reason": "",
      "rejected_at": "",
      "reseller_id": "",
      "sales_representative_id": 0,
      "status": 0,
      "street": [],
      "super_user_id": 0,
      "telephone": "",
      "vat_tax_id": ""
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "companies": [
    {
      "city": "",
      "comment": "",
      "company_email": "",
      "company_name": "",
      "country_id": "",
      "customer_group_id": 0,
      "extension_attributes": {
        "applicable_payment_method": 0,
        "available_payment_methods": "",
        "quote_config": {
          "company_id": "",
          "extension_attributes": {},
          "is_quote_enabled": false
        },
        "use_config_settings": 0
      },
      "id": 0,
      "legal_name": "",
      "postcode": "",
      "region": "",
      "region_id": "",
      "reject_reason": "",
      "rejected_at": "",
      "reseller_id": "",
      "sales_representative_id": 0,
      "status": 0,
      "street": [],
      "super_user_id": 0,
      "telephone": "",
      "vat_tax_id": ""
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/sharedCatalog/:sharedCatalogId/assignCompanies", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies"

payload = { "companies": [
        {
            "city": "",
            "comment": "",
            "company_email": "",
            "company_name": "",
            "country_id": "",
            "customer_group_id": 0,
            "extension_attributes": {
                "applicable_payment_method": 0,
                "available_payment_methods": "",
                "quote_config": {
                    "company_id": "",
                    "extension_attributes": {},
                    "is_quote_enabled": False
                },
                "use_config_settings": 0
            },
            "id": 0,
            "legal_name": "",
            "postcode": "",
            "region": "",
            "region_id": "",
            "reject_reason": "",
            "rejected_at": "",
            "reseller_id": "",
            "sales_representative_id": 0,
            "status": 0,
            "street": [],
            "super_user_id": 0,
            "telephone": "",
            "vat_tax_id": ""
        }
    ] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies"

payload <- "{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\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/V1/sharedCatalog/:sharedCatalogId/assignCompanies') do |req|
  req.body = "{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\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}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies";

    let payload = json!({"companies": (
            json!({
                "city": "",
                "comment": "",
                "company_email": "",
                "company_name": "",
                "country_id": "",
                "customer_group_id": 0,
                "extension_attributes": json!({
                    "applicable_payment_method": 0,
                    "available_payment_methods": "",
                    "quote_config": json!({
                        "company_id": "",
                        "extension_attributes": json!({}),
                        "is_quote_enabled": false
                    }),
                    "use_config_settings": 0
                }),
                "id": 0,
                "legal_name": "",
                "postcode": "",
                "region": "",
                "region_id": "",
                "reject_reason": "",
                "rejected_at": "",
                "reseller_id": "",
                "sales_representative_id": 0,
                "status": 0,
                "street": (),
                "super_user_id": 0,
                "telephone": "",
                "vat_tax_id": ""
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies \
  --header 'content-type: application/json' \
  --data '{
  "companies": [
    {
      "city": "",
      "comment": "",
      "company_email": "",
      "company_name": "",
      "country_id": "",
      "customer_group_id": 0,
      "extension_attributes": {
        "applicable_payment_method": 0,
        "available_payment_methods": "",
        "quote_config": {
          "company_id": "",
          "extension_attributes": {},
          "is_quote_enabled": false
        },
        "use_config_settings": 0
      },
      "id": 0,
      "legal_name": "",
      "postcode": "",
      "region": "",
      "region_id": "",
      "reject_reason": "",
      "rejected_at": "",
      "reseller_id": "",
      "sales_representative_id": 0,
      "status": 0,
      "street": [],
      "super_user_id": 0,
      "telephone": "",
      "vat_tax_id": ""
    }
  ]
}'
echo '{
  "companies": [
    {
      "city": "",
      "comment": "",
      "company_email": "",
      "company_name": "",
      "country_id": "",
      "customer_group_id": 0,
      "extension_attributes": {
        "applicable_payment_method": 0,
        "available_payment_methods": "",
        "quote_config": {
          "company_id": "",
          "extension_attributes": {},
          "is_quote_enabled": false
        },
        "use_config_settings": 0
      },
      "id": 0,
      "legal_name": "",
      "postcode": "",
      "region": "",
      "region_id": "",
      "reject_reason": "",
      "rejected_at": "",
      "reseller_id": "",
      "sales_representative_id": 0,
      "status": 0,
      "street": [],
      "super_user_id": 0,
      "telephone": "",
      "vat_tax_id": ""
    }
  ]
}' |  \
  http POST {{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "companies": [\n    {\n      "city": "",\n      "comment": "",\n      "company_email": "",\n      "company_name": "",\n      "country_id": "",\n      "customer_group_id": 0,\n      "extension_attributes": {\n        "applicable_payment_method": 0,\n        "available_payment_methods": "",\n        "quote_config": {\n          "company_id": "",\n          "extension_attributes": {},\n          "is_quote_enabled": false\n        },\n        "use_config_settings": 0\n      },\n      "id": 0,\n      "legal_name": "",\n      "postcode": "",\n      "region": "",\n      "region_id": "",\n      "reject_reason": "",\n      "rejected_at": "",\n      "reseller_id": "",\n      "sales_representative_id": 0,\n      "status": 0,\n      "street": [],\n      "super_user_id": 0,\n      "telephone": "",\n      "vat_tax_id": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["companies": [
    [
      "city": "",
      "comment": "",
      "company_email": "",
      "company_name": "",
      "country_id": "",
      "customer_group_id": 0,
      "extension_attributes": [
        "applicable_payment_method": 0,
        "available_payment_methods": "",
        "quote_config": [
          "company_id": "",
          "extension_attributes": [],
          "is_quote_enabled": false
        ],
        "use_config_settings": 0
      ],
      "id": 0,
      "legal_name": "",
      "postcode": "",
      "region": "",
      "region_id": "",
      "reject_reason": "",
      "rejected_at": "",
      "reseller_id": "",
      "sales_representative_id": 0,
      "status": 0,
      "street": [],
      "super_user_id": 0,
      "telephone": "",
      "vat_tax_id": ""
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/assignCompanies")! 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 sharedCatalog-{sharedCatalogId}-companies
{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies
QUERY PARAMS

sharedCatalogId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies")
require "http/client"

url = "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/sharedCatalog/:sharedCatalogId/companies HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/sharedCatalog/:sharedCatalogId/companies',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/sharedCatalog/:sharedCatalogId/companies")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/sharedCatalog/:sharedCatalogId/companies') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies
http GET {{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/companies")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST sharedCatalog-{sharedCatalogId}-unassignCompanies
{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies
QUERY PARAMS

sharedCatalogId
BODY json

{
  "companies": [
    {
      "city": "",
      "comment": "",
      "company_email": "",
      "company_name": "",
      "country_id": "",
      "customer_group_id": 0,
      "extension_attributes": {
        "applicable_payment_method": 0,
        "available_payment_methods": "",
        "quote_config": {
          "company_id": "",
          "extension_attributes": {},
          "is_quote_enabled": false
        },
        "use_config_settings": 0
      },
      "id": 0,
      "legal_name": "",
      "postcode": "",
      "region": "",
      "region_id": "",
      "reject_reason": "",
      "rejected_at": "",
      "reseller_id": "",
      "sales_representative_id": 0,
      "status": 0,
      "street": [],
      "super_user_id": 0,
      "telephone": "",
      "vat_tax_id": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies" {:content-type :json
                                                                                                :form-params {:companies [{:city ""
                                                                                                                           :comment ""
                                                                                                                           :company_email ""
                                                                                                                           :company_name ""
                                                                                                                           :country_id ""
                                                                                                                           :customer_group_id 0
                                                                                                                           :extension_attributes {:applicable_payment_method 0
                                                                                                                                                  :available_payment_methods ""
                                                                                                                                                  :quote_config {:company_id ""
                                                                                                                                                                 :extension_attributes {}
                                                                                                                                                                 :is_quote_enabled false}
                                                                                                                                                  :use_config_settings 0}
                                                                                                                           :id 0
                                                                                                                           :legal_name ""
                                                                                                                           :postcode ""
                                                                                                                           :region ""
                                                                                                                           :region_id ""
                                                                                                                           :reject_reason ""
                                                                                                                           :rejected_at ""
                                                                                                                           :reseller_id ""
                                                                                                                           :sales_representative_id 0
                                                                                                                           :status 0
                                                                                                                           :street []
                                                                                                                           :super_user_id 0
                                                                                                                           :telephone ""
                                                                                                                           :vat_tax_id ""}]}})
require "http/client"

url = "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\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}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies"),
    Content = new StringContent("{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\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}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies"

	payload := strings.NewReader("{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/sharedCatalog/:sharedCatalogId/unassignCompanies HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 804

{
  "companies": [
    {
      "city": "",
      "comment": "",
      "company_email": "",
      "company_name": "",
      "country_id": "",
      "customer_group_id": 0,
      "extension_attributes": {
        "applicable_payment_method": 0,
        "available_payment_methods": "",
        "quote_config": {
          "company_id": "",
          "extension_attributes": {},
          "is_quote_enabled": false
        },
        "use_config_settings": 0
      },
      "id": 0,
      "legal_name": "",
      "postcode": "",
      "region": "",
      "region_id": "",
      "reject_reason": "",
      "rejected_at": "",
      "reseller_id": "",
      "sales_representative_id": 0,
      "status": 0,
      "street": [],
      "super_user_id": 0,
      "telephone": "",
      "vat_tax_id": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\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  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies")
  .header("content-type", "application/json")
  .body("{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  companies: [
    {
      city: '',
      comment: '',
      company_email: '',
      company_name: '',
      country_id: '',
      customer_group_id: 0,
      extension_attributes: {
        applicable_payment_method: 0,
        available_payment_methods: '',
        quote_config: {
          company_id: '',
          extension_attributes: {},
          is_quote_enabled: false
        },
        use_config_settings: 0
      },
      id: 0,
      legal_name: '',
      postcode: '',
      region: '',
      region_id: '',
      reject_reason: '',
      rejected_at: '',
      reseller_id: '',
      sales_representative_id: 0,
      status: 0,
      street: [],
      super_user_id: 0,
      telephone: '',
      vat_tax_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}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies',
  headers: {'content-type': 'application/json'},
  data: {
    companies: [
      {
        city: '',
        comment: '',
        company_email: '',
        company_name: '',
        country_id: '',
        customer_group_id: 0,
        extension_attributes: {
          applicable_payment_method: 0,
          available_payment_methods: '',
          quote_config: {company_id: '', extension_attributes: {}, is_quote_enabled: false},
          use_config_settings: 0
        },
        id: 0,
        legal_name: '',
        postcode: '',
        region: '',
        region_id: '',
        reject_reason: '',
        rejected_at: '',
        reseller_id: '',
        sales_representative_id: 0,
        status: 0,
        street: [],
        super_user_id: 0,
        telephone: '',
        vat_tax_id: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"companies":[{"city":"","comment":"","company_email":"","company_name":"","country_id":"","customer_group_id":0,"extension_attributes":{"applicable_payment_method":0,"available_payment_methods":"","quote_config":{"company_id":"","extension_attributes":{},"is_quote_enabled":false},"use_config_settings":0},"id":0,"legal_name":"","postcode":"","region":"","region_id":"","reject_reason":"","rejected_at":"","reseller_id":"","sales_representative_id":0,"status":0,"street":[],"super_user_id":0,"telephone":"","vat_tax_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}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "companies": [\n    {\n      "city": "",\n      "comment": "",\n      "company_email": "",\n      "company_name": "",\n      "country_id": "",\n      "customer_group_id": 0,\n      "extension_attributes": {\n        "applicable_payment_method": 0,\n        "available_payment_methods": "",\n        "quote_config": {\n          "company_id": "",\n          "extension_attributes": {},\n          "is_quote_enabled": false\n        },\n        "use_config_settings": 0\n      },\n      "id": 0,\n      "legal_name": "",\n      "postcode": "",\n      "region": "",\n      "region_id": "",\n      "reject_reason": "",\n      "rejected_at": "",\n      "reseller_id": "",\n      "sales_representative_id": 0,\n      "status": 0,\n      "street": [],\n      "super_user_id": 0,\n      "telephone": "",\n      "vat_tax_id": ""\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  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/sharedCatalog/:sharedCatalogId/unassignCompanies',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  companies: [
    {
      city: '',
      comment: '',
      company_email: '',
      company_name: '',
      country_id: '',
      customer_group_id: 0,
      extension_attributes: {
        applicable_payment_method: 0,
        available_payment_methods: '',
        quote_config: {company_id: '', extension_attributes: {}, is_quote_enabled: false},
        use_config_settings: 0
      },
      id: 0,
      legal_name: '',
      postcode: '',
      region: '',
      region_id: '',
      reject_reason: '',
      rejected_at: '',
      reseller_id: '',
      sales_representative_id: 0,
      status: 0,
      street: [],
      super_user_id: 0,
      telephone: '',
      vat_tax_id: ''
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies',
  headers: {'content-type': 'application/json'},
  body: {
    companies: [
      {
        city: '',
        comment: '',
        company_email: '',
        company_name: '',
        country_id: '',
        customer_group_id: 0,
        extension_attributes: {
          applicable_payment_method: 0,
          available_payment_methods: '',
          quote_config: {company_id: '', extension_attributes: {}, is_quote_enabled: false},
          use_config_settings: 0
        },
        id: 0,
        legal_name: '',
        postcode: '',
        region: '',
        region_id: '',
        reject_reason: '',
        rejected_at: '',
        reseller_id: '',
        sales_representative_id: 0,
        status: 0,
        street: [],
        super_user_id: 0,
        telephone: '',
        vat_tax_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}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  companies: [
    {
      city: '',
      comment: '',
      company_email: '',
      company_name: '',
      country_id: '',
      customer_group_id: 0,
      extension_attributes: {
        applicable_payment_method: 0,
        available_payment_methods: '',
        quote_config: {
          company_id: '',
          extension_attributes: {},
          is_quote_enabled: false
        },
        use_config_settings: 0
      },
      id: 0,
      legal_name: '',
      postcode: '',
      region: '',
      region_id: '',
      reject_reason: '',
      rejected_at: '',
      reseller_id: '',
      sales_representative_id: 0,
      status: 0,
      street: [],
      super_user_id: 0,
      telephone: '',
      vat_tax_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}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies',
  headers: {'content-type': 'application/json'},
  data: {
    companies: [
      {
        city: '',
        comment: '',
        company_email: '',
        company_name: '',
        country_id: '',
        customer_group_id: 0,
        extension_attributes: {
          applicable_payment_method: 0,
          available_payment_methods: '',
          quote_config: {company_id: '', extension_attributes: {}, is_quote_enabled: false},
          use_config_settings: 0
        },
        id: 0,
        legal_name: '',
        postcode: '',
        region: '',
        region_id: '',
        reject_reason: '',
        rejected_at: '',
        reseller_id: '',
        sales_representative_id: 0,
        status: 0,
        street: [],
        super_user_id: 0,
        telephone: '',
        vat_tax_id: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"companies":[{"city":"","comment":"","company_email":"","company_name":"","country_id":"","customer_group_id":0,"extension_attributes":{"applicable_payment_method":0,"available_payment_methods":"","quote_config":{"company_id":"","extension_attributes":{},"is_quote_enabled":false},"use_config_settings":0},"id":0,"legal_name":"","postcode":"","region":"","region_id":"","reject_reason":"","rejected_at":"","reseller_id":"","sales_representative_id":0,"status":0,"street":[],"super_user_id":0,"telephone":"","vat_tax_id":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"companies": @[ @{ @"city": @"", @"comment": @"", @"company_email": @"", @"company_name": @"", @"country_id": @"", @"customer_group_id": @0, @"extension_attributes": @{ @"applicable_payment_method": @0, @"available_payment_methods": @"", @"quote_config": @{ @"company_id": @"", @"extension_attributes": @{  }, @"is_quote_enabled": @NO }, @"use_config_settings": @0 }, @"id": @0, @"legal_name": @"", @"postcode": @"", @"region": @"", @"region_id": @"", @"reject_reason": @"", @"rejected_at": @"", @"reseller_id": @"", @"sales_representative_id": @0, @"status": @0, @"street": @[  ], @"super_user_id": @0, @"telephone": @"", @"vat_tax_id": @"" } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies"]
                                                       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}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies",
  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([
    'companies' => [
        [
                'city' => '',
                'comment' => '',
                'company_email' => '',
                'company_name' => '',
                'country_id' => '',
                'customer_group_id' => 0,
                'extension_attributes' => [
                                'applicable_payment_method' => 0,
                                'available_payment_methods' => '',
                                'quote_config' => [
                                                                'company_id' => '',
                                                                'extension_attributes' => [
                                                                                                                                
                                                                ],
                                                                'is_quote_enabled' => null
                                ],
                                'use_config_settings' => 0
                ],
                'id' => 0,
                'legal_name' => '',
                'postcode' => '',
                'region' => '',
                'region_id' => '',
                'reject_reason' => '',
                'rejected_at' => '',
                'reseller_id' => '',
                'sales_representative_id' => 0,
                'status' => 0,
                'street' => [
                                
                ],
                'super_user_id' => 0,
                'telephone' => '',
                'vat_tax_id' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies', [
  'body' => '{
  "companies": [
    {
      "city": "",
      "comment": "",
      "company_email": "",
      "company_name": "",
      "country_id": "",
      "customer_group_id": 0,
      "extension_attributes": {
        "applicable_payment_method": 0,
        "available_payment_methods": "",
        "quote_config": {
          "company_id": "",
          "extension_attributes": {},
          "is_quote_enabled": false
        },
        "use_config_settings": 0
      },
      "id": 0,
      "legal_name": "",
      "postcode": "",
      "region": "",
      "region_id": "",
      "reject_reason": "",
      "rejected_at": "",
      "reseller_id": "",
      "sales_representative_id": 0,
      "status": 0,
      "street": [],
      "super_user_id": 0,
      "telephone": "",
      "vat_tax_id": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'companies' => [
    [
        'city' => '',
        'comment' => '',
        'company_email' => '',
        'company_name' => '',
        'country_id' => '',
        'customer_group_id' => 0,
        'extension_attributes' => [
                'applicable_payment_method' => 0,
                'available_payment_methods' => '',
                'quote_config' => [
                                'company_id' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'is_quote_enabled' => null
                ],
                'use_config_settings' => 0
        ],
        'id' => 0,
        'legal_name' => '',
        'postcode' => '',
        'region' => '',
        'region_id' => '',
        'reject_reason' => '',
        'rejected_at' => '',
        'reseller_id' => '',
        'sales_representative_id' => 0,
        'status' => 0,
        'street' => [
                
        ],
        'super_user_id' => 0,
        'telephone' => '',
        'vat_tax_id' => ''
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'companies' => [
    [
        'city' => '',
        'comment' => '',
        'company_email' => '',
        'company_name' => '',
        'country_id' => '',
        'customer_group_id' => 0,
        'extension_attributes' => [
                'applicable_payment_method' => 0,
                'available_payment_methods' => '',
                'quote_config' => [
                                'company_id' => '',
                                'extension_attributes' => [
                                                                
                                ],
                                'is_quote_enabled' => null
                ],
                'use_config_settings' => 0
        ],
        'id' => 0,
        'legal_name' => '',
        'postcode' => '',
        'region' => '',
        'region_id' => '',
        'reject_reason' => '',
        'rejected_at' => '',
        'reseller_id' => '',
        'sales_representative_id' => 0,
        'status' => 0,
        'street' => [
                
        ],
        'super_user_id' => 0,
        'telephone' => '',
        'vat_tax_id' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "companies": [
    {
      "city": "",
      "comment": "",
      "company_email": "",
      "company_name": "",
      "country_id": "",
      "customer_group_id": 0,
      "extension_attributes": {
        "applicable_payment_method": 0,
        "available_payment_methods": "",
        "quote_config": {
          "company_id": "",
          "extension_attributes": {},
          "is_quote_enabled": false
        },
        "use_config_settings": 0
      },
      "id": 0,
      "legal_name": "",
      "postcode": "",
      "region": "",
      "region_id": "",
      "reject_reason": "",
      "rejected_at": "",
      "reseller_id": "",
      "sales_representative_id": 0,
      "status": 0,
      "street": [],
      "super_user_id": 0,
      "telephone": "",
      "vat_tax_id": ""
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "companies": [
    {
      "city": "",
      "comment": "",
      "company_email": "",
      "company_name": "",
      "country_id": "",
      "customer_group_id": 0,
      "extension_attributes": {
        "applicable_payment_method": 0,
        "available_payment_methods": "",
        "quote_config": {
          "company_id": "",
          "extension_attributes": {},
          "is_quote_enabled": false
        },
        "use_config_settings": 0
      },
      "id": 0,
      "legal_name": "",
      "postcode": "",
      "region": "",
      "region_id": "",
      "reject_reason": "",
      "rejected_at": "",
      "reseller_id": "",
      "sales_representative_id": 0,
      "status": 0,
      "street": [],
      "super_user_id": 0,
      "telephone": "",
      "vat_tax_id": ""
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/sharedCatalog/:sharedCatalogId/unassignCompanies", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies"

payload = { "companies": [
        {
            "city": "",
            "comment": "",
            "company_email": "",
            "company_name": "",
            "country_id": "",
            "customer_group_id": 0,
            "extension_attributes": {
                "applicable_payment_method": 0,
                "available_payment_methods": "",
                "quote_config": {
                    "company_id": "",
                    "extension_attributes": {},
                    "is_quote_enabled": False
                },
                "use_config_settings": 0
            },
            "id": 0,
            "legal_name": "",
            "postcode": "",
            "region": "",
            "region_id": "",
            "reject_reason": "",
            "rejected_at": "",
            "reseller_id": "",
            "sales_representative_id": 0,
            "status": 0,
            "street": [],
            "super_user_id": 0,
            "telephone": "",
            "vat_tax_id": ""
        }
    ] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies"

payload <- "{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\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/V1/sharedCatalog/:sharedCatalogId/unassignCompanies') do |req|
  req.body = "{\n  \"companies\": [\n    {\n      \"city\": \"\",\n      \"comment\": \"\",\n      \"company_email\": \"\",\n      \"company_name\": \"\",\n      \"country_id\": \"\",\n      \"customer_group_id\": 0,\n      \"extension_attributes\": {\n        \"applicable_payment_method\": 0,\n        \"available_payment_methods\": \"\",\n        \"quote_config\": {\n          \"company_id\": \"\",\n          \"extension_attributes\": {},\n          \"is_quote_enabled\": false\n        },\n        \"use_config_settings\": 0\n      },\n      \"id\": 0,\n      \"legal_name\": \"\",\n      \"postcode\": \"\",\n      \"region\": \"\",\n      \"region_id\": \"\",\n      \"reject_reason\": \"\",\n      \"rejected_at\": \"\",\n      \"reseller_id\": \"\",\n      \"sales_representative_id\": 0,\n      \"status\": 0,\n      \"street\": [],\n      \"super_user_id\": 0,\n      \"telephone\": \"\",\n      \"vat_tax_id\": \"\"\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}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies";

    let payload = json!({"companies": (
            json!({
                "city": "",
                "comment": "",
                "company_email": "",
                "company_name": "",
                "country_id": "",
                "customer_group_id": 0,
                "extension_attributes": json!({
                    "applicable_payment_method": 0,
                    "available_payment_methods": "",
                    "quote_config": json!({
                        "company_id": "",
                        "extension_attributes": json!({}),
                        "is_quote_enabled": false
                    }),
                    "use_config_settings": 0
                }),
                "id": 0,
                "legal_name": "",
                "postcode": "",
                "region": "",
                "region_id": "",
                "reject_reason": "",
                "rejected_at": "",
                "reseller_id": "",
                "sales_representative_id": 0,
                "status": 0,
                "street": (),
                "super_user_id": 0,
                "telephone": "",
                "vat_tax_id": ""
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies \
  --header 'content-type: application/json' \
  --data '{
  "companies": [
    {
      "city": "",
      "comment": "",
      "company_email": "",
      "company_name": "",
      "country_id": "",
      "customer_group_id": 0,
      "extension_attributes": {
        "applicable_payment_method": 0,
        "available_payment_methods": "",
        "quote_config": {
          "company_id": "",
          "extension_attributes": {},
          "is_quote_enabled": false
        },
        "use_config_settings": 0
      },
      "id": 0,
      "legal_name": "",
      "postcode": "",
      "region": "",
      "region_id": "",
      "reject_reason": "",
      "rejected_at": "",
      "reseller_id": "",
      "sales_representative_id": 0,
      "status": 0,
      "street": [],
      "super_user_id": 0,
      "telephone": "",
      "vat_tax_id": ""
    }
  ]
}'
echo '{
  "companies": [
    {
      "city": "",
      "comment": "",
      "company_email": "",
      "company_name": "",
      "country_id": "",
      "customer_group_id": 0,
      "extension_attributes": {
        "applicable_payment_method": 0,
        "available_payment_methods": "",
        "quote_config": {
          "company_id": "",
          "extension_attributes": {},
          "is_quote_enabled": false
        },
        "use_config_settings": 0
      },
      "id": 0,
      "legal_name": "",
      "postcode": "",
      "region": "",
      "region_id": "",
      "reject_reason": "",
      "rejected_at": "",
      "reseller_id": "",
      "sales_representative_id": 0,
      "status": 0,
      "street": [],
      "super_user_id": 0,
      "telephone": "",
      "vat_tax_id": ""
    }
  ]
}' |  \
  http POST {{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "companies": [\n    {\n      "city": "",\n      "comment": "",\n      "company_email": "",\n      "company_name": "",\n      "country_id": "",\n      "customer_group_id": 0,\n      "extension_attributes": {\n        "applicable_payment_method": 0,\n        "available_payment_methods": "",\n        "quote_config": {\n          "company_id": "",\n          "extension_attributes": {},\n          "is_quote_enabled": false\n        },\n        "use_config_settings": 0\n      },\n      "id": 0,\n      "legal_name": "",\n      "postcode": "",\n      "region": "",\n      "region_id": "",\n      "reject_reason": "",\n      "rejected_at": "",\n      "reseller_id": "",\n      "sales_representative_id": 0,\n      "status": 0,\n      "street": [],\n      "super_user_id": 0,\n      "telephone": "",\n      "vat_tax_id": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["companies": [
    [
      "city": "",
      "comment": "",
      "company_email": "",
      "company_name": "",
      "country_id": "",
      "customer_group_id": 0,
      "extension_attributes": [
        "applicable_payment_method": 0,
        "available_payment_methods": "",
        "quote_config": [
          "company_id": "",
          "extension_attributes": [],
          "is_quote_enabled": false
        ],
        "use_config_settings": 0
      ],
      "id": 0,
      "legal_name": "",
      "postcode": "",
      "region": "",
      "region_id": "",
      "reject_reason": "",
      "rejected_at": "",
      "reseller_id": "",
      "sales_representative_id": 0,
      "status": 0,
      "street": [],
      "super_user_id": 0,
      "telephone": "",
      "vat_tax_id": ""
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/sharedCatalog/:sharedCatalogId/unassignCompanies")! 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 shipment-
{{baseUrl}}/V1/shipment/
BODY json

{
  "entity": {
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "customer_id": 0,
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "ext_location_id": "",
      "ext_return_shipment_id": "",
      "ext_shipment_id": "",
      "ext_tracking_reference": "",
      "ext_tracking_url": ""
    },
    "increment_id": "",
    "items": [
      {
        "additional_data": "",
        "description": "",
        "entity_id": 0,
        "extension_attributes": {},
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "sku": "",
        "weight": ""
      }
    ],
    "order_id": 0,
    "packages": [
      {
        "extension_attributes": {}
      }
    ],
    "shipment_status": 0,
    "shipping_address_id": 0,
    "shipping_label": "",
    "store_id": 0,
    "total_qty": "",
    "total_weight": "",
    "tracks": [
      {
        "carrier_code": "",
        "created_at": "",
        "description": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_id": 0,
        "parent_id": 0,
        "qty": "",
        "title": "",
        "track_number": "",
        "updated_at": "",
        "weight": ""
      }
    ],
    "updated_at": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/shipment/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"entity\": {\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"customer_id\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\"\n    },\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"sku\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"packages\": [\n      {\n        \"extension_attributes\": {}\n      }\n    ],\n    \"shipment_status\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_label\": \"\",\n    \"store_id\": 0,\n    \"total_qty\": \"\",\n    \"total_weight\": \"\",\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"created_at\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_id\": 0,\n        \"parent_id\": 0,\n        \"qty\": \"\",\n        \"title\": \"\",\n        \"track_number\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"updated_at\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/shipment/" {:content-type :json
                                                         :form-params {:entity {:billing_address_id 0
                                                                                :comments [{:comment ""
                                                                                            :created_at ""
                                                                                            :entity_id 0
                                                                                            :extension_attributes {}
                                                                                            :is_customer_notified 0
                                                                                            :is_visible_on_front 0
                                                                                            :parent_id 0}]
                                                                                :created_at ""
                                                                                :customer_id 0
                                                                                :email_sent 0
                                                                                :entity_id 0
                                                                                :extension_attributes {:ext_location_id ""
                                                                                                       :ext_return_shipment_id ""
                                                                                                       :ext_shipment_id ""
                                                                                                       :ext_tracking_reference ""
                                                                                                       :ext_tracking_url ""}
                                                                                :increment_id ""
                                                                                :items [{:additional_data ""
                                                                                         :description ""
                                                                                         :entity_id 0
                                                                                         :extension_attributes {}
                                                                                         :name ""
                                                                                         :order_item_id 0
                                                                                         :parent_id 0
                                                                                         :price ""
                                                                                         :product_id 0
                                                                                         :qty ""
                                                                                         :row_total ""
                                                                                         :sku ""
                                                                                         :weight ""}]
                                                                                :order_id 0
                                                                                :packages [{:extension_attributes {}}]
                                                                                :shipment_status 0
                                                                                :shipping_address_id 0
                                                                                :shipping_label ""
                                                                                :store_id 0
                                                                                :total_qty ""
                                                                                :total_weight ""
                                                                                :tracks [{:carrier_code ""
                                                                                          :created_at ""
                                                                                          :description ""
                                                                                          :entity_id 0
                                                                                          :extension_attributes {}
                                                                                          :order_id 0
                                                                                          :parent_id 0
                                                                                          :qty ""
                                                                                          :title ""
                                                                                          :track_number ""
                                                                                          :updated_at ""
                                                                                          :weight ""}]
                                                                                :updated_at ""}}})
require "http/client"

url = "{{baseUrl}}/V1/shipment/"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"entity\": {\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"customer_id\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\"\n    },\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"sku\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"packages\": [\n      {\n        \"extension_attributes\": {}\n      }\n    ],\n    \"shipment_status\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_label\": \"\",\n    \"store_id\": 0,\n    \"total_qty\": \"\",\n    \"total_weight\": \"\",\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"created_at\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_id\": 0,\n        \"parent_id\": 0,\n        \"qty\": \"\",\n        \"title\": \"\",\n        \"track_number\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"updated_at\": \"\"\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}}/V1/shipment/"),
    Content = new StringContent("{\n  \"entity\": {\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"customer_id\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\"\n    },\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"sku\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"packages\": [\n      {\n        \"extension_attributes\": {}\n      }\n    ],\n    \"shipment_status\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_label\": \"\",\n    \"store_id\": 0,\n    \"total_qty\": \"\",\n    \"total_weight\": \"\",\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"created_at\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_id\": 0,\n        \"parent_id\": 0,\n        \"qty\": \"\",\n        \"title\": \"\",\n        \"track_number\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"updated_at\": \"\"\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}}/V1/shipment/");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"entity\": {\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"customer_id\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\"\n    },\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"sku\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"packages\": [\n      {\n        \"extension_attributes\": {}\n      }\n    ],\n    \"shipment_status\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_label\": \"\",\n    \"store_id\": 0,\n    \"total_qty\": \"\",\n    \"total_weight\": \"\",\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"created_at\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_id\": 0,\n        \"parent_id\": 0,\n        \"qty\": \"\",\n        \"title\": \"\",\n        \"track_number\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"updated_at\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/shipment/"

	payload := strings.NewReader("{\n  \"entity\": {\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"customer_id\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\"\n    },\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"sku\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"packages\": [\n      {\n        \"extension_attributes\": {}\n      }\n    ],\n    \"shipment_status\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_label\": \"\",\n    \"store_id\": 0,\n    \"total_qty\": \"\",\n    \"total_weight\": \"\",\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"created_at\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_id\": 0,\n        \"parent_id\": 0,\n        \"qty\": \"\",\n        \"title\": \"\",\n        \"track_number\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"updated_at\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/shipment/ HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1559

{
  "entity": {
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "customer_id": 0,
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "ext_location_id": "",
      "ext_return_shipment_id": "",
      "ext_shipment_id": "",
      "ext_tracking_reference": "",
      "ext_tracking_url": ""
    },
    "increment_id": "",
    "items": [
      {
        "additional_data": "",
        "description": "",
        "entity_id": 0,
        "extension_attributes": {},
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "sku": "",
        "weight": ""
      }
    ],
    "order_id": 0,
    "packages": [
      {
        "extension_attributes": {}
      }
    ],
    "shipment_status": 0,
    "shipping_address_id": 0,
    "shipping_label": "",
    "store_id": 0,
    "total_qty": "",
    "total_weight": "",
    "tracks": [
      {
        "carrier_code": "",
        "created_at": "",
        "description": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_id": 0,
        "parent_id": 0,
        "qty": "",
        "title": "",
        "track_number": "",
        "updated_at": "",
        "weight": ""
      }
    ],
    "updated_at": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/shipment/")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"entity\": {\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"customer_id\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\"\n    },\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"sku\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"packages\": [\n      {\n        \"extension_attributes\": {}\n      }\n    ],\n    \"shipment_status\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_label\": \"\",\n    \"store_id\": 0,\n    \"total_qty\": \"\",\n    \"total_weight\": \"\",\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"created_at\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_id\": 0,\n        \"parent_id\": 0,\n        \"qty\": \"\",\n        \"title\": \"\",\n        \"track_number\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"updated_at\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/shipment/"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"entity\": {\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"customer_id\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\"\n    },\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"sku\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"packages\": [\n      {\n        \"extension_attributes\": {}\n      }\n    ],\n    \"shipment_status\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_label\": \"\",\n    \"store_id\": 0,\n    \"total_qty\": \"\",\n    \"total_weight\": \"\",\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"created_at\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_id\": 0,\n        \"parent_id\": 0,\n        \"qty\": \"\",\n        \"title\": \"\",\n        \"track_number\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"updated_at\": \"\"\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  \"entity\": {\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"customer_id\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\"\n    },\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"sku\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"packages\": [\n      {\n        \"extension_attributes\": {}\n      }\n    ],\n    \"shipment_status\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_label\": \"\",\n    \"store_id\": 0,\n    \"total_qty\": \"\",\n    \"total_weight\": \"\",\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"created_at\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_id\": 0,\n        \"parent_id\": 0,\n        \"qty\": \"\",\n        \"title\": \"\",\n        \"track_number\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"updated_at\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/shipment/")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/shipment/")
  .header("content-type", "application/json")
  .body("{\n  \"entity\": {\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"customer_id\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\"\n    },\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"sku\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"packages\": [\n      {\n        \"extension_attributes\": {}\n      }\n    ],\n    \"shipment_status\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_label\": \"\",\n    \"store_id\": 0,\n    \"total_qty\": \"\",\n    \"total_weight\": \"\",\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"created_at\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_id\": 0,\n        \"parent_id\": 0,\n        \"qty\": \"\",\n        \"title\": \"\",\n        \"track_number\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"updated_at\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  entity: {
    billing_address_id: 0,
    comments: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0
      }
    ],
    created_at: '',
    customer_id: 0,
    email_sent: 0,
    entity_id: 0,
    extension_attributes: {
      ext_location_id: '',
      ext_return_shipment_id: '',
      ext_shipment_id: '',
      ext_tracking_reference: '',
      ext_tracking_url: ''
    },
    increment_id: '',
    items: [
      {
        additional_data: '',
        description: '',
        entity_id: 0,
        extension_attributes: {},
        name: '',
        order_item_id: 0,
        parent_id: 0,
        price: '',
        product_id: 0,
        qty: '',
        row_total: '',
        sku: '',
        weight: ''
      }
    ],
    order_id: 0,
    packages: [
      {
        extension_attributes: {}
      }
    ],
    shipment_status: 0,
    shipping_address_id: 0,
    shipping_label: '',
    store_id: 0,
    total_qty: '',
    total_weight: '',
    tracks: [
      {
        carrier_code: '',
        created_at: '',
        description: '',
        entity_id: 0,
        extension_attributes: {},
        order_id: 0,
        parent_id: 0,
        qty: '',
        title: '',
        track_number: '',
        updated_at: '',
        weight: ''
      }
    ],
    updated_at: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/shipment/');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/shipment/',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      billing_address_id: 0,
      comments: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0
        }
      ],
      created_at: '',
      customer_id: 0,
      email_sent: 0,
      entity_id: 0,
      extension_attributes: {
        ext_location_id: '',
        ext_return_shipment_id: '',
        ext_shipment_id: '',
        ext_tracking_reference: '',
        ext_tracking_url: ''
      },
      increment_id: '',
      items: [
        {
          additional_data: '',
          description: '',
          entity_id: 0,
          extension_attributes: {},
          name: '',
          order_item_id: 0,
          parent_id: 0,
          price: '',
          product_id: 0,
          qty: '',
          row_total: '',
          sku: '',
          weight: ''
        }
      ],
      order_id: 0,
      packages: [{extension_attributes: {}}],
      shipment_status: 0,
      shipping_address_id: 0,
      shipping_label: '',
      store_id: 0,
      total_qty: '',
      total_weight: '',
      tracks: [
        {
          carrier_code: '',
          created_at: '',
          description: '',
          entity_id: 0,
          extension_attributes: {},
          order_id: 0,
          parent_id: 0,
          qty: '',
          title: '',
          track_number: '',
          updated_at: '',
          weight: ''
        }
      ],
      updated_at: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/shipment/';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"billing_address_id":0,"comments":[{"comment":"","created_at":"","entity_id":0,"extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_id":0}],"created_at":"","customer_id":0,"email_sent":0,"entity_id":0,"extension_attributes":{"ext_location_id":"","ext_return_shipment_id":"","ext_shipment_id":"","ext_tracking_reference":"","ext_tracking_url":""},"increment_id":"","items":[{"additional_data":"","description":"","entity_id":0,"extension_attributes":{},"name":"","order_item_id":0,"parent_id":0,"price":"","product_id":0,"qty":"","row_total":"","sku":"","weight":""}],"order_id":0,"packages":[{"extension_attributes":{}}],"shipment_status":0,"shipping_address_id":0,"shipping_label":"","store_id":0,"total_qty":"","total_weight":"","tracks":[{"carrier_code":"","created_at":"","description":"","entity_id":0,"extension_attributes":{},"order_id":0,"parent_id":0,"qty":"","title":"","track_number":"","updated_at":"","weight":""}],"updated_at":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/shipment/',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "entity": {\n    "billing_address_id": 0,\n    "comments": [\n      {\n        "comment": "",\n        "created_at": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "is_customer_notified": 0,\n        "is_visible_on_front": 0,\n        "parent_id": 0\n      }\n    ],\n    "created_at": "",\n    "customer_id": 0,\n    "email_sent": 0,\n    "entity_id": 0,\n    "extension_attributes": {\n      "ext_location_id": "",\n      "ext_return_shipment_id": "",\n      "ext_shipment_id": "",\n      "ext_tracking_reference": "",\n      "ext_tracking_url": ""\n    },\n    "increment_id": "",\n    "items": [\n      {\n        "additional_data": "",\n        "description": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "name": "",\n        "order_item_id": 0,\n        "parent_id": 0,\n        "price": "",\n        "product_id": 0,\n        "qty": "",\n        "row_total": "",\n        "sku": "",\n        "weight": ""\n      }\n    ],\n    "order_id": 0,\n    "packages": [\n      {\n        "extension_attributes": {}\n      }\n    ],\n    "shipment_status": 0,\n    "shipping_address_id": 0,\n    "shipping_label": "",\n    "store_id": 0,\n    "total_qty": "",\n    "total_weight": "",\n    "tracks": [\n      {\n        "carrier_code": "",\n        "created_at": "",\n        "description": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "order_id": 0,\n        "parent_id": 0,\n        "qty": "",\n        "title": "",\n        "track_number": "",\n        "updated_at": "",\n        "weight": ""\n      }\n    ],\n    "updated_at": ""\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  \"entity\": {\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"customer_id\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\"\n    },\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"sku\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"packages\": [\n      {\n        \"extension_attributes\": {}\n      }\n    ],\n    \"shipment_status\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_label\": \"\",\n    \"store_id\": 0,\n    \"total_qty\": \"\",\n    \"total_weight\": \"\",\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"created_at\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_id\": 0,\n        \"parent_id\": 0,\n        \"qty\": \"\",\n        \"title\": \"\",\n        \"track_number\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"updated_at\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/shipment/")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/shipment/',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  entity: {
    billing_address_id: 0,
    comments: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0
      }
    ],
    created_at: '',
    customer_id: 0,
    email_sent: 0,
    entity_id: 0,
    extension_attributes: {
      ext_location_id: '',
      ext_return_shipment_id: '',
      ext_shipment_id: '',
      ext_tracking_reference: '',
      ext_tracking_url: ''
    },
    increment_id: '',
    items: [
      {
        additional_data: '',
        description: '',
        entity_id: 0,
        extension_attributes: {},
        name: '',
        order_item_id: 0,
        parent_id: 0,
        price: '',
        product_id: 0,
        qty: '',
        row_total: '',
        sku: '',
        weight: ''
      }
    ],
    order_id: 0,
    packages: [{extension_attributes: {}}],
    shipment_status: 0,
    shipping_address_id: 0,
    shipping_label: '',
    store_id: 0,
    total_qty: '',
    total_weight: '',
    tracks: [
      {
        carrier_code: '',
        created_at: '',
        description: '',
        entity_id: 0,
        extension_attributes: {},
        order_id: 0,
        parent_id: 0,
        qty: '',
        title: '',
        track_number: '',
        updated_at: '',
        weight: ''
      }
    ],
    updated_at: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/shipment/',
  headers: {'content-type': 'application/json'},
  body: {
    entity: {
      billing_address_id: 0,
      comments: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0
        }
      ],
      created_at: '',
      customer_id: 0,
      email_sent: 0,
      entity_id: 0,
      extension_attributes: {
        ext_location_id: '',
        ext_return_shipment_id: '',
        ext_shipment_id: '',
        ext_tracking_reference: '',
        ext_tracking_url: ''
      },
      increment_id: '',
      items: [
        {
          additional_data: '',
          description: '',
          entity_id: 0,
          extension_attributes: {},
          name: '',
          order_item_id: 0,
          parent_id: 0,
          price: '',
          product_id: 0,
          qty: '',
          row_total: '',
          sku: '',
          weight: ''
        }
      ],
      order_id: 0,
      packages: [{extension_attributes: {}}],
      shipment_status: 0,
      shipping_address_id: 0,
      shipping_label: '',
      store_id: 0,
      total_qty: '',
      total_weight: '',
      tracks: [
        {
          carrier_code: '',
          created_at: '',
          description: '',
          entity_id: 0,
          extension_attributes: {},
          order_id: 0,
          parent_id: 0,
          qty: '',
          title: '',
          track_number: '',
          updated_at: '',
          weight: ''
        }
      ],
      updated_at: ''
    }
  },
  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}}/V1/shipment/');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  entity: {
    billing_address_id: 0,
    comments: [
      {
        comment: '',
        created_at: '',
        entity_id: 0,
        extension_attributes: {},
        is_customer_notified: 0,
        is_visible_on_front: 0,
        parent_id: 0
      }
    ],
    created_at: '',
    customer_id: 0,
    email_sent: 0,
    entity_id: 0,
    extension_attributes: {
      ext_location_id: '',
      ext_return_shipment_id: '',
      ext_shipment_id: '',
      ext_tracking_reference: '',
      ext_tracking_url: ''
    },
    increment_id: '',
    items: [
      {
        additional_data: '',
        description: '',
        entity_id: 0,
        extension_attributes: {},
        name: '',
        order_item_id: 0,
        parent_id: 0,
        price: '',
        product_id: 0,
        qty: '',
        row_total: '',
        sku: '',
        weight: ''
      }
    ],
    order_id: 0,
    packages: [
      {
        extension_attributes: {}
      }
    ],
    shipment_status: 0,
    shipping_address_id: 0,
    shipping_label: '',
    store_id: 0,
    total_qty: '',
    total_weight: '',
    tracks: [
      {
        carrier_code: '',
        created_at: '',
        description: '',
        entity_id: 0,
        extension_attributes: {},
        order_id: 0,
        parent_id: 0,
        qty: '',
        title: '',
        track_number: '',
        updated_at: '',
        weight: ''
      }
    ],
    updated_at: ''
  }
});

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}}/V1/shipment/',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      billing_address_id: 0,
      comments: [
        {
          comment: '',
          created_at: '',
          entity_id: 0,
          extension_attributes: {},
          is_customer_notified: 0,
          is_visible_on_front: 0,
          parent_id: 0
        }
      ],
      created_at: '',
      customer_id: 0,
      email_sent: 0,
      entity_id: 0,
      extension_attributes: {
        ext_location_id: '',
        ext_return_shipment_id: '',
        ext_shipment_id: '',
        ext_tracking_reference: '',
        ext_tracking_url: ''
      },
      increment_id: '',
      items: [
        {
          additional_data: '',
          description: '',
          entity_id: 0,
          extension_attributes: {},
          name: '',
          order_item_id: 0,
          parent_id: 0,
          price: '',
          product_id: 0,
          qty: '',
          row_total: '',
          sku: '',
          weight: ''
        }
      ],
      order_id: 0,
      packages: [{extension_attributes: {}}],
      shipment_status: 0,
      shipping_address_id: 0,
      shipping_label: '',
      store_id: 0,
      total_qty: '',
      total_weight: '',
      tracks: [
        {
          carrier_code: '',
          created_at: '',
          description: '',
          entity_id: 0,
          extension_attributes: {},
          order_id: 0,
          parent_id: 0,
          qty: '',
          title: '',
          track_number: '',
          updated_at: '',
          weight: ''
        }
      ],
      updated_at: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/shipment/';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"billing_address_id":0,"comments":[{"comment":"","created_at":"","entity_id":0,"extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_id":0}],"created_at":"","customer_id":0,"email_sent":0,"entity_id":0,"extension_attributes":{"ext_location_id":"","ext_return_shipment_id":"","ext_shipment_id":"","ext_tracking_reference":"","ext_tracking_url":""},"increment_id":"","items":[{"additional_data":"","description":"","entity_id":0,"extension_attributes":{},"name":"","order_item_id":0,"parent_id":0,"price":"","product_id":0,"qty":"","row_total":"","sku":"","weight":""}],"order_id":0,"packages":[{"extension_attributes":{}}],"shipment_status":0,"shipping_address_id":0,"shipping_label":"","store_id":0,"total_qty":"","total_weight":"","tracks":[{"carrier_code":"","created_at":"","description":"","entity_id":0,"extension_attributes":{},"order_id":0,"parent_id":0,"qty":"","title":"","track_number":"","updated_at":"","weight":""}],"updated_at":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"entity": @{ @"billing_address_id": @0, @"comments": @[ @{ @"comment": @"", @"created_at": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"is_customer_notified": @0, @"is_visible_on_front": @0, @"parent_id": @0 } ], @"created_at": @"", @"customer_id": @0, @"email_sent": @0, @"entity_id": @0, @"extension_attributes": @{ @"ext_location_id": @"", @"ext_return_shipment_id": @"", @"ext_shipment_id": @"", @"ext_tracking_reference": @"", @"ext_tracking_url": @"" }, @"increment_id": @"", @"items": @[ @{ @"additional_data": @"", @"description": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"name": @"", @"order_item_id": @0, @"parent_id": @0, @"price": @"", @"product_id": @0, @"qty": @"", @"row_total": @"", @"sku": @"", @"weight": @"" } ], @"order_id": @0, @"packages": @[ @{ @"extension_attributes": @{  } } ], @"shipment_status": @0, @"shipping_address_id": @0, @"shipping_label": @"", @"store_id": @0, @"total_qty": @"", @"total_weight": @"", @"tracks": @[ @{ @"carrier_code": @"", @"created_at": @"", @"description": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"order_id": @0, @"parent_id": @0, @"qty": @"", @"title": @"", @"track_number": @"", @"updated_at": @"", @"weight": @"" } ], @"updated_at": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/shipment/"]
                                                       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}}/V1/shipment/" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"entity\": {\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"customer_id\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\"\n    },\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"sku\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"packages\": [\n      {\n        \"extension_attributes\": {}\n      }\n    ],\n    \"shipment_status\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_label\": \"\",\n    \"store_id\": 0,\n    \"total_qty\": \"\",\n    \"total_weight\": \"\",\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"created_at\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_id\": 0,\n        \"parent_id\": 0,\n        \"qty\": \"\",\n        \"title\": \"\",\n        \"track_number\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"updated_at\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/shipment/",
  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([
    'entity' => [
        'billing_address_id' => 0,
        'comments' => [
                [
                                'comment' => '',
                                'created_at' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'is_customer_notified' => 0,
                                'is_visible_on_front' => 0,
                                'parent_id' => 0
                ]
        ],
        'created_at' => '',
        'customer_id' => 0,
        'email_sent' => 0,
        'entity_id' => 0,
        'extension_attributes' => [
                'ext_location_id' => '',
                'ext_return_shipment_id' => '',
                'ext_shipment_id' => '',
                'ext_tracking_reference' => '',
                'ext_tracking_url' => ''
        ],
        'increment_id' => '',
        'items' => [
                [
                                'additional_data' => '',
                                'description' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'name' => '',
                                'order_item_id' => 0,
                                'parent_id' => 0,
                                'price' => '',
                                'product_id' => 0,
                                'qty' => '',
                                'row_total' => '',
                                'sku' => '',
                                'weight' => ''
                ]
        ],
        'order_id' => 0,
        'packages' => [
                [
                                'extension_attributes' => [
                                                                
                                ]
                ]
        ],
        'shipment_status' => 0,
        'shipping_address_id' => 0,
        'shipping_label' => '',
        'store_id' => 0,
        'total_qty' => '',
        'total_weight' => '',
        'tracks' => [
                [
                                'carrier_code' => '',
                                'created_at' => '',
                                'description' => '',
                                'entity_id' => 0,
                                'extension_attributes' => [
                                                                
                                ],
                                'order_id' => 0,
                                'parent_id' => 0,
                                'qty' => '',
                                'title' => '',
                                'track_number' => '',
                                'updated_at' => '',
                                'weight' => ''
                ]
        ],
        'updated_at' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/shipment/', [
  'body' => '{
  "entity": {
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "customer_id": 0,
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "ext_location_id": "",
      "ext_return_shipment_id": "",
      "ext_shipment_id": "",
      "ext_tracking_reference": "",
      "ext_tracking_url": ""
    },
    "increment_id": "",
    "items": [
      {
        "additional_data": "",
        "description": "",
        "entity_id": 0,
        "extension_attributes": {},
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "sku": "",
        "weight": ""
      }
    ],
    "order_id": 0,
    "packages": [
      {
        "extension_attributes": {}
      }
    ],
    "shipment_status": 0,
    "shipping_address_id": 0,
    "shipping_label": "",
    "store_id": 0,
    "total_qty": "",
    "total_weight": "",
    "tracks": [
      {
        "carrier_code": "",
        "created_at": "",
        "description": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_id": 0,
        "parent_id": 0,
        "qty": "",
        "title": "",
        "track_number": "",
        "updated_at": "",
        "weight": ""
      }
    ],
    "updated_at": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/shipment/');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'entity' => [
    'billing_address_id' => 0,
    'comments' => [
        [
                'comment' => '',
                'created_at' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'is_customer_notified' => 0,
                'is_visible_on_front' => 0,
                'parent_id' => 0
        ]
    ],
    'created_at' => '',
    'customer_id' => 0,
    'email_sent' => 0,
    'entity_id' => 0,
    'extension_attributes' => [
        'ext_location_id' => '',
        'ext_return_shipment_id' => '',
        'ext_shipment_id' => '',
        'ext_tracking_reference' => '',
        'ext_tracking_url' => ''
    ],
    'increment_id' => '',
    'items' => [
        [
                'additional_data' => '',
                'description' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'name' => '',
                'order_item_id' => 0,
                'parent_id' => 0,
                'price' => '',
                'product_id' => 0,
                'qty' => '',
                'row_total' => '',
                'sku' => '',
                'weight' => ''
        ]
    ],
    'order_id' => 0,
    'packages' => [
        [
                'extension_attributes' => [
                                
                ]
        ]
    ],
    'shipment_status' => 0,
    'shipping_address_id' => 0,
    'shipping_label' => '',
    'store_id' => 0,
    'total_qty' => '',
    'total_weight' => '',
    'tracks' => [
        [
                'carrier_code' => '',
                'created_at' => '',
                'description' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'order_id' => 0,
                'parent_id' => 0,
                'qty' => '',
                'title' => '',
                'track_number' => '',
                'updated_at' => '',
                'weight' => ''
        ]
    ],
    'updated_at' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'entity' => [
    'billing_address_id' => 0,
    'comments' => [
        [
                'comment' => '',
                'created_at' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'is_customer_notified' => 0,
                'is_visible_on_front' => 0,
                'parent_id' => 0
        ]
    ],
    'created_at' => '',
    'customer_id' => 0,
    'email_sent' => 0,
    'entity_id' => 0,
    'extension_attributes' => [
        'ext_location_id' => '',
        'ext_return_shipment_id' => '',
        'ext_shipment_id' => '',
        'ext_tracking_reference' => '',
        'ext_tracking_url' => ''
    ],
    'increment_id' => '',
    'items' => [
        [
                'additional_data' => '',
                'description' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'name' => '',
                'order_item_id' => 0,
                'parent_id' => 0,
                'price' => '',
                'product_id' => 0,
                'qty' => '',
                'row_total' => '',
                'sku' => '',
                'weight' => ''
        ]
    ],
    'order_id' => 0,
    'packages' => [
        [
                'extension_attributes' => [
                                
                ]
        ]
    ],
    'shipment_status' => 0,
    'shipping_address_id' => 0,
    'shipping_label' => '',
    'store_id' => 0,
    'total_qty' => '',
    'total_weight' => '',
    'tracks' => [
        [
                'carrier_code' => '',
                'created_at' => '',
                'description' => '',
                'entity_id' => 0,
                'extension_attributes' => [
                                
                ],
                'order_id' => 0,
                'parent_id' => 0,
                'qty' => '',
                'title' => '',
                'track_number' => '',
                'updated_at' => '',
                'weight' => ''
        ]
    ],
    'updated_at' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/shipment/');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/shipment/' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "customer_id": 0,
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "ext_location_id": "",
      "ext_return_shipment_id": "",
      "ext_shipment_id": "",
      "ext_tracking_reference": "",
      "ext_tracking_url": ""
    },
    "increment_id": "",
    "items": [
      {
        "additional_data": "",
        "description": "",
        "entity_id": 0,
        "extension_attributes": {},
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "sku": "",
        "weight": ""
      }
    ],
    "order_id": 0,
    "packages": [
      {
        "extension_attributes": {}
      }
    ],
    "shipment_status": 0,
    "shipping_address_id": 0,
    "shipping_label": "",
    "store_id": 0,
    "total_qty": "",
    "total_weight": "",
    "tracks": [
      {
        "carrier_code": "",
        "created_at": "",
        "description": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_id": 0,
        "parent_id": 0,
        "qty": "",
        "title": "",
        "track_number": "",
        "updated_at": "",
        "weight": ""
      }
    ],
    "updated_at": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/shipment/' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "customer_id": 0,
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "ext_location_id": "",
      "ext_return_shipment_id": "",
      "ext_shipment_id": "",
      "ext_tracking_reference": "",
      "ext_tracking_url": ""
    },
    "increment_id": "",
    "items": [
      {
        "additional_data": "",
        "description": "",
        "entity_id": 0,
        "extension_attributes": {},
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "sku": "",
        "weight": ""
      }
    ],
    "order_id": 0,
    "packages": [
      {
        "extension_attributes": {}
      }
    ],
    "shipment_status": 0,
    "shipping_address_id": 0,
    "shipping_label": "",
    "store_id": 0,
    "total_qty": "",
    "total_weight": "",
    "tracks": [
      {
        "carrier_code": "",
        "created_at": "",
        "description": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_id": 0,
        "parent_id": 0,
        "qty": "",
        "title": "",
        "track_number": "",
        "updated_at": "",
        "weight": ""
      }
    ],
    "updated_at": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"entity\": {\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"customer_id\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\"\n    },\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"sku\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"packages\": [\n      {\n        \"extension_attributes\": {}\n      }\n    ],\n    \"shipment_status\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_label\": \"\",\n    \"store_id\": 0,\n    \"total_qty\": \"\",\n    \"total_weight\": \"\",\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"created_at\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_id\": 0,\n        \"parent_id\": 0,\n        \"qty\": \"\",\n        \"title\": \"\",\n        \"track_number\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"updated_at\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/shipment/", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/shipment/"

payload = { "entity": {
        "billing_address_id": 0,
        "comments": [
            {
                "comment": "",
                "created_at": "",
                "entity_id": 0,
                "extension_attributes": {},
                "is_customer_notified": 0,
                "is_visible_on_front": 0,
                "parent_id": 0
            }
        ],
        "created_at": "",
        "customer_id": 0,
        "email_sent": 0,
        "entity_id": 0,
        "extension_attributes": {
            "ext_location_id": "",
            "ext_return_shipment_id": "",
            "ext_shipment_id": "",
            "ext_tracking_reference": "",
            "ext_tracking_url": ""
        },
        "increment_id": "",
        "items": [
            {
                "additional_data": "",
                "description": "",
                "entity_id": 0,
                "extension_attributes": {},
                "name": "",
                "order_item_id": 0,
                "parent_id": 0,
                "price": "",
                "product_id": 0,
                "qty": "",
                "row_total": "",
                "sku": "",
                "weight": ""
            }
        ],
        "order_id": 0,
        "packages": [{ "extension_attributes": {} }],
        "shipment_status": 0,
        "shipping_address_id": 0,
        "shipping_label": "",
        "store_id": 0,
        "total_qty": "",
        "total_weight": "",
        "tracks": [
            {
                "carrier_code": "",
                "created_at": "",
                "description": "",
                "entity_id": 0,
                "extension_attributes": {},
                "order_id": 0,
                "parent_id": 0,
                "qty": "",
                "title": "",
                "track_number": "",
                "updated_at": "",
                "weight": ""
            }
        ],
        "updated_at": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/shipment/"

payload <- "{\n  \"entity\": {\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"customer_id\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\"\n    },\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"sku\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"packages\": [\n      {\n        \"extension_attributes\": {}\n      }\n    ],\n    \"shipment_status\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_label\": \"\",\n    \"store_id\": 0,\n    \"total_qty\": \"\",\n    \"total_weight\": \"\",\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"created_at\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_id\": 0,\n        \"parent_id\": 0,\n        \"qty\": \"\",\n        \"title\": \"\",\n        \"track_number\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"updated_at\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/shipment/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"entity\": {\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"customer_id\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\"\n    },\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"sku\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"packages\": [\n      {\n        \"extension_attributes\": {}\n      }\n    ],\n    \"shipment_status\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_label\": \"\",\n    \"store_id\": 0,\n    \"total_qty\": \"\",\n    \"total_weight\": \"\",\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"created_at\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_id\": 0,\n        \"parent_id\": 0,\n        \"qty\": \"\",\n        \"title\": \"\",\n        \"track_number\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"updated_at\": \"\"\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/V1/shipment/') do |req|
  req.body = "{\n  \"entity\": {\n    \"billing_address_id\": 0,\n    \"comments\": [\n      {\n        \"comment\": \"\",\n        \"created_at\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"is_customer_notified\": 0,\n        \"is_visible_on_front\": 0,\n        \"parent_id\": 0\n      }\n    ],\n    \"created_at\": \"\",\n    \"customer_id\": 0,\n    \"email_sent\": 0,\n    \"entity_id\": 0,\n    \"extension_attributes\": {\n      \"ext_location_id\": \"\",\n      \"ext_return_shipment_id\": \"\",\n      \"ext_shipment_id\": \"\",\n      \"ext_tracking_reference\": \"\",\n      \"ext_tracking_url\": \"\"\n    },\n    \"increment_id\": \"\",\n    \"items\": [\n      {\n        \"additional_data\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"name\": \"\",\n        \"order_item_id\": 0,\n        \"parent_id\": 0,\n        \"price\": \"\",\n        \"product_id\": 0,\n        \"qty\": \"\",\n        \"row_total\": \"\",\n        \"sku\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"order_id\": 0,\n    \"packages\": [\n      {\n        \"extension_attributes\": {}\n      }\n    ],\n    \"shipment_status\": 0,\n    \"shipping_address_id\": 0,\n    \"shipping_label\": \"\",\n    \"store_id\": 0,\n    \"total_qty\": \"\",\n    \"total_weight\": \"\",\n    \"tracks\": [\n      {\n        \"carrier_code\": \"\",\n        \"created_at\": \"\",\n        \"description\": \"\",\n        \"entity_id\": 0,\n        \"extension_attributes\": {},\n        \"order_id\": 0,\n        \"parent_id\": 0,\n        \"qty\": \"\",\n        \"title\": \"\",\n        \"track_number\": \"\",\n        \"updated_at\": \"\",\n        \"weight\": \"\"\n      }\n    ],\n    \"updated_at\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/shipment/";

    let payload = json!({"entity": json!({
            "billing_address_id": 0,
            "comments": (
                json!({
                    "comment": "",
                    "created_at": "",
                    "entity_id": 0,
                    "extension_attributes": json!({}),
                    "is_customer_notified": 0,
                    "is_visible_on_front": 0,
                    "parent_id": 0
                })
            ),
            "created_at": "",
            "customer_id": 0,
            "email_sent": 0,
            "entity_id": 0,
            "extension_attributes": json!({
                "ext_location_id": "",
                "ext_return_shipment_id": "",
                "ext_shipment_id": "",
                "ext_tracking_reference": "",
                "ext_tracking_url": ""
            }),
            "increment_id": "",
            "items": (
                json!({
                    "additional_data": "",
                    "description": "",
                    "entity_id": 0,
                    "extension_attributes": json!({}),
                    "name": "",
                    "order_item_id": 0,
                    "parent_id": 0,
                    "price": "",
                    "product_id": 0,
                    "qty": "",
                    "row_total": "",
                    "sku": "",
                    "weight": ""
                })
            ),
            "order_id": 0,
            "packages": (json!({"extension_attributes": json!({})})),
            "shipment_status": 0,
            "shipping_address_id": 0,
            "shipping_label": "",
            "store_id": 0,
            "total_qty": "",
            "total_weight": "",
            "tracks": (
                json!({
                    "carrier_code": "",
                    "created_at": "",
                    "description": "",
                    "entity_id": 0,
                    "extension_attributes": json!({}),
                    "order_id": 0,
                    "parent_id": 0,
                    "qty": "",
                    "title": "",
                    "track_number": "",
                    "updated_at": "",
                    "weight": ""
                })
            ),
            "updated_at": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/shipment/ \
  --header 'content-type: application/json' \
  --data '{
  "entity": {
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "customer_id": 0,
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "ext_location_id": "",
      "ext_return_shipment_id": "",
      "ext_shipment_id": "",
      "ext_tracking_reference": "",
      "ext_tracking_url": ""
    },
    "increment_id": "",
    "items": [
      {
        "additional_data": "",
        "description": "",
        "entity_id": 0,
        "extension_attributes": {},
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "sku": "",
        "weight": ""
      }
    ],
    "order_id": 0,
    "packages": [
      {
        "extension_attributes": {}
      }
    ],
    "shipment_status": 0,
    "shipping_address_id": 0,
    "shipping_label": "",
    "store_id": 0,
    "total_qty": "",
    "total_weight": "",
    "tracks": [
      {
        "carrier_code": "",
        "created_at": "",
        "description": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_id": 0,
        "parent_id": 0,
        "qty": "",
        "title": "",
        "track_number": "",
        "updated_at": "",
        "weight": ""
      }
    ],
    "updated_at": ""
  }
}'
echo '{
  "entity": {
    "billing_address_id": 0,
    "comments": [
      {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      }
    ],
    "created_at": "",
    "customer_id": 0,
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": {
      "ext_location_id": "",
      "ext_return_shipment_id": "",
      "ext_shipment_id": "",
      "ext_tracking_reference": "",
      "ext_tracking_url": ""
    },
    "increment_id": "",
    "items": [
      {
        "additional_data": "",
        "description": "",
        "entity_id": 0,
        "extension_attributes": {},
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "sku": "",
        "weight": ""
      }
    ],
    "order_id": 0,
    "packages": [
      {
        "extension_attributes": {}
      }
    ],
    "shipment_status": 0,
    "shipping_address_id": 0,
    "shipping_label": "",
    "store_id": 0,
    "total_qty": "",
    "total_weight": "",
    "tracks": [
      {
        "carrier_code": "",
        "created_at": "",
        "description": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_id": 0,
        "parent_id": 0,
        "qty": "",
        "title": "",
        "track_number": "",
        "updated_at": "",
        "weight": ""
      }
    ],
    "updated_at": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/shipment/ \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "entity": {\n    "billing_address_id": 0,\n    "comments": [\n      {\n        "comment": "",\n        "created_at": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "is_customer_notified": 0,\n        "is_visible_on_front": 0,\n        "parent_id": 0\n      }\n    ],\n    "created_at": "",\n    "customer_id": 0,\n    "email_sent": 0,\n    "entity_id": 0,\n    "extension_attributes": {\n      "ext_location_id": "",\n      "ext_return_shipment_id": "",\n      "ext_shipment_id": "",\n      "ext_tracking_reference": "",\n      "ext_tracking_url": ""\n    },\n    "increment_id": "",\n    "items": [\n      {\n        "additional_data": "",\n        "description": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "name": "",\n        "order_item_id": 0,\n        "parent_id": 0,\n        "price": "",\n        "product_id": 0,\n        "qty": "",\n        "row_total": "",\n        "sku": "",\n        "weight": ""\n      }\n    ],\n    "order_id": 0,\n    "packages": [\n      {\n        "extension_attributes": {}\n      }\n    ],\n    "shipment_status": 0,\n    "shipping_address_id": 0,\n    "shipping_label": "",\n    "store_id": 0,\n    "total_qty": "",\n    "total_weight": "",\n    "tracks": [\n      {\n        "carrier_code": "",\n        "created_at": "",\n        "description": "",\n        "entity_id": 0,\n        "extension_attributes": {},\n        "order_id": 0,\n        "parent_id": 0,\n        "qty": "",\n        "title": "",\n        "track_number": "",\n        "updated_at": "",\n        "weight": ""\n      }\n    ],\n    "updated_at": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/shipment/
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["entity": [
    "billing_address_id": 0,
    "comments": [
      [
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": [],
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
      ]
    ],
    "created_at": "",
    "customer_id": 0,
    "email_sent": 0,
    "entity_id": 0,
    "extension_attributes": [
      "ext_location_id": "",
      "ext_return_shipment_id": "",
      "ext_shipment_id": "",
      "ext_tracking_reference": "",
      "ext_tracking_url": ""
    ],
    "increment_id": "",
    "items": [
      [
        "additional_data": "",
        "description": "",
        "entity_id": 0,
        "extension_attributes": [],
        "name": "",
        "order_item_id": 0,
        "parent_id": 0,
        "price": "",
        "product_id": 0,
        "qty": "",
        "row_total": "",
        "sku": "",
        "weight": ""
      ]
    ],
    "order_id": 0,
    "packages": [["extension_attributes": []]],
    "shipment_status": 0,
    "shipping_address_id": 0,
    "shipping_label": "",
    "store_id": 0,
    "total_qty": "",
    "total_weight": "",
    "tracks": [
      [
        "carrier_code": "",
        "created_at": "",
        "description": "",
        "entity_id": 0,
        "extension_attributes": [],
        "order_id": 0,
        "parent_id": 0,
        "qty": "",
        "title": "",
        "track_number": "",
        "updated_at": "",
        "weight": ""
      ]
    ],
    "updated_at": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/shipment/")! 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 shipment-{id}
{{baseUrl}}/V1/shipment/:id
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/shipment/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/shipment/:id")
require "http/client"

url = "{{baseUrl}}/V1/shipment/:id"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/shipment/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/shipment/:id");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/shipment/:id"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/shipment/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/shipment/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/shipment/:id"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/shipment/:id")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/shipment/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/shipment/:id');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/shipment/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/shipment/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/shipment/:id',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/shipment/:id")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/shipment/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/shipment/:id'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/shipment/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/shipment/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/shipment/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/shipment/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/shipment/:id" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/shipment/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/shipment/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/shipment/:id');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/shipment/:id');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/shipment/:id' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/shipment/:id' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/shipment/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/shipment/:id"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/shipment/:id"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/shipment/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/shipment/:id') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/shipment/:id";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/shipment/:id
http GET {{baseUrl}}/V1/shipment/:id
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/shipment/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/shipment/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST shipment-{id}-comments (POST)
{{baseUrl}}/V1/shipment/:id/comments
QUERY PARAMS

id
BODY json

{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/shipment/:id/comments");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/shipment/:id/comments" {:content-type :json
                                                                     :form-params {:entity {:comment ""
                                                                                            :created_at ""
                                                                                            :entity_id 0
                                                                                            :extension_attributes {}
                                                                                            :is_customer_notified 0
                                                                                            :is_visible_on_front 0
                                                                                            :parent_id 0}}})
require "http/client"

url = "{{baseUrl}}/V1/shipment/:id/comments"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\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}}/V1/shipment/:id/comments"),
    Content = new StringContent("{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\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}}/V1/shipment/:id/comments");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/shipment/:id/comments"

	payload := strings.NewReader("{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/shipment/:id/comments HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 194

{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/shipment/:id/comments")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/shipment/:id/comments"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\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  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/shipment/:id/comments")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/shipment/:id/comments")
  .header("content-type", "application/json")
  .body("{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  entity: {
    comment: '',
    created_at: '',
    entity_id: 0,
    extension_attributes: {},
    is_customer_notified: 0,
    is_visible_on_front: 0,
    parent_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}}/V1/shipment/:id/comments');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/shipment/:id/comments',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      comment: '',
      created_at: '',
      entity_id: 0,
      extension_attributes: {},
      is_customer_notified: 0,
      is_visible_on_front: 0,
      parent_id: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/shipment/:id/comments';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"comment":"","created_at":"","entity_id":0,"extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_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}}/V1/shipment/:id/comments',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "entity": {\n    "comment": "",\n    "created_at": "",\n    "entity_id": 0,\n    "extension_attributes": {},\n    "is_customer_notified": 0,\n    "is_visible_on_front": 0,\n    "parent_id": 0\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  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/shipment/:id/comments")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/shipment/:id/comments',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  entity: {
    comment: '',
    created_at: '',
    entity_id: 0,
    extension_attributes: {},
    is_customer_notified: 0,
    is_visible_on_front: 0,
    parent_id: 0
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/shipment/:id/comments',
  headers: {'content-type': 'application/json'},
  body: {
    entity: {
      comment: '',
      created_at: '',
      entity_id: 0,
      extension_attributes: {},
      is_customer_notified: 0,
      is_visible_on_front: 0,
      parent_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}}/V1/shipment/:id/comments');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  entity: {
    comment: '',
    created_at: '',
    entity_id: 0,
    extension_attributes: {},
    is_customer_notified: 0,
    is_visible_on_front: 0,
    parent_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}}/V1/shipment/:id/comments',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      comment: '',
      created_at: '',
      entity_id: 0,
      extension_attributes: {},
      is_customer_notified: 0,
      is_visible_on_front: 0,
      parent_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}}/V1/shipment/:id/comments';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"comment":"","created_at":"","entity_id":0,"extension_attributes":{},"is_customer_notified":0,"is_visible_on_front":0,"parent_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 = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"entity": @{ @"comment": @"", @"created_at": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"is_customer_notified": @0, @"is_visible_on_front": @0, @"parent_id": @0 } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/shipment/:id/comments"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/shipment/:id/comments" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/shipment/:id/comments",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'entity' => [
        'comment' => '',
        'created_at' => '',
        'entity_id' => 0,
        'extension_attributes' => [
                
        ],
        'is_customer_notified' => 0,
        'is_visible_on_front' => 0,
        'parent_id' => 0
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/shipment/:id/comments', [
  'body' => '{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/shipment/:id/comments');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'entity' => [
    'comment' => '',
    'created_at' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'is_customer_notified' => 0,
    'is_visible_on_front' => 0,
    'parent_id' => 0
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'entity' => [
    'comment' => '',
    'created_at' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'is_customer_notified' => 0,
    'is_visible_on_front' => 0,
    'parent_id' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/shipment/:id/comments');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/shipment/:id/comments' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/shipment/:id/comments' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/shipment/:id/comments", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/shipment/:id/comments"

payload = { "entity": {
        "comment": "",
        "created_at": "",
        "entity_id": 0,
        "extension_attributes": {},
        "is_customer_notified": 0,
        "is_visible_on_front": 0,
        "parent_id": 0
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/shipment/:id/comments"

payload <- "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/shipment/:id/comments")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\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/V1/shipment/:id/comments') do |req|
  req.body = "{\n  \"entity\": {\n    \"comment\": \"\",\n    \"created_at\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"is_customer_notified\": 0,\n    \"is_visible_on_front\": 0,\n    \"parent_id\": 0\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/shipment/:id/comments";

    let payload = json!({"entity": json!({
            "comment": "",
            "created_at": "",
            "entity_id": 0,
            "extension_attributes": json!({}),
            "is_customer_notified": 0,
            "is_visible_on_front": 0,
            "parent_id": 0
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/shipment/:id/comments \
  --header 'content-type: application/json' \
  --data '{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}'
echo '{
  "entity": {
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": {},
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  }
}' |  \
  http POST {{baseUrl}}/V1/shipment/:id/comments \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "entity": {\n    "comment": "",\n    "created_at": "",\n    "entity_id": 0,\n    "extension_attributes": {},\n    "is_customer_notified": 0,\n    "is_visible_on_front": 0,\n    "parent_id": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/shipment/:id/comments
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["entity": [
    "comment": "",
    "created_at": "",
    "entity_id": 0,
    "extension_attributes": [],
    "is_customer_notified": 0,
    "is_visible_on_front": 0,
    "parent_id": 0
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/shipment/:id/comments")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET shipment-{id}-comments
{{baseUrl}}/V1/shipment/:id/comments
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/shipment/:id/comments");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/shipment/:id/comments")
require "http/client"

url = "{{baseUrl}}/V1/shipment/:id/comments"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/shipment/:id/comments"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/shipment/:id/comments");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/shipment/:id/comments"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/shipment/:id/comments HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/shipment/:id/comments")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/shipment/:id/comments"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/shipment/:id/comments")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/shipment/:id/comments")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/shipment/:id/comments');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/shipment/:id/comments'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/shipment/:id/comments';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/shipment/:id/comments',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/shipment/:id/comments")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/shipment/:id/comments',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/shipment/:id/comments'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/shipment/:id/comments');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/shipment/:id/comments'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/shipment/:id/comments';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/shipment/:id/comments"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/shipment/:id/comments" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/shipment/:id/comments",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/shipment/:id/comments');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/shipment/:id/comments');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/shipment/:id/comments');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/shipment/:id/comments' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/shipment/:id/comments' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/shipment/:id/comments")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/shipment/:id/comments"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/shipment/:id/comments"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/shipment/:id/comments")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/shipment/:id/comments') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/shipment/:id/comments";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/shipment/:id/comments
http GET {{baseUrl}}/V1/shipment/:id/comments
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/shipment/:id/comments
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/shipment/:id/comments")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST shipment-{id}-emails
{{baseUrl}}/V1/shipment/:id/emails
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/shipment/:id/emails");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/shipment/:id/emails")
require "http/client"

url = "{{baseUrl}}/V1/shipment/:id/emails"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/V1/shipment/:id/emails"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/shipment/:id/emails");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/shipment/:id/emails"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/shipment/:id/emails HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/shipment/:id/emails")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/shipment/:id/emails"))
    .method("POST", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/shipment/:id/emails")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/shipment/:id/emails")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/shipment/:id/emails');

xhr.send(data);
import axios from 'axios';

const options = {method: 'POST', url: '{{baseUrl}}/V1/shipment/:id/emails'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/shipment/:id/emails';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/shipment/:id/emails',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/shipment/:id/emails")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/shipment/:id/emails',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'POST', url: '{{baseUrl}}/V1/shipment/:id/emails'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/shipment/:id/emails');

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}}/V1/shipment/:id/emails'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/shipment/:id/emails';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/shipment/:id/emails"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/shipment/:id/emails" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/shipment/:id/emails",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/shipment/:id/emails');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/shipment/:id/emails');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/shipment/:id/emails');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/shipment/:id/emails' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/shipment/:id/emails' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/V1/shipment/:id/emails")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/shipment/:id/emails"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/shipment/:id/emails"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/shipment/:id/emails")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/V1/shipment/:id/emails') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/shipment/:id/emails";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/shipment/:id/emails
http POST {{baseUrl}}/V1/shipment/:id/emails
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/V1/shipment/:id/emails
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/shipment/:id/emails")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET shipment-{id}-label
{{baseUrl}}/V1/shipment/:id/label
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/shipment/:id/label");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/shipment/:id/label")
require "http/client"

url = "{{baseUrl}}/V1/shipment/:id/label"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/shipment/:id/label"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/shipment/:id/label");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/shipment/:id/label"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/shipment/:id/label HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/shipment/:id/label")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/shipment/:id/label"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/shipment/:id/label")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/shipment/:id/label")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/shipment/:id/label');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/shipment/:id/label'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/shipment/:id/label';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/shipment/:id/label',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/shipment/:id/label")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/shipment/:id/label',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/shipment/:id/label'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/shipment/:id/label');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/shipment/:id/label'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/shipment/:id/label';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/shipment/:id/label"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/shipment/:id/label" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/shipment/:id/label",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/shipment/:id/label');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/shipment/:id/label');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/shipment/:id/label');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/shipment/:id/label' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/shipment/:id/label' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/shipment/:id/label")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/shipment/:id/label"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/shipment/:id/label"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/shipment/:id/label")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/shipment/:id/label') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/shipment/:id/label";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/shipment/:id/label
http GET {{baseUrl}}/V1/shipment/:id/label
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/shipment/:id/label
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/shipment/:id/label")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST shipment-track
{{baseUrl}}/V1/shipment/track
BODY json

{
  "entity": {
    "carrier_code": "",
    "created_at": "",
    "description": "",
    "entity_id": 0,
    "extension_attributes": {},
    "order_id": 0,
    "parent_id": 0,
    "qty": "",
    "title": "",
    "track_number": "",
    "updated_at": "",
    "weight": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/shipment/track");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"entity\": {\n    \"carrier_code\": \"\",\n    \"created_at\": \"\",\n    \"description\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"order_id\": 0,\n    \"parent_id\": 0,\n    \"qty\": \"\",\n    \"title\": \"\",\n    \"track_number\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/shipment/track" {:content-type :json
                                                              :form-params {:entity {:carrier_code ""
                                                                                     :created_at ""
                                                                                     :description ""
                                                                                     :entity_id 0
                                                                                     :extension_attributes {}
                                                                                     :order_id 0
                                                                                     :parent_id 0
                                                                                     :qty ""
                                                                                     :title ""
                                                                                     :track_number ""
                                                                                     :updated_at ""
                                                                                     :weight ""}}})
require "http/client"

url = "{{baseUrl}}/V1/shipment/track"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"entity\": {\n    \"carrier_code\": \"\",\n    \"created_at\": \"\",\n    \"description\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"order_id\": 0,\n    \"parent_id\": 0,\n    \"qty\": \"\",\n    \"title\": \"\",\n    \"track_number\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\"\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}}/V1/shipment/track"),
    Content = new StringContent("{\n  \"entity\": {\n    \"carrier_code\": \"\",\n    \"created_at\": \"\",\n    \"description\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"order_id\": 0,\n    \"parent_id\": 0,\n    \"qty\": \"\",\n    \"title\": \"\",\n    \"track_number\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\"\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}}/V1/shipment/track");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"entity\": {\n    \"carrier_code\": \"\",\n    \"created_at\": \"\",\n    \"description\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"order_id\": 0,\n    \"parent_id\": 0,\n    \"qty\": \"\",\n    \"title\": \"\",\n    \"track_number\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/shipment/track"

	payload := strings.NewReader("{\n  \"entity\": {\n    \"carrier_code\": \"\",\n    \"created_at\": \"\",\n    \"description\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"order_id\": 0,\n    \"parent_id\": 0,\n    \"qty\": \"\",\n    \"title\": \"\",\n    \"track_number\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/shipment/track HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 276

{
  "entity": {
    "carrier_code": "",
    "created_at": "",
    "description": "",
    "entity_id": 0,
    "extension_attributes": {},
    "order_id": 0,
    "parent_id": 0,
    "qty": "",
    "title": "",
    "track_number": "",
    "updated_at": "",
    "weight": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/shipment/track")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"entity\": {\n    \"carrier_code\": \"\",\n    \"created_at\": \"\",\n    \"description\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"order_id\": 0,\n    \"parent_id\": 0,\n    \"qty\": \"\",\n    \"title\": \"\",\n    \"track_number\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/shipment/track"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"entity\": {\n    \"carrier_code\": \"\",\n    \"created_at\": \"\",\n    \"description\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"order_id\": 0,\n    \"parent_id\": 0,\n    \"qty\": \"\",\n    \"title\": \"\",\n    \"track_number\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\"\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  \"entity\": {\n    \"carrier_code\": \"\",\n    \"created_at\": \"\",\n    \"description\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"order_id\": 0,\n    \"parent_id\": 0,\n    \"qty\": \"\",\n    \"title\": \"\",\n    \"track_number\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/shipment/track")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/shipment/track")
  .header("content-type", "application/json")
  .body("{\n  \"entity\": {\n    \"carrier_code\": \"\",\n    \"created_at\": \"\",\n    \"description\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"order_id\": 0,\n    \"parent_id\": 0,\n    \"qty\": \"\",\n    \"title\": \"\",\n    \"track_number\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  entity: {
    carrier_code: '',
    created_at: '',
    description: '',
    entity_id: 0,
    extension_attributes: {},
    order_id: 0,
    parent_id: 0,
    qty: '',
    title: '',
    track_number: '',
    updated_at: '',
    weight: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/shipment/track');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/shipment/track',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      carrier_code: '',
      created_at: '',
      description: '',
      entity_id: 0,
      extension_attributes: {},
      order_id: 0,
      parent_id: 0,
      qty: '',
      title: '',
      track_number: '',
      updated_at: '',
      weight: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/shipment/track';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"carrier_code":"","created_at":"","description":"","entity_id":0,"extension_attributes":{},"order_id":0,"parent_id":0,"qty":"","title":"","track_number":"","updated_at":"","weight":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/shipment/track',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "entity": {\n    "carrier_code": "",\n    "created_at": "",\n    "description": "",\n    "entity_id": 0,\n    "extension_attributes": {},\n    "order_id": 0,\n    "parent_id": 0,\n    "qty": "",\n    "title": "",\n    "track_number": "",\n    "updated_at": "",\n    "weight": ""\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  \"entity\": {\n    \"carrier_code\": \"\",\n    \"created_at\": \"\",\n    \"description\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"order_id\": 0,\n    \"parent_id\": 0,\n    \"qty\": \"\",\n    \"title\": \"\",\n    \"track_number\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/shipment/track")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/shipment/track',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  entity: {
    carrier_code: '',
    created_at: '',
    description: '',
    entity_id: 0,
    extension_attributes: {},
    order_id: 0,
    parent_id: 0,
    qty: '',
    title: '',
    track_number: '',
    updated_at: '',
    weight: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/shipment/track',
  headers: {'content-type': 'application/json'},
  body: {
    entity: {
      carrier_code: '',
      created_at: '',
      description: '',
      entity_id: 0,
      extension_attributes: {},
      order_id: 0,
      parent_id: 0,
      qty: '',
      title: '',
      track_number: '',
      updated_at: '',
      weight: ''
    }
  },
  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}}/V1/shipment/track');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  entity: {
    carrier_code: '',
    created_at: '',
    description: '',
    entity_id: 0,
    extension_attributes: {},
    order_id: 0,
    parent_id: 0,
    qty: '',
    title: '',
    track_number: '',
    updated_at: '',
    weight: ''
  }
});

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}}/V1/shipment/track',
  headers: {'content-type': 'application/json'},
  data: {
    entity: {
      carrier_code: '',
      created_at: '',
      description: '',
      entity_id: 0,
      extension_attributes: {},
      order_id: 0,
      parent_id: 0,
      qty: '',
      title: '',
      track_number: '',
      updated_at: '',
      weight: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/shipment/track';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"entity":{"carrier_code":"","created_at":"","description":"","entity_id":0,"extension_attributes":{},"order_id":0,"parent_id":0,"qty":"","title":"","track_number":"","updated_at":"","weight":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"entity": @{ @"carrier_code": @"", @"created_at": @"", @"description": @"", @"entity_id": @0, @"extension_attributes": @{  }, @"order_id": @0, @"parent_id": @0, @"qty": @"", @"title": @"", @"track_number": @"", @"updated_at": @"", @"weight": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/shipment/track"]
                                                       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}}/V1/shipment/track" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"entity\": {\n    \"carrier_code\": \"\",\n    \"created_at\": \"\",\n    \"description\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"order_id\": 0,\n    \"parent_id\": 0,\n    \"qty\": \"\",\n    \"title\": \"\",\n    \"track_number\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/shipment/track",
  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([
    'entity' => [
        'carrier_code' => '',
        'created_at' => '',
        'description' => '',
        'entity_id' => 0,
        'extension_attributes' => [
                
        ],
        'order_id' => 0,
        'parent_id' => 0,
        'qty' => '',
        'title' => '',
        'track_number' => '',
        'updated_at' => '',
        'weight' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/shipment/track', [
  'body' => '{
  "entity": {
    "carrier_code": "",
    "created_at": "",
    "description": "",
    "entity_id": 0,
    "extension_attributes": {},
    "order_id": 0,
    "parent_id": 0,
    "qty": "",
    "title": "",
    "track_number": "",
    "updated_at": "",
    "weight": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/shipment/track');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'entity' => [
    'carrier_code' => '',
    'created_at' => '',
    'description' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'order_id' => 0,
    'parent_id' => 0,
    'qty' => '',
    'title' => '',
    'track_number' => '',
    'updated_at' => '',
    'weight' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'entity' => [
    'carrier_code' => '',
    'created_at' => '',
    'description' => '',
    'entity_id' => 0,
    'extension_attributes' => [
        
    ],
    'order_id' => 0,
    'parent_id' => 0,
    'qty' => '',
    'title' => '',
    'track_number' => '',
    'updated_at' => '',
    'weight' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/shipment/track');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/shipment/track' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "carrier_code": "",
    "created_at": "",
    "description": "",
    "entity_id": 0,
    "extension_attributes": {},
    "order_id": 0,
    "parent_id": 0,
    "qty": "",
    "title": "",
    "track_number": "",
    "updated_at": "",
    "weight": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/shipment/track' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entity": {
    "carrier_code": "",
    "created_at": "",
    "description": "",
    "entity_id": 0,
    "extension_attributes": {},
    "order_id": 0,
    "parent_id": 0,
    "qty": "",
    "title": "",
    "track_number": "",
    "updated_at": "",
    "weight": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"entity\": {\n    \"carrier_code\": \"\",\n    \"created_at\": \"\",\n    \"description\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"order_id\": 0,\n    \"parent_id\": 0,\n    \"qty\": \"\",\n    \"title\": \"\",\n    \"track_number\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/shipment/track", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/shipment/track"

payload = { "entity": {
        "carrier_code": "",
        "created_at": "",
        "description": "",
        "entity_id": 0,
        "extension_attributes": {},
        "order_id": 0,
        "parent_id": 0,
        "qty": "",
        "title": "",
        "track_number": "",
        "updated_at": "",
        "weight": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/shipment/track"

payload <- "{\n  \"entity\": {\n    \"carrier_code\": \"\",\n    \"created_at\": \"\",\n    \"description\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"order_id\": 0,\n    \"parent_id\": 0,\n    \"qty\": \"\",\n    \"title\": \"\",\n    \"track_number\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/shipment/track")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"entity\": {\n    \"carrier_code\": \"\",\n    \"created_at\": \"\",\n    \"description\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"order_id\": 0,\n    \"parent_id\": 0,\n    \"qty\": \"\",\n    \"title\": \"\",\n    \"track_number\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\"\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/V1/shipment/track') do |req|
  req.body = "{\n  \"entity\": {\n    \"carrier_code\": \"\",\n    \"created_at\": \"\",\n    \"description\": \"\",\n    \"entity_id\": 0,\n    \"extension_attributes\": {},\n    \"order_id\": 0,\n    \"parent_id\": 0,\n    \"qty\": \"\",\n    \"title\": \"\",\n    \"track_number\": \"\",\n    \"updated_at\": \"\",\n    \"weight\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/shipment/track";

    let payload = json!({"entity": json!({
            "carrier_code": "",
            "created_at": "",
            "description": "",
            "entity_id": 0,
            "extension_attributes": json!({}),
            "order_id": 0,
            "parent_id": 0,
            "qty": "",
            "title": "",
            "track_number": "",
            "updated_at": "",
            "weight": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/shipment/track \
  --header 'content-type: application/json' \
  --data '{
  "entity": {
    "carrier_code": "",
    "created_at": "",
    "description": "",
    "entity_id": 0,
    "extension_attributes": {},
    "order_id": 0,
    "parent_id": 0,
    "qty": "",
    "title": "",
    "track_number": "",
    "updated_at": "",
    "weight": ""
  }
}'
echo '{
  "entity": {
    "carrier_code": "",
    "created_at": "",
    "description": "",
    "entity_id": 0,
    "extension_attributes": {},
    "order_id": 0,
    "parent_id": 0,
    "qty": "",
    "title": "",
    "track_number": "",
    "updated_at": "",
    "weight": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/shipment/track \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "entity": {\n    "carrier_code": "",\n    "created_at": "",\n    "description": "",\n    "entity_id": 0,\n    "extension_attributes": {},\n    "order_id": 0,\n    "parent_id": 0,\n    "qty": "",\n    "title": "",\n    "track_number": "",\n    "updated_at": "",\n    "weight": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/shipment/track
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["entity": [
    "carrier_code": "",
    "created_at": "",
    "description": "",
    "entity_id": 0,
    "extension_attributes": [],
    "order_id": 0,
    "parent_id": 0,
    "qty": "",
    "title": "",
    "track_number": "",
    "updated_at": "",
    "weight": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/shipment/track")! 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 shipment-track-{id}
{{baseUrl}}/V1/shipment/track/:id
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/shipment/track/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/shipment/track/:id")
require "http/client"

url = "{{baseUrl}}/V1/shipment/track/:id"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/shipment/track/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/shipment/track/:id");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/shipment/track/:id"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/shipment/track/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/shipment/track/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/shipment/track/:id"))
    .method("DELETE", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/shipment/track/:id")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/shipment/track/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/V1/shipment/track/:id');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/shipment/track/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/shipment/track/:id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/shipment/track/:id',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/shipment/track/:id")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/shipment/track/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/shipment/track/:id'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/shipment/track/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/shipment/track/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/shipment/track/:id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/shipment/track/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/shipment/track/:id" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/shipment/track/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/shipment/track/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/shipment/track/:id');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/shipment/track/:id');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/shipment/track/:id' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/shipment/track/:id' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/shipment/track/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/shipment/track/:id"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/shipment/track/:id"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/shipment/track/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/shipment/track/:id') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/shipment/track/:id";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/shipment/track/:id
http DELETE {{baseUrl}}/V1/shipment/track/:id
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/shipment/track/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/shipment/track/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET shipments
{{baseUrl}}/V1/shipments
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/shipments");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/shipments")
require "http/client"

url = "{{baseUrl}}/V1/shipments"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/shipments"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/shipments");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/shipments"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/shipments HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/shipments")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/shipments"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/shipments")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/shipments")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/shipments');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/shipments'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/shipments';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/shipments',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/shipments")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/shipments',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/shipments'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/shipments');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/shipments'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/shipments';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/shipments"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/shipments" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/shipments",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/shipments');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/shipments');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/shipments');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/shipments' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/shipments' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/shipments")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/shipments"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/shipments"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/shipments")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/shipments') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/shipments";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/shipments
http GET {{baseUrl}}/V1/shipments
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/shipments
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/shipments")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET stockItems-{productSku}
{{baseUrl}}/V1/stockItems/:productSku
QUERY PARAMS

productSku
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/stockItems/:productSku");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/stockItems/:productSku")
require "http/client"

url = "{{baseUrl}}/V1/stockItems/:productSku"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/stockItems/:productSku"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/stockItems/:productSku");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/stockItems/:productSku"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/stockItems/:productSku HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/stockItems/:productSku")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/stockItems/:productSku"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/stockItems/:productSku")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/stockItems/:productSku")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/stockItems/:productSku');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/stockItems/:productSku'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/stockItems/:productSku';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/stockItems/:productSku',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/stockItems/:productSku")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/stockItems/:productSku',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/stockItems/:productSku'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/stockItems/:productSku');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/stockItems/:productSku'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/stockItems/:productSku';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/stockItems/:productSku"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/stockItems/:productSku" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/stockItems/:productSku",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/stockItems/:productSku');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/stockItems/:productSku');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/stockItems/:productSku');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/stockItems/:productSku' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/stockItems/:productSku' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/stockItems/:productSku")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/stockItems/:productSku"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/stockItems/:productSku"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/stockItems/:productSku")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/stockItems/:productSku') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/stockItems/:productSku";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/stockItems/:productSku
http GET {{baseUrl}}/V1/stockItems/:productSku
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/stockItems/:productSku
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/stockItems/:productSku")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET stockItems-lowStock-
{{baseUrl}}/V1/stockItems/lowStock/
QUERY PARAMS

scopeId
qty
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty=");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/stockItems/lowStock/" {:query-params {:scopeId ""
                                                                                  :qty ""}})
require "http/client"

url = "{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty="

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty="),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty=");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty="

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/stockItems/lowStock/?scopeId=&qty= HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty=")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty="))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty=")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty=")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty=');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/stockItems/lowStock/',
  params: {scopeId: '', qty: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty=';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty=',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty=")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/stockItems/lowStock/?scopeId=&qty=',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/stockItems/lowStock/',
  qs: {scopeId: '', qty: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/stockItems/lowStock/');

req.query({
  scopeId: '',
  qty: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/V1/stockItems/lowStock/',
  params: {scopeId: '', qty: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty=';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty="]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty=" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty=');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/stockItems/lowStock/');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'scopeId' => '',
  'qty' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/stockItems/lowStock/');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'scopeId' => '',
  'qty' => ''
]));

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty=' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty=' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/stockItems/lowStock/?scopeId=&qty=")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/stockItems/lowStock/"

querystring = {"scopeId":"","qty":""}

response = requests.get(url, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/stockItems/lowStock/"

queryString <- list(
  scopeId = "",
  qty = ""
)

response <- VERB("GET", url, query = queryString, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/stockItems/lowStock/') do |req|
  req.params['scopeId'] = ''
  req.params['qty'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/stockItems/lowStock/";

    let querystring = [
        ("scopeId", ""),
        ("qty", ""),
    ];

    let client = reqwest::Client::new();
    let response = client.get(url)
        .query(&querystring)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url '{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty='
http GET '{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty='
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty='
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/stockItems/lowStock/?scopeId=&qty=")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET stockStatuses-{productSku}
{{baseUrl}}/V1/stockStatuses/:productSku
QUERY PARAMS

productSku
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/stockStatuses/:productSku");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/stockStatuses/:productSku")
require "http/client"

url = "{{baseUrl}}/V1/stockStatuses/:productSku"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/stockStatuses/:productSku"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/stockStatuses/:productSku");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/stockStatuses/:productSku"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/stockStatuses/:productSku HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/stockStatuses/:productSku")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/stockStatuses/:productSku"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/stockStatuses/:productSku")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/stockStatuses/:productSku")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/stockStatuses/:productSku');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/stockStatuses/:productSku'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/stockStatuses/:productSku';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/stockStatuses/:productSku',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/stockStatuses/:productSku")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/stockStatuses/:productSku',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/stockStatuses/:productSku'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/stockStatuses/:productSku');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/stockStatuses/:productSku'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/stockStatuses/:productSku';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/stockStatuses/:productSku"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/stockStatuses/:productSku" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/stockStatuses/:productSku",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/stockStatuses/:productSku');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/stockStatuses/:productSku');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/stockStatuses/:productSku');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/stockStatuses/:productSku' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/stockStatuses/:productSku' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/stockStatuses/:productSku")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/stockStatuses/:productSku"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/stockStatuses/:productSku"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/stockStatuses/:productSku")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/stockStatuses/:productSku') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/stockStatuses/:productSku";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/stockStatuses/:productSku
http GET {{baseUrl}}/V1/stockStatuses/:productSku
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/stockStatuses/:productSku
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/stockStatuses/:productSku")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET store-storeConfigs
{{baseUrl}}/V1/store/storeConfigs
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/store/storeConfigs");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/store/storeConfigs")
require "http/client"

url = "{{baseUrl}}/V1/store/storeConfigs"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/store/storeConfigs"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/store/storeConfigs");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/store/storeConfigs"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/store/storeConfigs HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/store/storeConfigs")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/store/storeConfigs"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/store/storeConfigs")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/store/storeConfigs")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/store/storeConfigs');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/store/storeConfigs'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/store/storeConfigs';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/store/storeConfigs',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/store/storeConfigs")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/store/storeConfigs',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/store/storeConfigs'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/store/storeConfigs');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/store/storeConfigs'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/store/storeConfigs';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/store/storeConfigs"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/store/storeConfigs" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/store/storeConfigs",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/store/storeConfigs');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/store/storeConfigs');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/store/storeConfigs');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/store/storeConfigs' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/store/storeConfigs' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/store/storeConfigs")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/store/storeConfigs"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/store/storeConfigs"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/store/storeConfigs")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/store/storeConfigs') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/store/storeConfigs";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/store/storeConfigs
http GET {{baseUrl}}/V1/store/storeConfigs
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/store/storeConfigs
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/store/storeConfigs")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET store-storeGroups
{{baseUrl}}/V1/store/storeGroups
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/store/storeGroups");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/store/storeGroups")
require "http/client"

url = "{{baseUrl}}/V1/store/storeGroups"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/store/storeGroups"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/store/storeGroups");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/store/storeGroups"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/store/storeGroups HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/store/storeGroups")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/store/storeGroups"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/store/storeGroups")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/store/storeGroups")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/store/storeGroups');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/store/storeGroups'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/store/storeGroups';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/store/storeGroups',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/store/storeGroups")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/store/storeGroups',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/store/storeGroups'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/store/storeGroups');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/store/storeGroups'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/store/storeGroups';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/store/storeGroups"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/store/storeGroups" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/store/storeGroups",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/store/storeGroups');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/store/storeGroups');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/store/storeGroups');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/store/storeGroups' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/store/storeGroups' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/store/storeGroups")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/store/storeGroups"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/store/storeGroups"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/store/storeGroups")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/store/storeGroups') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/store/storeGroups";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/store/storeGroups
http GET {{baseUrl}}/V1/store/storeGroups
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/store/storeGroups
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/store/storeGroups")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET store-storeViews
{{baseUrl}}/V1/store/storeViews
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/store/storeViews");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/store/storeViews")
require "http/client"

url = "{{baseUrl}}/V1/store/storeViews"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/store/storeViews"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/store/storeViews");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/store/storeViews"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/store/storeViews HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/store/storeViews")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/store/storeViews"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/store/storeViews")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/store/storeViews")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/store/storeViews');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/store/storeViews'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/store/storeViews';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/store/storeViews',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/store/storeViews")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/store/storeViews',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/store/storeViews'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/store/storeViews');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/store/storeViews'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/store/storeViews';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/store/storeViews"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/store/storeViews" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/store/storeViews",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/store/storeViews');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/store/storeViews');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/store/storeViews');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/store/storeViews' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/store/storeViews' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/store/storeViews")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/store/storeViews"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/store/storeViews"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/store/storeViews")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/store/storeViews') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/store/storeViews";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/store/storeViews
http GET {{baseUrl}}/V1/store/storeViews
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/store/storeViews
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/store/storeViews")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET store-websites
{{baseUrl}}/V1/store/websites
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/store/websites");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/store/websites")
require "http/client"

url = "{{baseUrl}}/V1/store/websites"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/store/websites"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/store/websites");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/store/websites"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/store/websites HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/store/websites")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/store/websites"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/store/websites")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/store/websites")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/store/websites');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/store/websites'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/store/websites';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/store/websites',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/store/websites")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/store/websites',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/store/websites'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/store/websites');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/store/websites'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/store/websites';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/store/websites"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/store/websites" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/store/websites",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/store/websites');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/store/websites');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/store/websites');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/store/websites' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/store/websites' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/store/websites")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/store/websites"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/store/websites"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/store/websites")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/store/websites') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/store/websites";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/store/websites
http GET {{baseUrl}}/V1/store/websites
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/store/websites
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/store/websites")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST taxClasses
{{baseUrl}}/V1/taxClasses
BODY json

{
  "taxClass": {
    "class_id": 0,
    "class_name": "",
    "class_type": "",
    "extension_attributes": {}
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/taxClasses");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/taxClasses" {:content-type :json
                                                          :form-params {:taxClass {:class_id 0
                                                                                   :class_name ""
                                                                                   :class_type ""
                                                                                   :extension_attributes {}}}})
require "http/client"

url = "{{baseUrl}}/V1/taxClasses"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\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}}/V1/taxClasses"),
    Content = new StringContent("{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\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}}/V1/taxClasses");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/taxClasses"

	payload := strings.NewReader("{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/taxClasses HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 117

{
  "taxClass": {
    "class_id": 0,
    "class_name": "",
    "class_type": "",
    "extension_attributes": {}
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/taxClasses")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/taxClasses"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\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  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/taxClasses")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/taxClasses")
  .header("content-type", "application/json")
  .body("{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}")
  .asString();
const data = JSON.stringify({
  taxClass: {
    class_id: 0,
    class_name: '',
    class_type: '',
    extension_attributes: {}
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/taxClasses');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/taxClasses',
  headers: {'content-type': 'application/json'},
  data: {
    taxClass: {class_id: 0, class_name: '', class_type: '', extension_attributes: {}}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/taxClasses';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"taxClass":{"class_id":0,"class_name":"","class_type":"","extension_attributes":{}}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/taxClasses',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "taxClass": {\n    "class_id": 0,\n    "class_name": "",\n    "class_type": "",\n    "extension_attributes": {}\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  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/taxClasses")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/taxClasses',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  taxClass: {class_id: 0, class_name: '', class_type: '', extension_attributes: {}}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/taxClasses',
  headers: {'content-type': 'application/json'},
  body: {
    taxClass: {class_id: 0, class_name: '', class_type: '', extension_attributes: {}}
  },
  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}}/V1/taxClasses');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  taxClass: {
    class_id: 0,
    class_name: '',
    class_type: '',
    extension_attributes: {}
  }
});

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}}/V1/taxClasses',
  headers: {'content-type': 'application/json'},
  data: {
    taxClass: {class_id: 0, class_name: '', class_type: '', extension_attributes: {}}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/taxClasses';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"taxClass":{"class_id":0,"class_name":"","class_type":"","extension_attributes":{}}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"taxClass": @{ @"class_id": @0, @"class_name": @"", @"class_type": @"", @"extension_attributes": @{  } } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/taxClasses"]
                                                       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}}/V1/taxClasses" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/taxClasses",
  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([
    'taxClass' => [
        'class_id' => 0,
        'class_name' => '',
        'class_type' => '',
        'extension_attributes' => [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/taxClasses', [
  'body' => '{
  "taxClass": {
    "class_id": 0,
    "class_name": "",
    "class_type": "",
    "extension_attributes": {}
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/taxClasses');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'taxClass' => [
    'class_id' => 0,
    'class_name' => '',
    'class_type' => '',
    'extension_attributes' => [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'taxClass' => [
    'class_id' => 0,
    'class_name' => '',
    'class_type' => '',
    'extension_attributes' => [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/taxClasses');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/taxClasses' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "taxClass": {
    "class_id": 0,
    "class_name": "",
    "class_type": "",
    "extension_attributes": {}
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/taxClasses' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "taxClass": {
    "class_id": 0,
    "class_name": "",
    "class_type": "",
    "extension_attributes": {}
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/taxClasses", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/taxClasses"

payload = { "taxClass": {
        "class_id": 0,
        "class_name": "",
        "class_type": "",
        "extension_attributes": {}
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/taxClasses"

payload <- "{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/taxClasses")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\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/V1/taxClasses') do |req|
  req.body = "{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/taxClasses";

    let payload = json!({"taxClass": json!({
            "class_id": 0,
            "class_name": "",
            "class_type": "",
            "extension_attributes": json!({})
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/taxClasses \
  --header 'content-type: application/json' \
  --data '{
  "taxClass": {
    "class_id": 0,
    "class_name": "",
    "class_type": "",
    "extension_attributes": {}
  }
}'
echo '{
  "taxClass": {
    "class_id": 0,
    "class_name": "",
    "class_type": "",
    "extension_attributes": {}
  }
}' |  \
  http POST {{baseUrl}}/V1/taxClasses \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "taxClass": {\n    "class_id": 0,\n    "class_name": "",\n    "class_type": "",\n    "extension_attributes": {}\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/taxClasses
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["taxClass": [
    "class_id": 0,
    "class_name": "",
    "class_type": "",
    "extension_attributes": []
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/taxClasses")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT taxClasses-{classId}
{{baseUrl}}/V1/taxClasses/:classId
QUERY PARAMS

classId
BODY json

{
  "taxClass": {
    "class_id": 0,
    "class_name": "",
    "class_type": "",
    "extension_attributes": {}
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/taxClasses/:classId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/taxClasses/:classId" {:content-type :json
                                                                  :form-params {:taxClass {:class_id 0
                                                                                           :class_name ""
                                                                                           :class_type ""
                                                                                           :extension_attributes {}}}})
require "http/client"

url = "{{baseUrl}}/V1/taxClasses/:classId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\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}}/V1/taxClasses/:classId"),
    Content = new StringContent("{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\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}}/V1/taxClasses/:classId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/taxClasses/:classId"

	payload := strings.NewReader("{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/taxClasses/:classId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 117

{
  "taxClass": {
    "class_id": 0,
    "class_name": "",
    "class_type": "",
    "extension_attributes": {}
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/taxClasses/:classId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/taxClasses/:classId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\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  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/taxClasses/:classId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/taxClasses/:classId")
  .header("content-type", "application/json")
  .body("{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}")
  .asString();
const data = JSON.stringify({
  taxClass: {
    class_id: 0,
    class_name: '',
    class_type: '',
    extension_attributes: {}
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/taxClasses/:classId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/taxClasses/:classId',
  headers: {'content-type': 'application/json'},
  data: {
    taxClass: {class_id: 0, class_name: '', class_type: '', extension_attributes: {}}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/taxClasses/:classId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"taxClass":{"class_id":0,"class_name":"","class_type":"","extension_attributes":{}}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/taxClasses/:classId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "taxClass": {\n    "class_id": 0,\n    "class_name": "",\n    "class_type": "",\n    "extension_attributes": {}\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  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/taxClasses/:classId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/taxClasses/:classId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  taxClass: {class_id: 0, class_name: '', class_type: '', extension_attributes: {}}
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/taxClasses/:classId',
  headers: {'content-type': 'application/json'},
  body: {
    taxClass: {class_id: 0, class_name: '', class_type: '', extension_attributes: {}}
  },
  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}}/V1/taxClasses/:classId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  taxClass: {
    class_id: 0,
    class_name: '',
    class_type: '',
    extension_attributes: {}
  }
});

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}}/V1/taxClasses/:classId',
  headers: {'content-type': 'application/json'},
  data: {
    taxClass: {class_id: 0, class_name: '', class_type: '', extension_attributes: {}}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/taxClasses/:classId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"taxClass":{"class_id":0,"class_name":"","class_type":"","extension_attributes":{}}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"taxClass": @{ @"class_id": @0, @"class_name": @"", @"class_type": @"", @"extension_attributes": @{  } } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/taxClasses/:classId"]
                                                       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}}/V1/taxClasses/:classId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/taxClasses/:classId",
  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([
    'taxClass' => [
        'class_id' => 0,
        'class_name' => '',
        'class_type' => '',
        'extension_attributes' => [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/taxClasses/:classId', [
  'body' => '{
  "taxClass": {
    "class_id": 0,
    "class_name": "",
    "class_type": "",
    "extension_attributes": {}
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/taxClasses/:classId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'taxClass' => [
    'class_id' => 0,
    'class_name' => '',
    'class_type' => '',
    'extension_attributes' => [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'taxClass' => [
    'class_id' => 0,
    'class_name' => '',
    'class_type' => '',
    'extension_attributes' => [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/taxClasses/:classId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/taxClasses/:classId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "taxClass": {
    "class_id": 0,
    "class_name": "",
    "class_type": "",
    "extension_attributes": {}
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/taxClasses/:classId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "taxClass": {
    "class_id": 0,
    "class_name": "",
    "class_type": "",
    "extension_attributes": {}
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/taxClasses/:classId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/taxClasses/:classId"

payload = { "taxClass": {
        "class_id": 0,
        "class_name": "",
        "class_type": "",
        "extension_attributes": {}
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/taxClasses/:classId"

payload <- "{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/taxClasses/:classId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\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/V1/taxClasses/:classId') do |req|
  req.body = "{\n  \"taxClass\": {\n    \"class_id\": 0,\n    \"class_name\": \"\",\n    \"class_type\": \"\",\n    \"extension_attributes\": {}\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}}/V1/taxClasses/:classId";

    let payload = json!({"taxClass": json!({
            "class_id": 0,
            "class_name": "",
            "class_type": "",
            "extension_attributes": json!({})
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/taxClasses/:classId \
  --header 'content-type: application/json' \
  --data '{
  "taxClass": {
    "class_id": 0,
    "class_name": "",
    "class_type": "",
    "extension_attributes": {}
  }
}'
echo '{
  "taxClass": {
    "class_id": 0,
    "class_name": "",
    "class_type": "",
    "extension_attributes": {}
  }
}' |  \
  http PUT {{baseUrl}}/V1/taxClasses/:classId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "taxClass": {\n    "class_id": 0,\n    "class_name": "",\n    "class_type": "",\n    "extension_attributes": {}\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/taxClasses/:classId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["taxClass": [
    "class_id": 0,
    "class_name": "",
    "class_type": "",
    "extension_attributes": []
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/taxClasses/:classId")! 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 taxClasses-{taxClassId} (GET)
{{baseUrl}}/V1/taxClasses/:taxClassId
QUERY PARAMS

taxClassId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/taxClasses/:taxClassId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/taxClasses/:taxClassId")
require "http/client"

url = "{{baseUrl}}/V1/taxClasses/:taxClassId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/taxClasses/:taxClassId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/taxClasses/:taxClassId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/taxClasses/:taxClassId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/taxClasses/:taxClassId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/taxClasses/:taxClassId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/taxClasses/:taxClassId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/taxClasses/:taxClassId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/taxClasses/:taxClassId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/taxClasses/:taxClassId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxClasses/:taxClassId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/taxClasses/:taxClassId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/taxClasses/:taxClassId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/taxClasses/:taxClassId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/taxClasses/:taxClassId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxClasses/:taxClassId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/taxClasses/:taxClassId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxClasses/:taxClassId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/taxClasses/:taxClassId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/taxClasses/:taxClassId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/taxClasses/:taxClassId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/taxClasses/:taxClassId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/taxClasses/:taxClassId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/taxClasses/:taxClassId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/taxClasses/:taxClassId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/taxClasses/:taxClassId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/taxClasses/:taxClassId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/taxClasses/:taxClassId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/taxClasses/:taxClassId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/taxClasses/:taxClassId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/taxClasses/:taxClassId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/taxClasses/:taxClassId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/taxClasses/:taxClassId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/taxClasses/:taxClassId
http GET {{baseUrl}}/V1/taxClasses/:taxClassId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/taxClasses/:taxClassId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/taxClasses/:taxClassId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE taxClasses-{taxClassId}
{{baseUrl}}/V1/taxClasses/:taxClassId
QUERY PARAMS

taxClassId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/taxClasses/:taxClassId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/taxClasses/:taxClassId")
require "http/client"

url = "{{baseUrl}}/V1/taxClasses/:taxClassId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/taxClasses/:taxClassId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/taxClasses/:taxClassId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/taxClasses/:taxClassId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/taxClasses/:taxClassId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/taxClasses/:taxClassId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/taxClasses/:taxClassId"))
    .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}}/V1/taxClasses/:taxClassId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/taxClasses/:taxClassId")
  .asString();
const 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}}/V1/taxClasses/:taxClassId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/taxClasses/:taxClassId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/taxClasses/:taxClassId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/taxClasses/:taxClassId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/taxClasses/:taxClassId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/taxClasses/:taxClassId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/taxClasses/:taxClassId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/taxClasses/:taxClassId');

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}}/V1/taxClasses/:taxClassId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/taxClasses/:taxClassId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/taxClasses/:taxClassId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/taxClasses/:taxClassId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/taxClasses/:taxClassId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/taxClasses/:taxClassId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/taxClasses/:taxClassId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/taxClasses/:taxClassId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/taxClasses/:taxClassId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/taxClasses/:taxClassId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/taxClasses/:taxClassId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/taxClasses/:taxClassId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/taxClasses/:taxClassId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/taxClasses/:taxClassId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/taxClasses/:taxClassId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/taxClasses/:taxClassId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/taxClasses/:taxClassId
http DELETE {{baseUrl}}/V1/taxClasses/:taxClassId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/taxClasses/:taxClassId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/taxClasses/:taxClassId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/taxClasses/search");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/taxClasses/search")
require "http/client"

url = "{{baseUrl}}/V1/taxClasses/search"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/taxClasses/search"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/taxClasses/search");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/taxClasses/search"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/taxClasses/search HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/taxClasses/search")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/taxClasses/search"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/taxClasses/search")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/taxClasses/search")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/taxClasses/search');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxClasses/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/taxClasses/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/taxClasses/search',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/taxClasses/search")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/taxClasses/search',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxClasses/search'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/taxClasses/search');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxClasses/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/taxClasses/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/taxClasses/search"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/taxClasses/search" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/taxClasses/search",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/taxClasses/search');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/taxClasses/search');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/taxClasses/search');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/taxClasses/search' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/taxClasses/search' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/taxClasses/search")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/taxClasses/search"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/taxClasses/search"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/taxClasses/search")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/taxClasses/search') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/taxClasses/search";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/taxClasses/search
http GET {{baseUrl}}/V1/taxClasses/search
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/taxClasses/search
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/taxClasses/search")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT taxRates (PUT)
{{baseUrl}}/V1/taxRates
BODY json

{
  "taxRate": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "rate": "",
    "region_name": "",
    "tax_country_id": "",
    "tax_postcode": "",
    "tax_region_id": 0,
    "titles": [
      {
        "extension_attributes": {},
        "store_id": "",
        "value": ""
      }
    ],
    "zip_from": 0,
    "zip_is_range": 0,
    "zip_to": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/taxRates");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/taxRates" {:content-type :json
                                                       :form-params {:taxRate {:code ""
                                                                               :extension_attributes {}
                                                                               :id 0
                                                                               :rate ""
                                                                               :region_name ""
                                                                               :tax_country_id ""
                                                                               :tax_postcode ""
                                                                               :tax_region_id 0
                                                                               :titles [{:extension_attributes {}
                                                                                         :store_id ""
                                                                                         :value ""}]
                                                                               :zip_from 0
                                                                               :zip_is_range 0
                                                                               :zip_to 0}}})
require "http/client"

url = "{{baseUrl}}/V1/taxRates"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\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}}/V1/taxRates"),
    Content = new StringContent("{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\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}}/V1/taxRates");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/taxRates"

	payload := strings.NewReader("{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/taxRates HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 373

{
  "taxRate": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "rate": "",
    "region_name": "",
    "tax_country_id": "",
    "tax_postcode": "",
    "tax_region_id": 0,
    "titles": [
      {
        "extension_attributes": {},
        "store_id": "",
        "value": ""
      }
    ],
    "zip_from": 0,
    "zip_is_range": 0,
    "zip_to": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/taxRates")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/taxRates"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\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  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/taxRates")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/taxRates")
  .header("content-type", "application/json")
  .body("{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  taxRate: {
    code: '',
    extension_attributes: {},
    id: 0,
    rate: '',
    region_name: '',
    tax_country_id: '',
    tax_postcode: '',
    tax_region_id: 0,
    titles: [
      {
        extension_attributes: {},
        store_id: '',
        value: ''
      }
    ],
    zip_from: 0,
    zip_is_range: 0,
    zip_to: 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}}/V1/taxRates');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/taxRates',
  headers: {'content-type': 'application/json'},
  data: {
    taxRate: {
      code: '',
      extension_attributes: {},
      id: 0,
      rate: '',
      region_name: '',
      tax_country_id: '',
      tax_postcode: '',
      tax_region_id: 0,
      titles: [{extension_attributes: {}, store_id: '', value: ''}],
      zip_from: 0,
      zip_is_range: 0,
      zip_to: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/taxRates';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"taxRate":{"code":"","extension_attributes":{},"id":0,"rate":"","region_name":"","tax_country_id":"","tax_postcode":"","tax_region_id":0,"titles":[{"extension_attributes":{},"store_id":"","value":""}],"zip_from":0,"zip_is_range":0,"zip_to":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}}/V1/taxRates',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "taxRate": {\n    "code": "",\n    "extension_attributes": {},\n    "id": 0,\n    "rate": "",\n    "region_name": "",\n    "tax_country_id": "",\n    "tax_postcode": "",\n    "tax_region_id": 0,\n    "titles": [\n      {\n        "extension_attributes": {},\n        "store_id": "",\n        "value": ""\n      }\n    ],\n    "zip_from": 0,\n    "zip_is_range": 0,\n    "zip_to": 0\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  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/taxRates")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/taxRates',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  taxRate: {
    code: '',
    extension_attributes: {},
    id: 0,
    rate: '',
    region_name: '',
    tax_country_id: '',
    tax_postcode: '',
    tax_region_id: 0,
    titles: [{extension_attributes: {}, store_id: '', value: ''}],
    zip_from: 0,
    zip_is_range: 0,
    zip_to: 0
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/taxRates',
  headers: {'content-type': 'application/json'},
  body: {
    taxRate: {
      code: '',
      extension_attributes: {},
      id: 0,
      rate: '',
      region_name: '',
      tax_country_id: '',
      tax_postcode: '',
      tax_region_id: 0,
      titles: [{extension_attributes: {}, store_id: '', value: ''}],
      zip_from: 0,
      zip_is_range: 0,
      zip_to: 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}}/V1/taxRates');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  taxRate: {
    code: '',
    extension_attributes: {},
    id: 0,
    rate: '',
    region_name: '',
    tax_country_id: '',
    tax_postcode: '',
    tax_region_id: 0,
    titles: [
      {
        extension_attributes: {},
        store_id: '',
        value: ''
      }
    ],
    zip_from: 0,
    zip_is_range: 0,
    zip_to: 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}}/V1/taxRates',
  headers: {'content-type': 'application/json'},
  data: {
    taxRate: {
      code: '',
      extension_attributes: {},
      id: 0,
      rate: '',
      region_name: '',
      tax_country_id: '',
      tax_postcode: '',
      tax_region_id: 0,
      titles: [{extension_attributes: {}, store_id: '', value: ''}],
      zip_from: 0,
      zip_is_range: 0,
      zip_to: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/taxRates';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"taxRate":{"code":"","extension_attributes":{},"id":0,"rate":"","region_name":"","tax_country_id":"","tax_postcode":"","tax_region_id":0,"titles":[{"extension_attributes":{},"store_id":"","value":""}],"zip_from":0,"zip_is_range":0,"zip_to":0}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"taxRate": @{ @"code": @"", @"extension_attributes": @{  }, @"id": @0, @"rate": @"", @"region_name": @"", @"tax_country_id": @"", @"tax_postcode": @"", @"tax_region_id": @0, @"titles": @[ @{ @"extension_attributes": @{  }, @"store_id": @"", @"value": @"" } ], @"zip_from": @0, @"zip_is_range": @0, @"zip_to": @0 } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/taxRates"]
                                                       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}}/V1/taxRates" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/taxRates",
  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([
    'taxRate' => [
        'code' => '',
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'rate' => '',
        'region_name' => '',
        'tax_country_id' => '',
        'tax_postcode' => '',
        'tax_region_id' => 0,
        'titles' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'store_id' => '',
                                'value' => ''
                ]
        ],
        'zip_from' => 0,
        'zip_is_range' => 0,
        'zip_to' => 0
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/taxRates', [
  'body' => '{
  "taxRate": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "rate": "",
    "region_name": "",
    "tax_country_id": "",
    "tax_postcode": "",
    "tax_region_id": 0,
    "titles": [
      {
        "extension_attributes": {},
        "store_id": "",
        "value": ""
      }
    ],
    "zip_from": 0,
    "zip_is_range": 0,
    "zip_to": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/taxRates');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'taxRate' => [
    'code' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'rate' => '',
    'region_name' => '',
    'tax_country_id' => '',
    'tax_postcode' => '',
    'tax_region_id' => 0,
    'titles' => [
        [
                'extension_attributes' => [
                                
                ],
                'store_id' => '',
                'value' => ''
        ]
    ],
    'zip_from' => 0,
    'zip_is_range' => 0,
    'zip_to' => 0
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'taxRate' => [
    'code' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'rate' => '',
    'region_name' => '',
    'tax_country_id' => '',
    'tax_postcode' => '',
    'tax_region_id' => 0,
    'titles' => [
        [
                'extension_attributes' => [
                                
                ],
                'store_id' => '',
                'value' => ''
        ]
    ],
    'zip_from' => 0,
    'zip_is_range' => 0,
    'zip_to' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/taxRates');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/taxRates' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "taxRate": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "rate": "",
    "region_name": "",
    "tax_country_id": "",
    "tax_postcode": "",
    "tax_region_id": 0,
    "titles": [
      {
        "extension_attributes": {},
        "store_id": "",
        "value": ""
      }
    ],
    "zip_from": 0,
    "zip_is_range": 0,
    "zip_to": 0
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/taxRates' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "taxRate": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "rate": "",
    "region_name": "",
    "tax_country_id": "",
    "tax_postcode": "",
    "tax_region_id": 0,
    "titles": [
      {
        "extension_attributes": {},
        "store_id": "",
        "value": ""
      }
    ],
    "zip_from": 0,
    "zip_is_range": 0,
    "zip_to": 0
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/taxRates", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/taxRates"

payload = { "taxRate": {
        "code": "",
        "extension_attributes": {},
        "id": 0,
        "rate": "",
        "region_name": "",
        "tax_country_id": "",
        "tax_postcode": "",
        "tax_region_id": 0,
        "titles": [
            {
                "extension_attributes": {},
                "store_id": "",
                "value": ""
            }
        ],
        "zip_from": 0,
        "zip_is_range": 0,
        "zip_to": 0
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/taxRates"

payload <- "{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/taxRates")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\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/V1/taxRates') do |req|
  req.body = "{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\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}}/V1/taxRates";

    let payload = json!({"taxRate": json!({
            "code": "",
            "extension_attributes": json!({}),
            "id": 0,
            "rate": "",
            "region_name": "",
            "tax_country_id": "",
            "tax_postcode": "",
            "tax_region_id": 0,
            "titles": (
                json!({
                    "extension_attributes": json!({}),
                    "store_id": "",
                    "value": ""
                })
            ),
            "zip_from": 0,
            "zip_is_range": 0,
            "zip_to": 0
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/taxRates \
  --header 'content-type: application/json' \
  --data '{
  "taxRate": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "rate": "",
    "region_name": "",
    "tax_country_id": "",
    "tax_postcode": "",
    "tax_region_id": 0,
    "titles": [
      {
        "extension_attributes": {},
        "store_id": "",
        "value": ""
      }
    ],
    "zip_from": 0,
    "zip_is_range": 0,
    "zip_to": 0
  }
}'
echo '{
  "taxRate": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "rate": "",
    "region_name": "",
    "tax_country_id": "",
    "tax_postcode": "",
    "tax_region_id": 0,
    "titles": [
      {
        "extension_attributes": {},
        "store_id": "",
        "value": ""
      }
    ],
    "zip_from": 0,
    "zip_is_range": 0,
    "zip_to": 0
  }
}' |  \
  http PUT {{baseUrl}}/V1/taxRates \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "taxRate": {\n    "code": "",\n    "extension_attributes": {},\n    "id": 0,\n    "rate": "",\n    "region_name": "",\n    "tax_country_id": "",\n    "tax_postcode": "",\n    "tax_region_id": 0,\n    "titles": [\n      {\n        "extension_attributes": {},\n        "store_id": "",\n        "value": ""\n      }\n    ],\n    "zip_from": 0,\n    "zip_is_range": 0,\n    "zip_to": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/taxRates
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["taxRate": [
    "code": "",
    "extension_attributes": [],
    "id": 0,
    "rate": "",
    "region_name": "",
    "tax_country_id": "",
    "tax_postcode": "",
    "tax_region_id": 0,
    "titles": [
      [
        "extension_attributes": [],
        "store_id": "",
        "value": ""
      ]
    ],
    "zip_from": 0,
    "zip_is_range": 0,
    "zip_to": 0
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/taxRates")! 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 taxRates
{{baseUrl}}/V1/taxRates
BODY json

{
  "taxRate": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "rate": "",
    "region_name": "",
    "tax_country_id": "",
    "tax_postcode": "",
    "tax_region_id": 0,
    "titles": [
      {
        "extension_attributes": {},
        "store_id": "",
        "value": ""
      }
    ],
    "zip_from": 0,
    "zip_is_range": 0,
    "zip_to": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/taxRates");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/taxRates" {:content-type :json
                                                        :form-params {:taxRate {:code ""
                                                                                :extension_attributes {}
                                                                                :id 0
                                                                                :rate ""
                                                                                :region_name ""
                                                                                :tax_country_id ""
                                                                                :tax_postcode ""
                                                                                :tax_region_id 0
                                                                                :titles [{:extension_attributes {}
                                                                                          :store_id ""
                                                                                          :value ""}]
                                                                                :zip_from 0
                                                                                :zip_is_range 0
                                                                                :zip_to 0}}})
require "http/client"

url = "{{baseUrl}}/V1/taxRates"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\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}}/V1/taxRates"),
    Content = new StringContent("{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\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}}/V1/taxRates");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/taxRates"

	payload := strings.NewReader("{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/taxRates HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 373

{
  "taxRate": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "rate": "",
    "region_name": "",
    "tax_country_id": "",
    "tax_postcode": "",
    "tax_region_id": 0,
    "titles": [
      {
        "extension_attributes": {},
        "store_id": "",
        "value": ""
      }
    ],
    "zip_from": 0,
    "zip_is_range": 0,
    "zip_to": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/taxRates")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/taxRates"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\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  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/taxRates")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/taxRates")
  .header("content-type", "application/json")
  .body("{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  taxRate: {
    code: '',
    extension_attributes: {},
    id: 0,
    rate: '',
    region_name: '',
    tax_country_id: '',
    tax_postcode: '',
    tax_region_id: 0,
    titles: [
      {
        extension_attributes: {},
        store_id: '',
        value: ''
      }
    ],
    zip_from: 0,
    zip_is_range: 0,
    zip_to: 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}}/V1/taxRates');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/taxRates',
  headers: {'content-type': 'application/json'},
  data: {
    taxRate: {
      code: '',
      extension_attributes: {},
      id: 0,
      rate: '',
      region_name: '',
      tax_country_id: '',
      tax_postcode: '',
      tax_region_id: 0,
      titles: [{extension_attributes: {}, store_id: '', value: ''}],
      zip_from: 0,
      zip_is_range: 0,
      zip_to: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/taxRates';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"taxRate":{"code":"","extension_attributes":{},"id":0,"rate":"","region_name":"","tax_country_id":"","tax_postcode":"","tax_region_id":0,"titles":[{"extension_attributes":{},"store_id":"","value":""}],"zip_from":0,"zip_is_range":0,"zip_to":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}}/V1/taxRates',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "taxRate": {\n    "code": "",\n    "extension_attributes": {},\n    "id": 0,\n    "rate": "",\n    "region_name": "",\n    "tax_country_id": "",\n    "tax_postcode": "",\n    "tax_region_id": 0,\n    "titles": [\n      {\n        "extension_attributes": {},\n        "store_id": "",\n        "value": ""\n      }\n    ],\n    "zip_from": 0,\n    "zip_is_range": 0,\n    "zip_to": 0\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  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/taxRates")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/taxRates',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  taxRate: {
    code: '',
    extension_attributes: {},
    id: 0,
    rate: '',
    region_name: '',
    tax_country_id: '',
    tax_postcode: '',
    tax_region_id: 0,
    titles: [{extension_attributes: {}, store_id: '', value: ''}],
    zip_from: 0,
    zip_is_range: 0,
    zip_to: 0
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/taxRates',
  headers: {'content-type': 'application/json'},
  body: {
    taxRate: {
      code: '',
      extension_attributes: {},
      id: 0,
      rate: '',
      region_name: '',
      tax_country_id: '',
      tax_postcode: '',
      tax_region_id: 0,
      titles: [{extension_attributes: {}, store_id: '', value: ''}],
      zip_from: 0,
      zip_is_range: 0,
      zip_to: 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}}/V1/taxRates');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  taxRate: {
    code: '',
    extension_attributes: {},
    id: 0,
    rate: '',
    region_name: '',
    tax_country_id: '',
    tax_postcode: '',
    tax_region_id: 0,
    titles: [
      {
        extension_attributes: {},
        store_id: '',
        value: ''
      }
    ],
    zip_from: 0,
    zip_is_range: 0,
    zip_to: 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}}/V1/taxRates',
  headers: {'content-type': 'application/json'},
  data: {
    taxRate: {
      code: '',
      extension_attributes: {},
      id: 0,
      rate: '',
      region_name: '',
      tax_country_id: '',
      tax_postcode: '',
      tax_region_id: 0,
      titles: [{extension_attributes: {}, store_id: '', value: ''}],
      zip_from: 0,
      zip_is_range: 0,
      zip_to: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/taxRates';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"taxRate":{"code":"","extension_attributes":{},"id":0,"rate":"","region_name":"","tax_country_id":"","tax_postcode":"","tax_region_id":0,"titles":[{"extension_attributes":{},"store_id":"","value":""}],"zip_from":0,"zip_is_range":0,"zip_to":0}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"taxRate": @{ @"code": @"", @"extension_attributes": @{  }, @"id": @0, @"rate": @"", @"region_name": @"", @"tax_country_id": @"", @"tax_postcode": @"", @"tax_region_id": @0, @"titles": @[ @{ @"extension_attributes": @{  }, @"store_id": @"", @"value": @"" } ], @"zip_from": @0, @"zip_is_range": @0, @"zip_to": @0 } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/taxRates"]
                                                       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}}/V1/taxRates" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/taxRates",
  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([
    'taxRate' => [
        'code' => '',
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'rate' => '',
        'region_name' => '',
        'tax_country_id' => '',
        'tax_postcode' => '',
        'tax_region_id' => 0,
        'titles' => [
                [
                                'extension_attributes' => [
                                                                
                                ],
                                'store_id' => '',
                                'value' => ''
                ]
        ],
        'zip_from' => 0,
        'zip_is_range' => 0,
        'zip_to' => 0
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/taxRates', [
  'body' => '{
  "taxRate": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "rate": "",
    "region_name": "",
    "tax_country_id": "",
    "tax_postcode": "",
    "tax_region_id": 0,
    "titles": [
      {
        "extension_attributes": {},
        "store_id": "",
        "value": ""
      }
    ],
    "zip_from": 0,
    "zip_is_range": 0,
    "zip_to": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/taxRates');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'taxRate' => [
    'code' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'rate' => '',
    'region_name' => '',
    'tax_country_id' => '',
    'tax_postcode' => '',
    'tax_region_id' => 0,
    'titles' => [
        [
                'extension_attributes' => [
                                
                ],
                'store_id' => '',
                'value' => ''
        ]
    ],
    'zip_from' => 0,
    'zip_is_range' => 0,
    'zip_to' => 0
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'taxRate' => [
    'code' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'rate' => '',
    'region_name' => '',
    'tax_country_id' => '',
    'tax_postcode' => '',
    'tax_region_id' => 0,
    'titles' => [
        [
                'extension_attributes' => [
                                
                ],
                'store_id' => '',
                'value' => ''
        ]
    ],
    'zip_from' => 0,
    'zip_is_range' => 0,
    'zip_to' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/taxRates');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/taxRates' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "taxRate": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "rate": "",
    "region_name": "",
    "tax_country_id": "",
    "tax_postcode": "",
    "tax_region_id": 0,
    "titles": [
      {
        "extension_attributes": {},
        "store_id": "",
        "value": ""
      }
    ],
    "zip_from": 0,
    "zip_is_range": 0,
    "zip_to": 0
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/taxRates' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "taxRate": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "rate": "",
    "region_name": "",
    "tax_country_id": "",
    "tax_postcode": "",
    "tax_region_id": 0,
    "titles": [
      {
        "extension_attributes": {},
        "store_id": "",
        "value": ""
      }
    ],
    "zip_from": 0,
    "zip_is_range": 0,
    "zip_to": 0
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/taxRates", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/taxRates"

payload = { "taxRate": {
        "code": "",
        "extension_attributes": {},
        "id": 0,
        "rate": "",
        "region_name": "",
        "tax_country_id": "",
        "tax_postcode": "",
        "tax_region_id": 0,
        "titles": [
            {
                "extension_attributes": {},
                "store_id": "",
                "value": ""
            }
        ],
        "zip_from": 0,
        "zip_is_range": 0,
        "zip_to": 0
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/taxRates"

payload <- "{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/taxRates")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\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/V1/taxRates') do |req|
  req.body = "{\n  \"taxRate\": {\n    \"code\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"rate\": \"\",\n    \"region_name\": \"\",\n    \"tax_country_id\": \"\",\n    \"tax_postcode\": \"\",\n    \"tax_region_id\": 0,\n    \"titles\": [\n      {\n        \"extension_attributes\": {},\n        \"store_id\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"zip_from\": 0,\n    \"zip_is_range\": 0,\n    \"zip_to\": 0\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/taxRates";

    let payload = json!({"taxRate": json!({
            "code": "",
            "extension_attributes": json!({}),
            "id": 0,
            "rate": "",
            "region_name": "",
            "tax_country_id": "",
            "tax_postcode": "",
            "tax_region_id": 0,
            "titles": (
                json!({
                    "extension_attributes": json!({}),
                    "store_id": "",
                    "value": ""
                })
            ),
            "zip_from": 0,
            "zip_is_range": 0,
            "zip_to": 0
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/taxRates \
  --header 'content-type: application/json' \
  --data '{
  "taxRate": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "rate": "",
    "region_name": "",
    "tax_country_id": "",
    "tax_postcode": "",
    "tax_region_id": 0,
    "titles": [
      {
        "extension_attributes": {},
        "store_id": "",
        "value": ""
      }
    ],
    "zip_from": 0,
    "zip_is_range": 0,
    "zip_to": 0
  }
}'
echo '{
  "taxRate": {
    "code": "",
    "extension_attributes": {},
    "id": 0,
    "rate": "",
    "region_name": "",
    "tax_country_id": "",
    "tax_postcode": "",
    "tax_region_id": 0,
    "titles": [
      {
        "extension_attributes": {},
        "store_id": "",
        "value": ""
      }
    ],
    "zip_from": 0,
    "zip_is_range": 0,
    "zip_to": 0
  }
}' |  \
  http POST {{baseUrl}}/V1/taxRates \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "taxRate": {\n    "code": "",\n    "extension_attributes": {},\n    "id": 0,\n    "rate": "",\n    "region_name": "",\n    "tax_country_id": "",\n    "tax_postcode": "",\n    "tax_region_id": 0,\n    "titles": [\n      {\n        "extension_attributes": {},\n        "store_id": "",\n        "value": ""\n      }\n    ],\n    "zip_from": 0,\n    "zip_is_range": 0,\n    "zip_to": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/taxRates
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["taxRate": [
    "code": "",
    "extension_attributes": [],
    "id": 0,
    "rate": "",
    "region_name": "",
    "tax_country_id": "",
    "tax_postcode": "",
    "tax_region_id": 0,
    "titles": [
      [
        "extension_attributes": [],
        "store_id": "",
        "value": ""
      ]
    ],
    "zip_from": 0,
    "zip_is_range": 0,
    "zip_to": 0
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/taxRates")! 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 taxRates-{rateId} (GET)
{{baseUrl}}/V1/taxRates/:rateId
QUERY PARAMS

rateId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/taxRates/:rateId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/taxRates/:rateId")
require "http/client"

url = "{{baseUrl}}/V1/taxRates/:rateId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/taxRates/:rateId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/taxRates/:rateId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/taxRates/:rateId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/taxRates/:rateId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/taxRates/:rateId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/taxRates/:rateId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/taxRates/:rateId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/taxRates/:rateId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/taxRates/:rateId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxRates/:rateId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/taxRates/:rateId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/taxRates/:rateId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/taxRates/:rateId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/taxRates/:rateId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxRates/:rateId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/taxRates/:rateId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxRates/:rateId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/taxRates/:rateId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/taxRates/:rateId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/taxRates/:rateId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/taxRates/:rateId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/taxRates/:rateId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/taxRates/:rateId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/taxRates/:rateId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/taxRates/:rateId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/taxRates/:rateId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/taxRates/:rateId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/taxRates/:rateId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/taxRates/:rateId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/taxRates/:rateId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/taxRates/:rateId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/taxRates/:rateId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/taxRates/:rateId
http GET {{baseUrl}}/V1/taxRates/:rateId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/taxRates/:rateId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/taxRates/:rateId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE taxRates-{rateId}
{{baseUrl}}/V1/taxRates/:rateId
QUERY PARAMS

rateId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/taxRates/:rateId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/taxRates/:rateId")
require "http/client"

url = "{{baseUrl}}/V1/taxRates/:rateId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/taxRates/:rateId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/taxRates/:rateId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/taxRates/:rateId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/taxRates/:rateId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/taxRates/:rateId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/taxRates/:rateId"))
    .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}}/V1/taxRates/:rateId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/taxRates/:rateId")
  .asString();
const 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}}/V1/taxRates/:rateId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/taxRates/:rateId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/taxRates/:rateId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/taxRates/:rateId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/taxRates/:rateId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/taxRates/:rateId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/taxRates/:rateId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/taxRates/:rateId');

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}}/V1/taxRates/:rateId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/taxRates/:rateId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/taxRates/:rateId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/taxRates/:rateId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/taxRates/:rateId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/taxRates/:rateId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/taxRates/:rateId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/taxRates/:rateId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/taxRates/:rateId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/taxRates/:rateId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/taxRates/:rateId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/taxRates/:rateId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/taxRates/:rateId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/taxRates/:rateId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/taxRates/:rateId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/taxRates/:rateId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/taxRates/:rateId
http DELETE {{baseUrl}}/V1/taxRates/:rateId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/taxRates/:rateId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/taxRates/:rateId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/taxRates/search");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/taxRates/search")
require "http/client"

url = "{{baseUrl}}/V1/taxRates/search"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/taxRates/search"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/taxRates/search");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/taxRates/search"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/taxRates/search HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/taxRates/search")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/taxRates/search"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/taxRates/search")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/taxRates/search")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/taxRates/search');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxRates/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/taxRates/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/taxRates/search',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/taxRates/search")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/taxRates/search',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxRates/search'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/taxRates/search');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxRates/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/taxRates/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/taxRates/search"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/taxRates/search" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/taxRates/search",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/taxRates/search');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/taxRates/search');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/taxRates/search');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/taxRates/search' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/taxRates/search' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/taxRates/search")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/taxRates/search"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/taxRates/search"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/taxRates/search")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/taxRates/search') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/taxRates/search";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/taxRates/search
http GET {{baseUrl}}/V1/taxRates/search
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/taxRates/search
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/taxRates/search")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT taxRules (PUT)
{{baseUrl}}/V1/taxRules
BODY json

{
  "rule": {
    "calculate_subtotal": false,
    "code": "",
    "customer_tax_class_ids": [],
    "extension_attributes": {},
    "id": 0,
    "position": 0,
    "priority": 0,
    "product_tax_class_ids": [],
    "tax_rate_ids": []
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/taxRules");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/taxRules" {:content-type :json
                                                       :form-params {:rule {:calculate_subtotal false
                                                                            :code ""
                                                                            :customer_tax_class_ids []
                                                                            :extension_attributes {}
                                                                            :id 0
                                                                            :position 0
                                                                            :priority 0
                                                                            :product_tax_class_ids []
                                                                            :tax_rate_ids []}}})
require "http/client"

url = "{{baseUrl}}/V1/taxRules"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\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}}/V1/taxRules"),
    Content = new StringContent("{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\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}}/V1/taxRules");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/taxRules"

	payload := strings.NewReader("{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/taxRules HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 241

{
  "rule": {
    "calculate_subtotal": false,
    "code": "",
    "customer_tax_class_ids": [],
    "extension_attributes": {},
    "id": 0,
    "position": 0,
    "priority": 0,
    "product_tax_class_ids": [],
    "tax_rate_ids": []
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/taxRules")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/taxRules"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\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  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/taxRules")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/taxRules")
  .header("content-type", "application/json")
  .body("{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}")
  .asString();
const data = JSON.stringify({
  rule: {
    calculate_subtotal: false,
    code: '',
    customer_tax_class_ids: [],
    extension_attributes: {},
    id: 0,
    position: 0,
    priority: 0,
    product_tax_class_ids: [],
    tax_rate_ids: []
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/taxRules');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/taxRules',
  headers: {'content-type': 'application/json'},
  data: {
    rule: {
      calculate_subtotal: false,
      code: '',
      customer_tax_class_ids: [],
      extension_attributes: {},
      id: 0,
      position: 0,
      priority: 0,
      product_tax_class_ids: [],
      tax_rate_ids: []
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/taxRules';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"rule":{"calculate_subtotal":false,"code":"","customer_tax_class_ids":[],"extension_attributes":{},"id":0,"position":0,"priority":0,"product_tax_class_ids":[],"tax_rate_ids":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/taxRules',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "rule": {\n    "calculate_subtotal": false,\n    "code": "",\n    "customer_tax_class_ids": [],\n    "extension_attributes": {},\n    "id": 0,\n    "position": 0,\n    "priority": 0,\n    "product_tax_class_ids": [],\n    "tax_rate_ids": []\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  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/taxRules")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/taxRules',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  rule: {
    calculate_subtotal: false,
    code: '',
    customer_tax_class_ids: [],
    extension_attributes: {},
    id: 0,
    position: 0,
    priority: 0,
    product_tax_class_ids: [],
    tax_rate_ids: []
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/taxRules',
  headers: {'content-type': 'application/json'},
  body: {
    rule: {
      calculate_subtotal: false,
      code: '',
      customer_tax_class_ids: [],
      extension_attributes: {},
      id: 0,
      position: 0,
      priority: 0,
      product_tax_class_ids: [],
      tax_rate_ids: []
    }
  },
  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}}/V1/taxRules');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  rule: {
    calculate_subtotal: false,
    code: '',
    customer_tax_class_ids: [],
    extension_attributes: {},
    id: 0,
    position: 0,
    priority: 0,
    product_tax_class_ids: [],
    tax_rate_ids: []
  }
});

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}}/V1/taxRules',
  headers: {'content-type': 'application/json'},
  data: {
    rule: {
      calculate_subtotal: false,
      code: '',
      customer_tax_class_ids: [],
      extension_attributes: {},
      id: 0,
      position: 0,
      priority: 0,
      product_tax_class_ids: [],
      tax_rate_ids: []
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/taxRules';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"rule":{"calculate_subtotal":false,"code":"","customer_tax_class_ids":[],"extension_attributes":{},"id":0,"position":0,"priority":0,"product_tax_class_ids":[],"tax_rate_ids":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"rule": @{ @"calculate_subtotal": @NO, @"code": @"", @"customer_tax_class_ids": @[  ], @"extension_attributes": @{  }, @"id": @0, @"position": @0, @"priority": @0, @"product_tax_class_ids": @[  ], @"tax_rate_ids": @[  ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/taxRules"]
                                                       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}}/V1/taxRules" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/taxRules",
  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([
    'rule' => [
        'calculate_subtotal' => null,
        'code' => '',
        'customer_tax_class_ids' => [
                
        ],
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'position' => 0,
        'priority' => 0,
        'product_tax_class_ids' => [
                
        ],
        'tax_rate_ids' => [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/taxRules', [
  'body' => '{
  "rule": {
    "calculate_subtotal": false,
    "code": "",
    "customer_tax_class_ids": [],
    "extension_attributes": {},
    "id": 0,
    "position": 0,
    "priority": 0,
    "product_tax_class_ids": [],
    "tax_rate_ids": []
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/taxRules');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'rule' => [
    'calculate_subtotal' => null,
    'code' => '',
    'customer_tax_class_ids' => [
        
    ],
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'position' => 0,
    'priority' => 0,
    'product_tax_class_ids' => [
        
    ],
    'tax_rate_ids' => [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'rule' => [
    'calculate_subtotal' => null,
    'code' => '',
    'customer_tax_class_ids' => [
        
    ],
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'position' => 0,
    'priority' => 0,
    'product_tax_class_ids' => [
        
    ],
    'tax_rate_ids' => [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/taxRules');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/taxRules' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "rule": {
    "calculate_subtotal": false,
    "code": "",
    "customer_tax_class_ids": [],
    "extension_attributes": {},
    "id": 0,
    "position": 0,
    "priority": 0,
    "product_tax_class_ids": [],
    "tax_rate_ids": []
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/taxRules' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "rule": {
    "calculate_subtotal": false,
    "code": "",
    "customer_tax_class_ids": [],
    "extension_attributes": {},
    "id": 0,
    "position": 0,
    "priority": 0,
    "product_tax_class_ids": [],
    "tax_rate_ids": []
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/taxRules", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/taxRules"

payload = { "rule": {
        "calculate_subtotal": False,
        "code": "",
        "customer_tax_class_ids": [],
        "extension_attributes": {},
        "id": 0,
        "position": 0,
        "priority": 0,
        "product_tax_class_ids": [],
        "tax_rate_ids": []
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/taxRules"

payload <- "{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/taxRules")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\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/V1/taxRules') do |req|
  req.body = "{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\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}}/V1/taxRules";

    let payload = json!({"rule": json!({
            "calculate_subtotal": false,
            "code": "",
            "customer_tax_class_ids": (),
            "extension_attributes": json!({}),
            "id": 0,
            "position": 0,
            "priority": 0,
            "product_tax_class_ids": (),
            "tax_rate_ids": ()
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/taxRules \
  --header 'content-type: application/json' \
  --data '{
  "rule": {
    "calculate_subtotal": false,
    "code": "",
    "customer_tax_class_ids": [],
    "extension_attributes": {},
    "id": 0,
    "position": 0,
    "priority": 0,
    "product_tax_class_ids": [],
    "tax_rate_ids": []
  }
}'
echo '{
  "rule": {
    "calculate_subtotal": false,
    "code": "",
    "customer_tax_class_ids": [],
    "extension_attributes": {},
    "id": 0,
    "position": 0,
    "priority": 0,
    "product_tax_class_ids": [],
    "tax_rate_ids": []
  }
}' |  \
  http PUT {{baseUrl}}/V1/taxRules \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "rule": {\n    "calculate_subtotal": false,\n    "code": "",\n    "customer_tax_class_ids": [],\n    "extension_attributes": {},\n    "id": 0,\n    "position": 0,\n    "priority": 0,\n    "product_tax_class_ids": [],\n    "tax_rate_ids": []\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/taxRules
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["rule": [
    "calculate_subtotal": false,
    "code": "",
    "customer_tax_class_ids": [],
    "extension_attributes": [],
    "id": 0,
    "position": 0,
    "priority": 0,
    "product_tax_class_ids": [],
    "tax_rate_ids": []
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/taxRules")! 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 taxRules
{{baseUrl}}/V1/taxRules
BODY json

{
  "rule": {
    "calculate_subtotal": false,
    "code": "",
    "customer_tax_class_ids": [],
    "extension_attributes": {},
    "id": 0,
    "position": 0,
    "priority": 0,
    "product_tax_class_ids": [],
    "tax_rate_ids": []
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/taxRules");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/taxRules" {:content-type :json
                                                        :form-params {:rule {:calculate_subtotal false
                                                                             :code ""
                                                                             :customer_tax_class_ids []
                                                                             :extension_attributes {}
                                                                             :id 0
                                                                             :position 0
                                                                             :priority 0
                                                                             :product_tax_class_ids []
                                                                             :tax_rate_ids []}}})
require "http/client"

url = "{{baseUrl}}/V1/taxRules"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\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}}/V1/taxRules"),
    Content = new StringContent("{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\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}}/V1/taxRules");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/taxRules"

	payload := strings.NewReader("{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/taxRules HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 241

{
  "rule": {
    "calculate_subtotal": false,
    "code": "",
    "customer_tax_class_ids": [],
    "extension_attributes": {},
    "id": 0,
    "position": 0,
    "priority": 0,
    "product_tax_class_ids": [],
    "tax_rate_ids": []
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/taxRules")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/taxRules"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\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  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/taxRules")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/taxRules")
  .header("content-type", "application/json")
  .body("{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}")
  .asString();
const data = JSON.stringify({
  rule: {
    calculate_subtotal: false,
    code: '',
    customer_tax_class_ids: [],
    extension_attributes: {},
    id: 0,
    position: 0,
    priority: 0,
    product_tax_class_ids: [],
    tax_rate_ids: []
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/taxRules');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/taxRules',
  headers: {'content-type': 'application/json'},
  data: {
    rule: {
      calculate_subtotal: false,
      code: '',
      customer_tax_class_ids: [],
      extension_attributes: {},
      id: 0,
      position: 0,
      priority: 0,
      product_tax_class_ids: [],
      tax_rate_ids: []
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/taxRules';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"rule":{"calculate_subtotal":false,"code":"","customer_tax_class_ids":[],"extension_attributes":{},"id":0,"position":0,"priority":0,"product_tax_class_ids":[],"tax_rate_ids":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/taxRules',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "rule": {\n    "calculate_subtotal": false,\n    "code": "",\n    "customer_tax_class_ids": [],\n    "extension_attributes": {},\n    "id": 0,\n    "position": 0,\n    "priority": 0,\n    "product_tax_class_ids": [],\n    "tax_rate_ids": []\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  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/taxRules")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/taxRules',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  rule: {
    calculate_subtotal: false,
    code: '',
    customer_tax_class_ids: [],
    extension_attributes: {},
    id: 0,
    position: 0,
    priority: 0,
    product_tax_class_ids: [],
    tax_rate_ids: []
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/taxRules',
  headers: {'content-type': 'application/json'},
  body: {
    rule: {
      calculate_subtotal: false,
      code: '',
      customer_tax_class_ids: [],
      extension_attributes: {},
      id: 0,
      position: 0,
      priority: 0,
      product_tax_class_ids: [],
      tax_rate_ids: []
    }
  },
  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}}/V1/taxRules');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  rule: {
    calculate_subtotal: false,
    code: '',
    customer_tax_class_ids: [],
    extension_attributes: {},
    id: 0,
    position: 0,
    priority: 0,
    product_tax_class_ids: [],
    tax_rate_ids: []
  }
});

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}}/V1/taxRules',
  headers: {'content-type': 'application/json'},
  data: {
    rule: {
      calculate_subtotal: false,
      code: '',
      customer_tax_class_ids: [],
      extension_attributes: {},
      id: 0,
      position: 0,
      priority: 0,
      product_tax_class_ids: [],
      tax_rate_ids: []
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/taxRules';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"rule":{"calculate_subtotal":false,"code":"","customer_tax_class_ids":[],"extension_attributes":{},"id":0,"position":0,"priority":0,"product_tax_class_ids":[],"tax_rate_ids":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"rule": @{ @"calculate_subtotal": @NO, @"code": @"", @"customer_tax_class_ids": @[  ], @"extension_attributes": @{  }, @"id": @0, @"position": @0, @"priority": @0, @"product_tax_class_ids": @[  ], @"tax_rate_ids": @[  ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/taxRules"]
                                                       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}}/V1/taxRules" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/taxRules",
  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([
    'rule' => [
        'calculate_subtotal' => null,
        'code' => '',
        'customer_tax_class_ids' => [
                
        ],
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'position' => 0,
        'priority' => 0,
        'product_tax_class_ids' => [
                
        ],
        'tax_rate_ids' => [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/taxRules', [
  'body' => '{
  "rule": {
    "calculate_subtotal": false,
    "code": "",
    "customer_tax_class_ids": [],
    "extension_attributes": {},
    "id": 0,
    "position": 0,
    "priority": 0,
    "product_tax_class_ids": [],
    "tax_rate_ids": []
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/taxRules');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'rule' => [
    'calculate_subtotal' => null,
    'code' => '',
    'customer_tax_class_ids' => [
        
    ],
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'position' => 0,
    'priority' => 0,
    'product_tax_class_ids' => [
        
    ],
    'tax_rate_ids' => [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'rule' => [
    'calculate_subtotal' => null,
    'code' => '',
    'customer_tax_class_ids' => [
        
    ],
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'position' => 0,
    'priority' => 0,
    'product_tax_class_ids' => [
        
    ],
    'tax_rate_ids' => [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/taxRules');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/taxRules' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "rule": {
    "calculate_subtotal": false,
    "code": "",
    "customer_tax_class_ids": [],
    "extension_attributes": {},
    "id": 0,
    "position": 0,
    "priority": 0,
    "product_tax_class_ids": [],
    "tax_rate_ids": []
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/taxRules' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "rule": {
    "calculate_subtotal": false,
    "code": "",
    "customer_tax_class_ids": [],
    "extension_attributes": {},
    "id": 0,
    "position": 0,
    "priority": 0,
    "product_tax_class_ids": [],
    "tax_rate_ids": []
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/taxRules", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/taxRules"

payload = { "rule": {
        "calculate_subtotal": False,
        "code": "",
        "customer_tax_class_ids": [],
        "extension_attributes": {},
        "id": 0,
        "position": 0,
        "priority": 0,
        "product_tax_class_ids": [],
        "tax_rate_ids": []
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/taxRules"

payload <- "{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/taxRules")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\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/V1/taxRules') do |req|
  req.body = "{\n  \"rule\": {\n    \"calculate_subtotal\": false,\n    \"code\": \"\",\n    \"customer_tax_class_ids\": [],\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"position\": 0,\n    \"priority\": 0,\n    \"product_tax_class_ids\": [],\n    \"tax_rate_ids\": []\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/taxRules";

    let payload = json!({"rule": json!({
            "calculate_subtotal": false,
            "code": "",
            "customer_tax_class_ids": (),
            "extension_attributes": json!({}),
            "id": 0,
            "position": 0,
            "priority": 0,
            "product_tax_class_ids": (),
            "tax_rate_ids": ()
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/taxRules \
  --header 'content-type: application/json' \
  --data '{
  "rule": {
    "calculate_subtotal": false,
    "code": "",
    "customer_tax_class_ids": [],
    "extension_attributes": {},
    "id": 0,
    "position": 0,
    "priority": 0,
    "product_tax_class_ids": [],
    "tax_rate_ids": []
  }
}'
echo '{
  "rule": {
    "calculate_subtotal": false,
    "code": "",
    "customer_tax_class_ids": [],
    "extension_attributes": {},
    "id": 0,
    "position": 0,
    "priority": 0,
    "product_tax_class_ids": [],
    "tax_rate_ids": []
  }
}' |  \
  http POST {{baseUrl}}/V1/taxRules \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "rule": {\n    "calculate_subtotal": false,\n    "code": "",\n    "customer_tax_class_ids": [],\n    "extension_attributes": {},\n    "id": 0,\n    "position": 0,\n    "priority": 0,\n    "product_tax_class_ids": [],\n    "tax_rate_ids": []\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/taxRules
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["rule": [
    "calculate_subtotal": false,
    "code": "",
    "customer_tax_class_ids": [],
    "extension_attributes": [],
    "id": 0,
    "position": 0,
    "priority": 0,
    "product_tax_class_ids": [],
    "tax_rate_ids": []
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/taxRules")! 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 taxRules-{ruleId} (GET)
{{baseUrl}}/V1/taxRules/:ruleId
QUERY PARAMS

ruleId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/taxRules/:ruleId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/taxRules/:ruleId")
require "http/client"

url = "{{baseUrl}}/V1/taxRules/:ruleId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/taxRules/:ruleId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/taxRules/:ruleId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/taxRules/:ruleId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/taxRules/:ruleId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/taxRules/:ruleId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/taxRules/:ruleId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/taxRules/:ruleId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/taxRules/:ruleId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/taxRules/:ruleId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxRules/:ruleId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/taxRules/:ruleId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/taxRules/:ruleId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/taxRules/:ruleId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/taxRules/:ruleId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxRules/:ruleId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/taxRules/:ruleId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxRules/:ruleId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/taxRules/:ruleId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/taxRules/:ruleId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/taxRules/:ruleId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/taxRules/:ruleId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/taxRules/:ruleId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/taxRules/:ruleId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/taxRules/:ruleId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/taxRules/:ruleId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/taxRules/:ruleId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/taxRules/:ruleId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/taxRules/:ruleId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/taxRules/:ruleId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/taxRules/:ruleId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/taxRules/:ruleId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/taxRules/:ruleId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/taxRules/:ruleId
http GET {{baseUrl}}/V1/taxRules/:ruleId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/taxRules/:ruleId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/taxRules/:ruleId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE taxRules-{ruleId}
{{baseUrl}}/V1/taxRules/:ruleId
QUERY PARAMS

ruleId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/taxRules/:ruleId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/taxRules/:ruleId")
require "http/client"

url = "{{baseUrl}}/V1/taxRules/:ruleId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/taxRules/:ruleId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/taxRules/:ruleId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/taxRules/:ruleId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/taxRules/:ruleId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/taxRules/:ruleId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/taxRules/:ruleId"))
    .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}}/V1/taxRules/:ruleId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/taxRules/:ruleId")
  .asString();
const 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}}/V1/taxRules/:ruleId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/taxRules/:ruleId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/taxRules/:ruleId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/taxRules/:ruleId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/taxRules/:ruleId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/taxRules/:ruleId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/taxRules/:ruleId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/taxRules/:ruleId');

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}}/V1/taxRules/:ruleId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/taxRules/:ruleId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/taxRules/:ruleId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/taxRules/:ruleId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/taxRules/:ruleId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/taxRules/:ruleId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/taxRules/:ruleId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/taxRules/:ruleId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/taxRules/:ruleId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/taxRules/:ruleId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/taxRules/:ruleId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/taxRules/:ruleId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/taxRules/:ruleId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/taxRules/:ruleId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/taxRules/:ruleId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/taxRules/:ruleId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/taxRules/:ruleId
http DELETE {{baseUrl}}/V1/taxRules/:ruleId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/taxRules/:ruleId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/taxRules/:ruleId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/taxRules/search");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/taxRules/search")
require "http/client"

url = "{{baseUrl}}/V1/taxRules/search"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/taxRules/search"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/taxRules/search");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/taxRules/search"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/taxRules/search HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/taxRules/search")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/taxRules/search"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/taxRules/search")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/taxRules/search")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/taxRules/search');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxRules/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/taxRules/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/taxRules/search',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/taxRules/search")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/taxRules/search',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxRules/search'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/taxRules/search');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/taxRules/search'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/taxRules/search';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/taxRules/search"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/taxRules/search" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/taxRules/search",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/taxRules/search');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/taxRules/search');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/taxRules/search');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/taxRules/search' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/taxRules/search' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/taxRules/search")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/taxRules/search"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/taxRules/search"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/taxRules/search")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/taxRules/search') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/taxRules/search";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/taxRules/search
http GET {{baseUrl}}/V1/taxRules/search
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/taxRules/search
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/taxRules/search")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET team-
{{baseUrl}}/V1/team/
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/team/");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/team/")
require "http/client"

url = "{{baseUrl}}/V1/team/"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/team/"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/team/");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/team/"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/team/ HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/team/")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/team/"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/team/")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/team/")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/team/');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/team/'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/team/';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/team/',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/team/")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/team/',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/team/'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/team/');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/team/'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/team/';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/team/"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/team/" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/team/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/team/');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/team/');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/team/');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/team/' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/team/' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/team/")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/team/"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/team/"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/team/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/team/') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/team/";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/team/
http GET {{baseUrl}}/V1/team/
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/team/
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/team/")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST team-{companyId}
{{baseUrl}}/V1/team/:companyId
QUERY PARAMS

companyId
BODY json

{
  "team": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "name": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/team/:companyId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/team/:companyId" {:content-type :json
                                                               :form-params {:team {:custom_attributes [{:attribute_code ""
                                                                                                         :value ""}]
                                                                                    :description ""
                                                                                    :extension_attributes {}
                                                                                    :id 0
                                                                                    :name ""}}})
require "http/client"

url = "{{baseUrl}}/V1/team/:companyId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\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}}/V1/team/:companyId"),
    Content = new StringContent("{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\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}}/V1/team/:companyId");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/team/:companyId"

	payload := strings.NewReader("{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/team/:companyId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 202

{
  "team": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "name": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/team/:companyId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/team/:companyId"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\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  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/team/:companyId")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/team/:companyId")
  .header("content-type", "application/json")
  .body("{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  team: {
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    description: '',
    extension_attributes: {},
    id: 0,
    name: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/team/:companyId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/team/:companyId',
  headers: {'content-type': 'application/json'},
  data: {
    team: {
      custom_attributes: [{attribute_code: '', value: ''}],
      description: '',
      extension_attributes: {},
      id: 0,
      name: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/team/:companyId';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"team":{"custom_attributes":[{"attribute_code":"","value":""}],"description":"","extension_attributes":{},"id":0,"name":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/team/:companyId',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "team": {\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "description": "",\n    "extension_attributes": {},\n    "id": 0,\n    "name": ""\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  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/team/:companyId")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/team/:companyId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  team: {
    custom_attributes: [{attribute_code: '', value: ''}],
    description: '',
    extension_attributes: {},
    id: 0,
    name: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/team/:companyId',
  headers: {'content-type': 'application/json'},
  body: {
    team: {
      custom_attributes: [{attribute_code: '', value: ''}],
      description: '',
      extension_attributes: {},
      id: 0,
      name: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/team/:companyId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  team: {
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    description: '',
    extension_attributes: {},
    id: 0,
    name: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/team/:companyId',
  headers: {'content-type': 'application/json'},
  data: {
    team: {
      custom_attributes: [{attribute_code: '', value: ''}],
      description: '',
      extension_attributes: {},
      id: 0,
      name: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/team/:companyId';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"team":{"custom_attributes":[{"attribute_code":"","value":""}],"description":"","extension_attributes":{},"id":0,"name":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"team": @{ @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"description": @"", @"extension_attributes": @{  }, @"id": @0, @"name": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/team/:companyId"]
                                                       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}}/V1/team/:companyId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/team/:companyId",
  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([
    'team' => [
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'description' => '',
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'name' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/team/:companyId', [
  'body' => '{
  "team": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "name": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/team/:companyId');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'team' => [
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'description' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'name' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'team' => [
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'description' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'name' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/team/:companyId');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/team/:companyId' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "team": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "name": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/team/:companyId' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "team": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "name": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/team/:companyId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/team/:companyId"

payload = { "team": {
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "description": "",
        "extension_attributes": {},
        "id": 0,
        "name": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/team/:companyId"

payload <- "{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/team/:companyId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\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/V1/team/:companyId') do |req|
  req.body = "{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/team/:companyId";

    let payload = json!({"team": json!({
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "description": "",
            "extension_attributes": json!({}),
            "id": 0,
            "name": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/team/:companyId \
  --header 'content-type: application/json' \
  --data '{
  "team": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "name": ""
  }
}'
echo '{
  "team": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "name": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/team/:companyId \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "team": {\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "description": "",\n    "extension_attributes": {},\n    "id": 0,\n    "name": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/team/:companyId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["team": [
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "description": "",
    "extension_attributes": [],
    "id": 0,
    "name": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/team/:companyId")! 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 team-{teamId} (GET)
{{baseUrl}}/V1/team/:teamId
QUERY PARAMS

teamId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/team/:teamId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/team/:teamId")
require "http/client"

url = "{{baseUrl}}/V1/team/:teamId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/team/:teamId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/team/:teamId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/team/:teamId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/team/:teamId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/team/:teamId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/team/:teamId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/team/:teamId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/team/:teamId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/team/:teamId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/team/:teamId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/team/:teamId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/team/:teamId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/team/:teamId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/team/:teamId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/team/:teamId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/team/:teamId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/team/:teamId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/team/:teamId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/team/:teamId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/team/:teamId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/team/:teamId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/team/:teamId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/team/:teamId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/team/:teamId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/team/:teamId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/team/:teamId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/team/:teamId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/team/:teamId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/team/:teamId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/team/:teamId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/team/:teamId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/team/:teamId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/team/:teamId
http GET {{baseUrl}}/V1/team/:teamId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/team/:teamId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/team/:teamId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT team-{teamId} (PUT)
{{baseUrl}}/V1/team/:teamId
QUERY PARAMS

teamId
BODY json

{
  "team": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "name": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/team/:teamId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/team/:teamId" {:content-type :json
                                                           :form-params {:team {:custom_attributes [{:attribute_code ""
                                                                                                     :value ""}]
                                                                                :description ""
                                                                                :extension_attributes {}
                                                                                :id 0
                                                                                :name ""}}})
require "http/client"

url = "{{baseUrl}}/V1/team/:teamId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\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}}/V1/team/:teamId"),
    Content = new StringContent("{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\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}}/V1/team/:teamId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/team/:teamId"

	payload := strings.NewReader("{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/team/:teamId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 202

{
  "team": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "name": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/team/:teamId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/team/:teamId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\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  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/team/:teamId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/team/:teamId")
  .header("content-type", "application/json")
  .body("{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  team: {
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    description: '',
    extension_attributes: {},
    id: 0,
    name: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/team/:teamId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/team/:teamId',
  headers: {'content-type': 'application/json'},
  data: {
    team: {
      custom_attributes: [{attribute_code: '', value: ''}],
      description: '',
      extension_attributes: {},
      id: 0,
      name: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/team/:teamId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"team":{"custom_attributes":[{"attribute_code":"","value":""}],"description":"","extension_attributes":{},"id":0,"name":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/team/:teamId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "team": {\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "description": "",\n    "extension_attributes": {},\n    "id": 0,\n    "name": ""\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  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/team/:teamId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/team/:teamId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  team: {
    custom_attributes: [{attribute_code: '', value: ''}],
    description: '',
    extension_attributes: {},
    id: 0,
    name: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/team/:teamId',
  headers: {'content-type': 'application/json'},
  body: {
    team: {
      custom_attributes: [{attribute_code: '', value: ''}],
      description: '',
      extension_attributes: {},
      id: 0,
      name: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/V1/team/:teamId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  team: {
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    description: '',
    extension_attributes: {},
    id: 0,
    name: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/team/:teamId',
  headers: {'content-type': 'application/json'},
  data: {
    team: {
      custom_attributes: [{attribute_code: '', value: ''}],
      description: '',
      extension_attributes: {},
      id: 0,
      name: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/team/:teamId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"team":{"custom_attributes":[{"attribute_code":"","value":""}],"description":"","extension_attributes":{},"id":0,"name":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"team": @{ @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"description": @"", @"extension_attributes": @{  }, @"id": @0, @"name": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/team/:teamId"]
                                                       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}}/V1/team/:teamId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/team/:teamId",
  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([
    'team' => [
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'description' => '',
        'extension_attributes' => [
                
        ],
        'id' => 0,
        'name' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/team/:teamId', [
  'body' => '{
  "team": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "name": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/team/:teamId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'team' => [
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'description' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'name' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'team' => [
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'description' => '',
    'extension_attributes' => [
        
    ],
    'id' => 0,
    'name' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/team/:teamId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/team/:teamId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "team": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "name": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/team/:teamId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "team": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "name": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/team/:teamId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/team/:teamId"

payload = { "team": {
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "description": "",
        "extension_attributes": {},
        "id": 0,
        "name": ""
    } }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/team/:teamId"

payload <- "{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/team/:teamId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\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/V1/team/:teamId') do |req|
  req.body = "{\n  \"team\": {\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"description\": \"\",\n    \"extension_attributes\": {},\n    \"id\": 0,\n    \"name\": \"\"\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}}/V1/team/:teamId";

    let payload = json!({"team": json!({
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "description": "",
            "extension_attributes": json!({}),
            "id": 0,
            "name": ""
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/team/:teamId \
  --header 'content-type: application/json' \
  --data '{
  "team": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "name": ""
  }
}'
echo '{
  "team": {
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "description": "",
    "extension_attributes": {},
    "id": 0,
    "name": ""
  }
}' |  \
  http PUT {{baseUrl}}/V1/team/:teamId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "team": {\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "description": "",\n    "extension_attributes": {},\n    "id": 0,\n    "name": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/team/:teamId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["team": [
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "description": "",
    "extension_attributes": [],
    "id": 0,
    "name": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/team/:teamId")! 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()
DELETE team-{teamId}
{{baseUrl}}/V1/team/:teamId
QUERY PARAMS

teamId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/team/:teamId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/V1/team/:teamId")
require "http/client"

url = "{{baseUrl}}/V1/team/:teamId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/V1/team/:teamId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/team/:teamId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/team/:teamId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/V1/team/:teamId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/V1/team/:teamId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/team/:teamId"))
    .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}}/V1/team/:teamId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/V1/team/:teamId")
  .asString();
const 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}}/V1/team/:teamId');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/team/:teamId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/team/:teamId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/team/:teamId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/team/:teamId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/team/:teamId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/V1/team/:teamId'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/V1/team/:teamId');

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}}/V1/team/:teamId'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/team/:teamId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/team/:teamId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/team/:teamId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/team/:teamId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/V1/team/:teamId');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/team/:teamId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/team/:teamId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/team/:teamId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/team/:teamId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/V1/team/:teamId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/team/:teamId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/team/:teamId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/team/:teamId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/V1/team/:teamId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/team/:teamId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/V1/team/:teamId
http DELETE {{baseUrl}}/V1/team/:teamId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/V1/team/:teamId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/team/:teamId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT temando-rma-{rmaId}-shipments
{{baseUrl}}/V1/temando/rma/:rmaId/shipments
QUERY PARAMS

rmaId
BODY json

{
  "returnShipmentIds": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/temando/rma/:rmaId/shipments");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"returnShipmentIds\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/V1/temando/rma/:rmaId/shipments" {:content-type :json
                                                                           :form-params {:returnShipmentIds []}})
require "http/client"

url = "{{baseUrl}}/V1/temando/rma/:rmaId/shipments"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"returnShipmentIds\": []\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}}/V1/temando/rma/:rmaId/shipments"),
    Content = new StringContent("{\n  \"returnShipmentIds\": []\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}}/V1/temando/rma/:rmaId/shipments");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"returnShipmentIds\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/temando/rma/:rmaId/shipments"

	payload := strings.NewReader("{\n  \"returnShipmentIds\": []\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/V1/temando/rma/:rmaId/shipments HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 29

{
  "returnShipmentIds": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/V1/temando/rma/:rmaId/shipments")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"returnShipmentIds\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/temando/rma/:rmaId/shipments"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"returnShipmentIds\": []\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  \"returnShipmentIds\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/temando/rma/:rmaId/shipments")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/V1/temando/rma/:rmaId/shipments")
  .header("content-type", "application/json")
  .body("{\n  \"returnShipmentIds\": []\n}")
  .asString();
const data = JSON.stringify({
  returnShipmentIds: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/V1/temando/rma/:rmaId/shipments');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/temando/rma/:rmaId/shipments',
  headers: {'content-type': 'application/json'},
  data: {returnShipmentIds: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/temando/rma/:rmaId/shipments';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"returnShipmentIds":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/temando/rma/:rmaId/shipments',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "returnShipmentIds": []\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"returnShipmentIds\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/temando/rma/:rmaId/shipments")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/temando/rma/:rmaId/shipments',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({returnShipmentIds: []}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/V1/temando/rma/:rmaId/shipments',
  headers: {'content-type': 'application/json'},
  body: {returnShipmentIds: []},
  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}}/V1/temando/rma/:rmaId/shipments');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  returnShipmentIds: []
});

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}}/V1/temando/rma/:rmaId/shipments',
  headers: {'content-type': 'application/json'},
  data: {returnShipmentIds: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/temando/rma/:rmaId/shipments';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"returnShipmentIds":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"returnShipmentIds": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/temando/rma/:rmaId/shipments"]
                                                       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}}/V1/temando/rma/:rmaId/shipments" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"returnShipmentIds\": []\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/temando/rma/:rmaId/shipments",
  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([
    'returnShipmentIds' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/V1/temando/rma/:rmaId/shipments', [
  'body' => '{
  "returnShipmentIds": []
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/temando/rma/:rmaId/shipments');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'returnShipmentIds' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'returnShipmentIds' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/temando/rma/:rmaId/shipments');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/temando/rma/:rmaId/shipments' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "returnShipmentIds": []
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/temando/rma/:rmaId/shipments' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "returnShipmentIds": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"returnShipmentIds\": []\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/V1/temando/rma/:rmaId/shipments", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/temando/rma/:rmaId/shipments"

payload = { "returnShipmentIds": [] }
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/temando/rma/:rmaId/shipments"

payload <- "{\n  \"returnShipmentIds\": []\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/temando/rma/:rmaId/shipments")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"returnShipmentIds\": []\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/V1/temando/rma/:rmaId/shipments') do |req|
  req.body = "{\n  \"returnShipmentIds\": []\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}}/V1/temando/rma/:rmaId/shipments";

    let payload = json!({"returnShipmentIds": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/V1/temando/rma/:rmaId/shipments \
  --header 'content-type: application/json' \
  --data '{
  "returnShipmentIds": []
}'
echo '{
  "returnShipmentIds": []
}' |  \
  http PUT {{baseUrl}}/V1/temando/rma/:rmaId/shipments \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "returnShipmentIds": []\n}' \
  --output-document \
  - {{baseUrl}}/V1/temando/rma/:rmaId/shipments
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["returnShipmentIds": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/temando/rma/:rmaId/shipments")! 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 transactions
{{baseUrl}}/V1/transactions
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/transactions");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/transactions")
require "http/client"

url = "{{baseUrl}}/V1/transactions"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/transactions"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/transactions");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/transactions"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/transactions HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/transactions")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/transactions"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/transactions")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/transactions")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/transactions');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/transactions'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/transactions';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/transactions',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/transactions")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/transactions',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/transactions'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/transactions');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/transactions'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/transactions';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/transactions"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/transactions" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/transactions",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/transactions');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/transactions');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/transactions');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/transactions' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/transactions' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/transactions")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/transactions"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/transactions"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/transactions")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/transactions') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/transactions";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/transactions
http GET {{baseUrl}}/V1/transactions
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/transactions
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/transactions")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET transactions-{id}
{{baseUrl}}/V1/transactions/:id
QUERY PARAMS

id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/transactions/:id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/V1/transactions/:id")
require "http/client"

url = "{{baseUrl}}/V1/transactions/:id"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/V1/transactions/:id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/V1/transactions/:id");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/transactions/:id"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/V1/transactions/:id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/V1/transactions/:id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/transactions/:id"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/transactions/:id")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/V1/transactions/:id")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/V1/transactions/:id');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/V1/transactions/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/transactions/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/transactions/:id',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/V1/transactions/:id")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/transactions/:id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/V1/transactions/:id'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/V1/transactions/:id');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/V1/transactions/:id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/transactions/:id';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/transactions/:id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/V1/transactions/:id" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/transactions/:id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/V1/transactions/:id');

echo $response->getBody();
setUrl('{{baseUrl}}/V1/transactions/:id');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/V1/transactions/:id');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/transactions/:id' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/transactions/:id' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/V1/transactions/:id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/transactions/:id"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/transactions/:id"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/transactions/:id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/V1/transactions/:id') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/transactions/:id";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/V1/transactions/:id
http GET {{baseUrl}}/V1/transactions/:id
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/V1/transactions/:id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/transactions/:id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST worldpay-guest-carts-{cartId}-payment-information
{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information
QUERY PARAMS

cartId
BODY json

{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information" {:content-type :json
                                                                                                :form-params {:billingAddress {:city ""
                                                                                                                               :company ""
                                                                                                                               :country_id ""
                                                                                                                               :custom_attributes [{:attribute_code ""
                                                                                                                                                    :value ""}]
                                                                                                                               :customer_address_id 0
                                                                                                                               :customer_id 0
                                                                                                                               :email ""
                                                                                                                               :extension_attributes {:checkout_fields [{}]
                                                                                                                                                      :gift_registry_id 0}
                                                                                                                               :fax ""
                                                                                                                               :firstname ""
                                                                                                                               :id 0
                                                                                                                               :lastname ""
                                                                                                                               :middlename ""
                                                                                                                               :postcode ""
                                                                                                                               :prefix ""
                                                                                                                               :region ""
                                                                                                                               :region_code ""
                                                                                                                               :region_id 0
                                                                                                                               :same_as_billing 0
                                                                                                                               :save_in_address_book 0
                                                                                                                               :street []
                                                                                                                               :suffix ""
                                                                                                                               :telephone ""
                                                                                                                               :vat_id ""}
                                                                                                              :email ""
                                                                                                              :paymentMethod {:additional_data []
                                                                                                                              :extension_attributes {:agreement_ids []}
                                                                                                                              :method ""
                                                                                                                              :po_number ""}}})
require "http/client"

url = "{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/worldpay-guest-carts/:cartId/payment-information"),
    Content = new StringContent("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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}}/V1/worldpay-guest-carts/:cartId/payment-information");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information"

	payload := strings.NewReader("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/V1/worldpay-guest-carts/:cartId/payment-information HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 857

{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information")
  .header("content-type", "application/json")
  .body("{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  email: '',
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information',
  headers: {'content-type': 'application/json'},
  data: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    email: '',
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"billingAddress":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"email":"","paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "billingAddress": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "email": "",\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\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  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/V1/worldpay-guest-carts/:cartId/payment-information',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [{attribute_code: '', value: ''}],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  email: '',
  paymentMethod: {
    additional_data: [],
    extension_attributes: {agreement_ids: []},
    method: '',
    po_number: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information',
  headers: {'content-type': 'application/json'},
  body: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    email: '',
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  billingAddress: {
    city: '',
    company: '',
    country_id: '',
    custom_attributes: [
      {
        attribute_code: '',
        value: ''
      }
    ],
    customer_address_id: 0,
    customer_id: 0,
    email: '',
    extension_attributes: {
      checkout_fields: [
        {}
      ],
      gift_registry_id: 0
    },
    fax: '',
    firstname: '',
    id: 0,
    lastname: '',
    middlename: '',
    postcode: '',
    prefix: '',
    region: '',
    region_code: '',
    region_id: 0,
    same_as_billing: 0,
    save_in_address_book: 0,
    street: [],
    suffix: '',
    telephone: '',
    vat_id: ''
  },
  email: '',
  paymentMethod: {
    additional_data: [],
    extension_attributes: {
      agreement_ids: []
    },
    method: '',
    po_number: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information',
  headers: {'content-type': 'application/json'},
  data: {
    billingAddress: {
      city: '',
      company: '',
      country_id: '',
      custom_attributes: [{attribute_code: '', value: ''}],
      customer_address_id: 0,
      customer_id: 0,
      email: '',
      extension_attributes: {checkout_fields: [{}], gift_registry_id: 0},
      fax: '',
      firstname: '',
      id: 0,
      lastname: '',
      middlename: '',
      postcode: '',
      prefix: '',
      region: '',
      region_code: '',
      region_id: 0,
      same_as_billing: 0,
      save_in_address_book: 0,
      street: [],
      suffix: '',
      telephone: '',
      vat_id: ''
    },
    email: '',
    paymentMethod: {
      additional_data: [],
      extension_attributes: {agreement_ids: []},
      method: '',
      po_number: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"billingAddress":{"city":"","company":"","country_id":"","custom_attributes":[{"attribute_code":"","value":""}],"customer_address_id":0,"customer_id":0,"email":"","extension_attributes":{"checkout_fields":[{}],"gift_registry_id":0},"fax":"","firstname":"","id":0,"lastname":"","middlename":"","postcode":"","prefix":"","region":"","region_code":"","region_id":0,"same_as_billing":0,"save_in_address_book":0,"street":[],"suffix":"","telephone":"","vat_id":""},"email":"","paymentMethod":{"additional_data":[],"extension_attributes":{"agreement_ids":[]},"method":"","po_number":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"billingAddress": @{ @"city": @"", @"company": @"", @"country_id": @"", @"custom_attributes": @[ @{ @"attribute_code": @"", @"value": @"" } ], @"customer_address_id": @0, @"customer_id": @0, @"email": @"", @"extension_attributes": @{ @"checkout_fields": @[ @{  } ], @"gift_registry_id": @0 }, @"fax": @"", @"firstname": @"", @"id": @0, @"lastname": @"", @"middlename": @"", @"postcode": @"", @"prefix": @"", @"region": @"", @"region_code": @"", @"region_id": @0, @"same_as_billing": @0, @"save_in_address_book": @0, @"street": @[  ], @"suffix": @"", @"telephone": @"", @"vat_id": @"" },
                              @"email": @"",
                              @"paymentMethod": @{ @"additional_data": @[  ], @"extension_attributes": @{ @"agreement_ids": @[  ] }, @"method": @"", @"po_number": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information"]
                                                       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}}/V1/worldpay-guest-carts/:cartId/payment-information" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information",
  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([
    'billingAddress' => [
        'city' => '',
        'company' => '',
        'country_id' => '',
        'custom_attributes' => [
                [
                                'attribute_code' => '',
                                'value' => ''
                ]
        ],
        'customer_address_id' => 0,
        'customer_id' => 0,
        'email' => '',
        'extension_attributes' => [
                'checkout_fields' => [
                                [
                                                                
                                ]
                ],
                'gift_registry_id' => 0
        ],
        'fax' => '',
        'firstname' => '',
        'id' => 0,
        'lastname' => '',
        'middlename' => '',
        'postcode' => '',
        'prefix' => '',
        'region' => '',
        'region_code' => '',
        'region_id' => 0,
        'same_as_billing' => 0,
        'save_in_address_book' => 0,
        'street' => [
                
        ],
        'suffix' => '',
        'telephone' => '',
        'vat_id' => ''
    ],
    'email' => '',
    'paymentMethod' => [
        'additional_data' => [
                
        ],
        'extension_attributes' => [
                'agreement_ids' => [
                                
                ]
        ],
        'method' => '',
        'po_number' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information', [
  'body' => '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'billingAddress' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'email' => '',
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'billingAddress' => [
    'city' => '',
    'company' => '',
    'country_id' => '',
    'custom_attributes' => [
        [
                'attribute_code' => '',
                'value' => ''
        ]
    ],
    'customer_address_id' => 0,
    'customer_id' => 0,
    'email' => '',
    'extension_attributes' => [
        'checkout_fields' => [
                [
                                
                ]
        ],
        'gift_registry_id' => 0
    ],
    'fax' => '',
    'firstname' => '',
    'id' => 0,
    'lastname' => '',
    'middlename' => '',
    'postcode' => '',
    'prefix' => '',
    'region' => '',
    'region_code' => '',
    'region_id' => 0,
    'same_as_billing' => 0,
    'save_in_address_book' => 0,
    'street' => [
        
    ],
    'suffix' => '',
    'telephone' => '',
    'vat_id' => ''
  ],
  'email' => '',
  'paymentMethod' => [
    'additional_data' => [
        
    ],
    'extension_attributes' => [
        'agreement_ids' => [
                
        ]
    ],
    'method' => '',
    'po_number' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/V1/worldpay-guest-carts/:cartId/payment-information", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information"

payload = {
    "billingAddress": {
        "city": "",
        "company": "",
        "country_id": "",
        "custom_attributes": [
            {
                "attribute_code": "",
                "value": ""
            }
        ],
        "customer_address_id": 0,
        "customer_id": 0,
        "email": "",
        "extension_attributes": {
            "checkout_fields": [{}],
            "gift_registry_id": 0
        },
        "fax": "",
        "firstname": "",
        "id": 0,
        "lastname": "",
        "middlename": "",
        "postcode": "",
        "prefix": "",
        "region": "",
        "region_code": "",
        "region_id": 0,
        "same_as_billing": 0,
        "save_in_address_book": 0,
        "street": [],
        "suffix": "",
        "telephone": "",
        "vat_id": ""
    },
    "email": "",
    "paymentMethod": {
        "additional_data": [],
        "extension_attributes": { "agreement_ids": [] },
        "method": "",
        "po_number": ""
    }
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information"

payload <- "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\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/V1/worldpay-guest-carts/:cartId/payment-information') do |req|
  req.body = "{\n  \"billingAddress\": {\n    \"city\": \"\",\n    \"company\": \"\",\n    \"country_id\": \"\",\n    \"custom_attributes\": [\n      {\n        \"attribute_code\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"customer_address_id\": 0,\n    \"customer_id\": 0,\n    \"email\": \"\",\n    \"extension_attributes\": {\n      \"checkout_fields\": [\n        {}\n      ],\n      \"gift_registry_id\": 0\n    },\n    \"fax\": \"\",\n    \"firstname\": \"\",\n    \"id\": 0,\n    \"lastname\": \"\",\n    \"middlename\": \"\",\n    \"postcode\": \"\",\n    \"prefix\": \"\",\n    \"region\": \"\",\n    \"region_code\": \"\",\n    \"region_id\": 0,\n    \"same_as_billing\": 0,\n    \"save_in_address_book\": 0,\n    \"street\": [],\n    \"suffix\": \"\",\n    \"telephone\": \"\",\n    \"vat_id\": \"\"\n  },\n  \"email\": \"\",\n  \"paymentMethod\": {\n    \"additional_data\": [],\n    \"extension_attributes\": {\n      \"agreement_ids\": []\n    },\n    \"method\": \"\",\n    \"po_number\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information";

    let payload = json!({
        "billingAddress": json!({
            "city": "",
            "company": "",
            "country_id": "",
            "custom_attributes": (
                json!({
                    "attribute_code": "",
                    "value": ""
                })
            ),
            "customer_address_id": 0,
            "customer_id": 0,
            "email": "",
            "extension_attributes": json!({
                "checkout_fields": (json!({})),
                "gift_registry_id": 0
            }),
            "fax": "",
            "firstname": "",
            "id": 0,
            "lastname": "",
            "middlename": "",
            "postcode": "",
            "prefix": "",
            "region": "",
            "region_code": "",
            "region_id": 0,
            "same_as_billing": 0,
            "save_in_address_book": 0,
            "street": (),
            "suffix": "",
            "telephone": "",
            "vat_id": ""
        }),
        "email": "",
        "paymentMethod": json!({
            "additional_data": (),
            "extension_attributes": json!({"agreement_ids": ()}),
            "method": "",
            "po_number": ""
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information \
  --header 'content-type: application/json' \
  --data '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}'
echo '{
  "billingAddress": {
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      {
        "attribute_code": "",
        "value": ""
      }
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": {
      "checkout_fields": [
        {}
      ],
      "gift_registry_id": 0
    },
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  },
  "email": "",
  "paymentMethod": {
    "additional_data": [],
    "extension_attributes": {
      "agreement_ids": []
    },
    "method": "",
    "po_number": ""
  }
}' |  \
  http POST {{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "billingAddress": {\n    "city": "",\n    "company": "",\n    "country_id": "",\n    "custom_attributes": [\n      {\n        "attribute_code": "",\n        "value": ""\n      }\n    ],\n    "customer_address_id": 0,\n    "customer_id": 0,\n    "email": "",\n    "extension_attributes": {\n      "checkout_fields": [\n        {}\n      ],\n      "gift_registry_id": 0\n    },\n    "fax": "",\n    "firstname": "",\n    "id": 0,\n    "lastname": "",\n    "middlename": "",\n    "postcode": "",\n    "prefix": "",\n    "region": "",\n    "region_code": "",\n    "region_id": 0,\n    "same_as_billing": 0,\n    "save_in_address_book": 0,\n    "street": [],\n    "suffix": "",\n    "telephone": "",\n    "vat_id": ""\n  },\n  "email": "",\n  "paymentMethod": {\n    "additional_data": [],\n    "extension_attributes": {\n      "agreement_ids": []\n    },\n    "method": "",\n    "po_number": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "billingAddress": [
    "city": "",
    "company": "",
    "country_id": "",
    "custom_attributes": [
      [
        "attribute_code": "",
        "value": ""
      ]
    ],
    "customer_address_id": 0,
    "customer_id": 0,
    "email": "",
    "extension_attributes": [
      "checkout_fields": [[]],
      "gift_registry_id": 0
    ],
    "fax": "",
    "firstname": "",
    "id": 0,
    "lastname": "",
    "middlename": "",
    "postcode": "",
    "prefix": "",
    "region": "",
    "region_code": "",
    "region_id": 0,
    "same_as_billing": 0,
    "save_in_address_book": 0,
    "street": [],
    "suffix": "",
    "telephone": "",
    "vat_id": ""
  ],
  "email": "",
  "paymentMethod": [
    "additional_data": [],
    "extension_attributes": ["agreement_ids": []],
    "method": "",
    "po_number": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/V1/worldpay-guest-carts/:cartId/payment-information")! 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()